├── .clabot ├── .dockerignore ├── .github ├── ISSUE_TEMPLATE │ ├── bug_report.md │ └── feature_request.md ├── codeql │ └── codeql-config.yml └── workflows │ ├── arbitrator-ci.yml │ ├── arbitrator-skip-ci.yml │ ├── ci.yml │ ├── codeql-analysis.yml │ ├── docker.yml │ ├── release-ci.yml │ └── waitForNitro.sh ├── .gitignore ├── .gitmodules ├── .golangci.yml ├── .nitro-tag.txt ├── Dockerfile ├── LICENSE.md ├── Makefile ├── README.md ├── arbcompress ├── compress_common.go ├── compress_test.go ├── native.go └── wasm.go ├── arbitrator ├── .gitignore ├── Cargo.lock ├── Cargo.toml ├── arbutil │ ├── Cargo.toml │ └── src │ │ ├── color.rs │ │ ├── crypto.rs │ │ ├── evm │ │ ├── api.rs │ │ ├── mod.rs │ │ ├── req.rs │ │ ├── storage.rs │ │ └── user.rs │ │ ├── format.rs │ │ ├── lib.rs │ │ ├── math.rs │ │ ├── operator.rs │ │ ├── pricing.rs │ │ └── types.rs ├── brotli │ ├── Cargo.toml │ ├── build.rs │ ├── fuzz │ │ ├── .gitignore │ │ ├── Cargo.toml │ │ ├── README │ │ └── fuzz_targets │ │ │ ├── compress.rs │ │ │ ├── decompress.rs │ │ │ └── round_trip.rs │ └── src │ │ ├── cgo.rs │ │ ├── dicts │ │ ├── mod.rs │ │ └── stylus-program-11.lz │ │ ├── lib.rs │ │ ├── types.rs │ │ └── wasmer_traits.rs ├── caller-env │ ├── Cargo.toml │ └── src │ │ ├── brotli │ │ └── mod.rs │ │ ├── guest_ptr.rs │ │ ├── lib.rs │ │ ├── static_caller.rs │ │ ├── wasip1_stub.rs │ │ └── wasmer_traits.rs ├── jit │ ├── .gitignore │ ├── Cargo.lock │ ├── Cargo.toml │ ├── programs │ │ ├── print │ │ │ └── main.go │ │ ├── pure │ │ │ └── main.wat │ │ └── time │ │ │ └── main.go │ └── src │ │ ├── arbcompress.rs │ │ ├── caller_env.rs │ │ ├── machine.rs │ │ ├── main.rs │ │ ├── program.rs │ │ ├── socket.rs │ │ ├── stylus_backend.rs │ │ ├── test.rs │ │ ├── wasip1_stub.rs │ │ └── wavmio.rs ├── prover │ ├── Cargo.toml │ ├── fuzz │ │ ├── .gitignore │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── fuzz_targets │ │ │ └── osp.rs │ ├── src │ │ ├── binary.rs │ │ ├── bulk_memory.wat │ │ ├── host.rs │ │ ├── kzg-trusted-setup.json │ │ ├── kzg.rs │ │ ├── lib.rs │ │ ├── machine.rs │ │ ├── main.rs │ │ ├── memory.rs │ │ ├── merkle.rs │ │ ├── print.rs │ │ ├── programs │ │ │ ├── config.rs │ │ │ ├── counter.rs │ │ │ ├── depth.rs │ │ │ ├── dynamic.rs │ │ │ ├── heap.rs │ │ │ ├── memory.rs │ │ │ ├── meter.rs │ │ │ ├── mod.rs │ │ │ ├── prelude.rs │ │ │ └── start.rs │ │ ├── reinterpret.rs │ │ ├── test.rs │ │ ├── utils.rs │ │ ├── value.rs │ │ └── wavm.rs │ └── test-cases │ │ ├── block.wat │ │ ├── bulk-memory.wat │ │ ├── call-indirect.wat │ │ ├── call.wat │ │ ├── const.wat │ │ ├── div-overflow.wat │ │ ├── dynamic.wat │ │ ├── float32.wat │ │ ├── float64.wat │ │ ├── forward-test.wat │ │ ├── forward │ │ ├── forward.wat │ │ └── target.wat │ │ ├── global-state-wavm.wat │ │ ├── global-state-wrapper.wat │ │ ├── global-state.wat │ │ ├── globals.wat │ │ ├── go │ │ └── main.go │ │ ├── if-else.wat │ │ ├── iops.wat │ │ ├── link.txt │ │ ├── link.wat │ │ ├── locals.wat │ │ ├── loop.wat │ │ ├── math.wat │ │ ├── memory-grow.wat │ │ ├── memory.wat │ │ ├── no-stack-pollution.wat │ │ ├── read-inboxmsg-10.wat │ │ ├── return.wat │ │ ├── rust │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ ├── data │ │ │ ├── msg0.bin │ │ │ └── msg1.bin │ │ └── src │ │ │ ├── bin │ │ │ ├── basics.rs │ │ │ ├── globalstate.rs │ │ │ ├── host-io.rs │ │ │ ├── keccak256.rs │ │ │ ├── pi.rs │ │ │ └── stdlib.rs │ │ │ └── lib.rs │ │ └── user.wat ├── stylus │ ├── Cargo.toml │ ├── cbindgen.toml │ ├── src │ │ ├── benchmarks.rs │ │ ├── cache.rs │ │ ├── env.rs │ │ ├── evm_api.rs │ │ ├── host.rs │ │ ├── lib.rs │ │ ├── native.rs │ │ ├── run.rs │ │ ├── test │ │ │ ├── api.rs │ │ │ ├── misc.rs │ │ │ ├── mod.rs │ │ │ ├── native.rs │ │ │ ├── sdk.rs │ │ │ ├── timings.rs │ │ │ └── wavm.rs │ │ └── util.rs │ └── tests │ │ ├── .cargo │ │ └── config.toml │ │ ├── add.wat │ │ ├── bad-mods │ │ ├── bad-export.wat │ │ ├── bad-export2.wat │ │ ├── bad-export3.wat │ │ ├── bad-export4.wat │ │ └── bad-import.wat │ │ ├── bf │ │ ├── .gitignore │ │ └── cat.b │ │ ├── bulk-memory-oob.wat │ │ ├── clz.wat │ │ ├── console.wat │ │ ├── create │ │ ├── .cargo │ │ │ └── config │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── depth.wat │ │ ├── erc20 │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ ├── erc20.rs │ │ │ └── main.rs │ │ ├── evm-data │ │ ├── .cargo │ │ │ └── config │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── exit-early │ │ ├── exit-early.wat │ │ └── panic-after-write.wat │ │ ├── fallible │ │ ├── .cargo │ │ │ └── config │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── grow │ │ ├── fixed.wat │ │ ├── grow-120.wat │ │ ├── grow-and-call.wat │ │ └── mem-write.wat │ │ ├── keccak-100 │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── keccak │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── log │ │ ├── .cargo │ │ │ └── config │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── math │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── memory.wat │ │ ├── memory2.wat │ │ ├── module-mod.wat │ │ ├── multicall │ │ ├── .cargo │ │ │ └── config │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── read-return-data │ │ ├── .cargo │ │ │ └── config │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── sdk-storage │ │ ├── .cargo │ │ │ └── config │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── start.wat │ │ ├── storage │ │ ├── .cargo │ │ │ └── config │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ │ ├── test.wat │ │ └── timings │ │ ├── Cargo.lock │ │ ├── block_basefee.wat │ │ ├── block_coinbase.wat │ │ ├── block_gas_limit.wat │ │ ├── block_number.wat │ │ ├── block_timestamp.wat │ │ ├── chainid.wat │ │ ├── contract_address.wat │ │ ├── evm_gas_left.wat │ │ ├── evm_ink_left.wat │ │ ├── keccak.wat │ │ ├── msg_sender.wat │ │ ├── msg_value.wat │ │ ├── null_host.wat │ │ ├── read_args.wat │ │ ├── return_data_size.wat │ │ ├── tx_gas_price.wat │ │ ├── tx_ink_price.wat │ │ ├── tx_origin.wat │ │ └── write_result.wat ├── tools │ └── module_roots │ │ ├── Cargo.lock │ │ ├── Cargo.toml │ │ └── src │ │ └── main.rs ├── wasm-libraries │ ├── Cargo.lock │ ├── Cargo.toml │ ├── arbcompress │ │ ├── Cargo.toml │ │ ├── build.rs │ │ └── src │ │ │ └── lib.rs │ ├── forward │ │ ├── .gitignore │ │ ├── Cargo.toml │ │ └── src │ │ │ └── main.rs │ ├── host-io │ │ ├── Cargo.toml │ │ └── src │ │ │ └── lib.rs │ ├── program-exec │ │ ├── Cargo.toml │ │ └── src │ │ │ └── lib.rs │ ├── soft-float │ │ ├── bindings32.c │ │ └── bindings64.c │ ├── user-host-trait │ │ ├── Cargo.toml │ │ └── src │ │ │ └── lib.rs │ ├── user-host │ │ ├── Cargo.toml │ │ └── src │ │ │ ├── host.rs │ │ │ ├── ink.rs │ │ │ ├── lib.rs │ │ │ ├── link.rs │ │ │ └── program.rs │ ├── user-test │ │ ├── Cargo.toml │ │ └── src │ │ │ ├── host.rs │ │ │ ├── ink.rs │ │ │ ├── lib.rs │ │ │ └── program.rs │ └── wasi-stub │ │ ├── Cargo.toml │ │ └── src │ │ └── lib.rs └── wasm-testsuite │ ├── .gitignore │ ├── Cargo.lock │ ├── Cargo.toml │ ├── check.sh │ └── src │ └── main.rs ├── arbnode ├── api.go ├── batch_poster.go ├── dataposter │ ├── data_poster.go │ ├── dataposter_test.go │ ├── dbstorage │ │ └── storage.go │ ├── externalsigner │ │ ├── externalsigner.go │ │ └── externalsigner_test.go │ ├── externalsignertest │ │ └── externalsignertest.go │ ├── noop │ │ └── storage.go │ ├── redis │ │ └── redisstorage.go │ ├── slice │ │ └── slicestorage.go │ ├── storage │ │ ├── rlp_test.go │ │ ├── storage.go │ │ └── time.go │ ├── storage_test.go │ └── testdata │ │ ├── client.cnf │ │ ├── client.crt │ │ ├── client.key │ │ ├── localhost.cnf │ │ ├── localhost.crt │ │ └── localhost.key ├── delayed.go ├── delayed_seq_reorg_test.go ├── delayed_sequencer.go ├── inbox_reader.go ├── inbox_test.go ├── inbox_tracker.go ├── inbox_tracker_test.go ├── maintenance.go ├── maintenance_test.go ├── message_pruner.go ├── message_pruner_test.go ├── node.go ├── redislock │ └── redis.go ├── resourcemanager │ ├── resource_management.go │ └── resource_management_test.go ├── schema.go ├── seq_coordinator.go ├── seq_coordinator_atomic_test.go ├── sequencer_inbox.go ├── simple_redis_lock_test.go ├── sync_monitor.go └── transaction_streamer.go ├── arbos ├── activate_test.go ├── addressSet │ ├── addressSet.go │ └── addressSet_test.go ├── addressTable │ ├── addressTable.go │ └── addressTable_test.go ├── arbosState │ ├── arbosstate.go │ ├── arbosstate_test.go │ ├── common_test.go │ ├── initialization_test.go │ └── initialize.go ├── arbostypes │ ├── incomingmessage.go │ └── messagewithmeta.go ├── block_processor.go ├── blockhash │ ├── blockhash.go │ └── blockhash_test.go ├── burn │ └── burn.go ├── common_test.go ├── engine.go ├── extra_transaction_checks.go ├── incomingmessage_test.go ├── internal_tx.go ├── l1pricing │ ├── batchPoster.go │ ├── batchPoster_test.go │ ├── common_test.go │ ├── l1PricingOldVersions.go │ ├── l1pricing.go │ └── l1pricing_test.go ├── l1pricing_test.go ├── l2pricing │ ├── l2pricing.go │ ├── l2pricing_test.go │ └── model.go ├── merkleAccumulator │ └── merkleAccumulator.go ├── parse_l2.go ├── programs │ ├── api.go │ ├── constant_test.go │ ├── data_pricer.go │ ├── memory.go │ ├── memory_test.go │ ├── native.go │ ├── native_api.go │ ├── params.go │ ├── programs.go │ ├── testconstants.go │ ├── wasm.go │ └── wasm_api.go ├── queue_test.go ├── retryable_test.go ├── retryables │ └── retryable.go ├── storage │ ├── queue.go │ ├── storage.go │ └── storage_test.go ├── tx_processor.go └── util │ ├── retryable_encoding_test.go │ ├── tracing.go │ ├── transfer.go │ └── util.go ├── arbstate ├── das_reader.go ├── inbox.go └── inbox_fuzz_test.go ├── arbutil ├── block_message_relation.go ├── correspondingl1blocknumber.go ├── format.go ├── hash.go ├── hash_test.go ├── preimage_type.go ├── transaction_data.go ├── unsafe.go └── wait_for_l1.go ├── audits ├── ConsenSys_Diligence_Arbitrum_Contracts_11_2021.pdf ├── ConsenSys_Diligence_Nitro_Contracts_5_2022.pdf └── Trail_Of_Bits_Nitro_10_2022.pdf ├── blocks_reexecutor └── blocks_reexecutor.go ├── blsSignatures ├── blsSignatures.go └── blsSignatures_test.go ├── broadcastclient ├── broadcastclient.go └── broadcastclient_test.go ├── broadcastclients └── broadcastclients.go ├── broadcaster ├── backlog │ ├── backlog.go │ ├── backlog_test.go │ └── config.go ├── broadcaster.go ├── broadcaster_test.go └── message │ ├── message.go │ ├── message_serialization_test.go │ └── message_test_utils.go ├── cmd ├── chaininfo │ ├── arbitrum_chain_info.json │ └── chain_info.go ├── conf │ ├── chain.go │ ├── database.go │ └── init.go ├── daserver │ └── daserver.go ├── dataavailability │ ├── data_availability_check │ └── data_availability_check.go ├── datool │ └── datool.go ├── deploy │ └── deploy.go ├── genericconf │ ├── config.go │ ├── filehandler_test.go │ ├── getversion17.go │ ├── getversion18.go │ ├── jwt.go │ ├── liveconfig.go │ ├── logging.go │ ├── pprof.go │ ├── server.go │ └── wallet.go ├── ipfshelper │ ├── ipfshelper.bkup_go │ ├── ipfshelper_stub.go │ └── ipfshelper_test.go ├── nitro-val │ ├── config.go │ └── nitro_val.go ├── nitro │ ├── config_test.go │ ├── init.go │ └── nitro.go ├── pruning │ └── pruning.go ├── relay │ ├── config_test.go │ └── relay.go ├── replay │ ├── db.go │ └── main.go ├── seq-coordinator-invalidate │ └── seq-coordinator-invalidate.go ├── seq-coordinator-manager │ ├── rediscoordinator │ │ └── redis_coordinator.go │ └── seq-coordinator-manager.go ├── staterecovery │ └── staterecovery.go └── util │ ├── chaininfoutil.go │ ├── confighelpers │ └── configuration.go │ ├── keystore.go │ └── keystore_test.go ├── codecov.yml ├── das ├── aggregator.go ├── aggregator_test.go ├── cache_storage_service.go ├── cache_storage_service_test.go ├── chain_fetch_das.go ├── das.go ├── dasRpcClient.go ├── dasRpcServer.go ├── das_test.go ├── dastree │ ├── dastree.go │ └── dastree_test.go ├── db_storage_service.go ├── extra_signature_checker_test.go ├── factory.go ├── fallback_storage_service.go ├── fallback_storage_service_test.go ├── ipfs_storage_service.bkup_go ├── ipfs_storage_service_stub.go ├── ipfs_storage_service_test.go ├── iterable_storage_service.go ├── key_utils.go ├── lifecycle.go ├── local_file_storage_service.go ├── memory_backed_storage_service.go ├── panic_wrapper.go ├── read_limited.go ├── reader_aggregator_strategies.go ├── reader_aggregator_strategies_test.go ├── redis_storage_service.go ├── redis_storage_service_test.go ├── redundant_storage_service.go ├── redundant_storage_test.go ├── regular_sync_storage_test.go ├── regularly_sync_storage.go ├── rest_server_list.go ├── restful_client.go ├── restful_server.go ├── restful_server_list_test.go ├── restful_server_test.go ├── rpc_aggregator.go ├── rpc_test.go ├── s3_storage_service.go ├── s3_storage_service_test.go ├── sign_after_store_das_writer.go ├── simple_das_reader_aggregator.go ├── simple_das_reader_aggregator_test.go ├── storage_service.go ├── store_signing.go ├── store_signing_test.go ├── syncing_fallback_storage.go ├── timeout_wrapper.go └── util.go ├── deploy └── deploy.go ├── docs ├── Nitro-whitepaper.pdf └── notice.md ├── execution ├── gethexec │ ├── api.go │ ├── arb_interface.go │ ├── block_recorder.go │ ├── blockchain.go │ ├── classicMessage.go │ ├── executionengine.go │ ├── forwarder.go │ ├── node.go │ ├── sequencer.go │ ├── sync_monitor.go │ └── tx_pre_checker.go ├── interface.go └── nodeInterface │ ├── NodeInterface.go │ ├── NodeInterfaceDebug.go │ └── virtual-contracts.go ├── gethhook ├── geth-hook.go └── geth_test.go ├── go.mod ├── go.sum ├── linters ├── koanf │ ├── handlers.go │ ├── koanf.go │ └── koanf_test.go ├── linters.go ├── pointercheck │ ├── pointercheck.go │ └── pointercheck_test.go ├── rightshift │ ├── rightshift.go │ └── rightshift_test.go ├── structinit │ ├── structinit.go │ └── structinit_test.go └── testdata │ └── src │ ├── koanf │ ├── a │ │ └── a.go │ └── b │ │ └── b.go │ ├── pointercheck │ └── pointercheck.go │ ├── rightshift │ └── rightshift.go │ └── structinit │ └── a │ └── a.go ├── precompiles ├── ArbAddressTable.go ├── ArbAddressTable_test.go ├── ArbAggregator.go ├── ArbAggregator_test.go ├── ArbBLS.go ├── ArbDebug.go ├── ArbFunctionTable.go ├── ArbGasInfo.go ├── ArbInfo.go ├── ArbOwner.go ├── ArbOwnerPublic.go ├── ArbOwner_test.go ├── ArbRetryableTx.go ├── ArbRetryableTx_test.go ├── ArbStatistics.go ├── ArbSys.go ├── ArbWasm.go ├── ArbWasmCache.go ├── ArbosActs.go ├── ArbosTest.go ├── context.go ├── precompile.go ├── precompile_test.go └── wrapper.go ├── pubsub ├── consumer.go ├── producer.go └── pubsub_test.go ├── relay ├── relay.go └── relay_stress_test.go ├── scripts ├── build-brotli.sh ├── create-test-preimages.py ├── download-machine.sh ├── fuzz.bash ├── split-val-entry.sh └── startup-testnode.bash ├── solgen └── gen.go ├── staker ├── assertion.go ├── block_challenge_backend.go ├── block_validator.go ├── block_validator_schema.go ├── challenge_manager.go ├── challenge_test.go ├── common_test.go ├── execution_challenge_bakend.go ├── l1_validator.go ├── rollup_watcher.go ├── staker.go ├── stateless_block_validator.go ├── txbuilder │ └── builder.go └── validatorwallet │ ├── contract.go │ ├── eoa.go │ └── noop.go ├── statetransfer ├── data.go ├── interface.go ├── jsondatareader.go └── memdatareader.go ├── system_tests ├── aliasing_test.go ├── arbtrace_test.go ├── batch_poster_test.go ├── benchmarks_test.go ├── block_hash_test.go ├── block_validator_bench_test.go ├── block_validator_test.go ├── blocks_reexecutor_test.go ├── bloom_test.go ├── common_test.go ├── conditionaltx_test.go ├── contract_tx_test.go ├── das_test.go ├── debug_trace_test.go ├── debugapi_test.go ├── delayedinbox_test.go ├── delayedinboxlong_test.go ├── deployment_test.go ├── estimation_test.go ├── eth_sync_test.go ├── fees_test.go ├── forwarder_test.go ├── full_challenge_impl_test.go ├── full_challenge_mock_test.go ├── full_challenge_test.go ├── infra_fee_test.go ├── initialization_test.go ├── log_subscription_test.go ├── meaningless_reorg_test.go ├── nodeinterface_test.go ├── outbox_test.go ├── pendingblock_test.go ├── precompile_fuzz_test.go ├── precompile_test.go ├── program_norace_test.go ├── program_race_test.go ├── program_test.go ├── pruning_test.go ├── recreatestate_rpc_test.go ├── reorg_resequencing_test.go ├── retryable_test.go ├── rpc_test.go ├── seq_coordinator_test.go ├── seq_nonce_test.go ├── seq_pause_test.go ├── seq_reject_test.go ├── seq_whitelist_test.go ├── seqcompensation_test.go ├── seqfeed_test.go ├── seqinbox_test.go ├── staker_challenge_test.go ├── staker_test.go ├── state_fuzz_test.go ├── staterecovery_test.go ├── stylus_test.go ├── test_info.go ├── transfer_test.go ├── triedb_race_test.go ├── twonodes_test.go ├── twonodeslong_test.go ├── unsupported_txtypes_test.go ├── validation_mock_test.go ├── validator_reorg_test.go └── wrap_transaction_test.go ├── util ├── arbmath │ ├── bips.go │ ├── bits.go │ ├── math.go │ ├── math_test.go │ ├── moving_average.go │ ├── moving_average_test.go │ ├── time.go │ └── uint24.go ├── blobs │ ├── blobs.go │ └── blobs_test.go ├── colors │ └── colors.go ├── containers │ ├── lru.go │ ├── promise.go │ ├── promise_test.go │ ├── queue.go │ ├── queue_test.go │ └── syncmap.go ├── contracts │ └── address_verifier.go ├── headerreader │ ├── blob_client.go │ ├── blob_client_test.go │ ├── execution_reverted_test.go │ └── header_reader.go ├── jsonapi │ ├── preimages.go │ ├── preimages_test.go │ └── uint64_string.go ├── log.go ├── log_test.go ├── merkletree │ ├── common_test.go │ ├── merkleAccumulator_test.go │ ├── merkleEventProof.go │ ├── merkleEventProof_test.go │ └── merkleTree.go ├── metricsutil │ └── metricsutil.go ├── normalizeGas.go ├── pretty │ └── pretty_printing.go ├── redisutil │ ├── redis_coordinator.go │ ├── redisutil.go │ └── test_redis.go ├── rpcclient │ ├── rpcclient.go │ ├── rpcclient_test.go │ └── rpcclient_toxiproxy_test.go ├── sharedmetrics │ └── sharedmetrics.go ├── signature │ ├── datasigner.go │ ├── sign_verify.go │ ├── sign_verify_test.go │ ├── simple_hmac.go │ ├── verifier.go │ └── verifier_test.go ├── stopwaiter │ ├── stopwaiter.go │ ├── stopwaiter_promise_test.go │ └── stopwaiter_test.go └── testhelpers │ ├── pseudorandom.go │ └── testhelpers.go ├── validator ├── client │ ├── redis │ │ └── producer.go │ └── validation_client.go ├── execution_state.go ├── interface.go ├── server_api │ └── json.go ├── server_arb │ ├── execution_run.go │ ├── machine.go │ ├── machine_cache.go │ ├── machine_loader.go │ ├── mock_machine.go │ ├── nitro_machine.go │ ├── preimage_resolver.go │ ├── prover_interface.go │ └── validator_spawner.go ├── server_common │ ├── machine_loader.go │ ├── machine_locator.go │ ├── machine_locator_test.go │ ├── testdata │ │ ├── 0x68e4fe5023f792d4ef584796c84d710303a5e12ea02d6e37e2b5e9c4332507c4 │ │ │ └── module-root.txt │ │ ├── 0x8b104a2e80ac6165dc58b9048de12f301d70b02a0ab51396c22b4b4b802a16a4 │ │ │ └── module-root.txt │ │ ├── 0xf4389b835497a910d7ba3ebfb77aa93da985634f3c052de1290360635be40c4a │ │ │ └── module-root.txt │ │ └── latest │ └── valrun.go ├── server_jit │ ├── jit_machine.go │ ├── machine_loader.go │ └── spawner.go ├── utils.go ├── validation_entry.go └── valnode │ ├── redis │ └── consumer.go │ ├── validation_api.go │ └── valnode.go ├── wavmio ├── higher.go ├── raw.go └── stub.go ├── wsbroadcastserver ├── clientconnection.go ├── clientmanager.go ├── connectionlimiter.go ├── connectionlimiter_test.go ├── dictionary.go ├── utils.go └── wsbroadcastserver.go └── zeroheavy ├── common_test.go ├── zeroheavy.go └── zeroheavy_test.go /.clabot: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.clabot -------------------------------------------------------------------------------- /.dockerignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.dockerignore -------------------------------------------------------------------------------- /.github/ISSUE_TEMPLATE/bug_report.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.github/ISSUE_TEMPLATE/bug_report.md -------------------------------------------------------------------------------- /.github/ISSUE_TEMPLATE/feature_request.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.github/ISSUE_TEMPLATE/feature_request.md -------------------------------------------------------------------------------- /.github/codeql/codeql-config.yml: -------------------------------------------------------------------------------- 1 | name: "Nitro CodeQL config" 2 | 3 | -------------------------------------------------------------------------------- /.github/workflows/arbitrator-ci.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.github/workflows/arbitrator-ci.yml -------------------------------------------------------------------------------- /.github/workflows/arbitrator-skip-ci.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.github/workflows/arbitrator-skip-ci.yml -------------------------------------------------------------------------------- /.github/workflows/ci.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.github/workflows/ci.yml -------------------------------------------------------------------------------- /.github/workflows/codeql-analysis.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.github/workflows/codeql-analysis.yml -------------------------------------------------------------------------------- /.github/workflows/docker.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.github/workflows/docker.yml -------------------------------------------------------------------------------- /.github/workflows/release-ci.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.github/workflows/release-ci.yml -------------------------------------------------------------------------------- /.github/workflows/waitForNitro.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.github/workflows/waitForNitro.sh -------------------------------------------------------------------------------- /.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.gitignore -------------------------------------------------------------------------------- /.gitmodules: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.gitmodules -------------------------------------------------------------------------------- /.golangci.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/.golangci.yml -------------------------------------------------------------------------------- /.nitro-tag.txt: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /Dockerfile: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/Dockerfile -------------------------------------------------------------------------------- /LICENSE.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/LICENSE.md -------------------------------------------------------------------------------- /Makefile: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/Makefile -------------------------------------------------------------------------------- /README.md: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/README.md -------------------------------------------------------------------------------- /arbcompress/compress_common.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbcompress/compress_common.go -------------------------------------------------------------------------------- /arbcompress/compress_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbcompress/compress_test.go -------------------------------------------------------------------------------- /arbcompress/native.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbcompress/native.go -------------------------------------------------------------------------------- /arbcompress/wasm.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbcompress/wasm.go -------------------------------------------------------------------------------- /arbitrator/.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/.gitignore -------------------------------------------------------------------------------- /arbitrator/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/arbutil/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/arbutil/src/color.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/color.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/crypto.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/crypto.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/evm/api.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/evm/api.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/evm/mod.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/evm/mod.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/evm/req.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/evm/req.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/evm/storage.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/evm/storage.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/evm/user.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/evm/user.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/format.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/format.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/math.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/math.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/operator.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/operator.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/pricing.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/pricing.rs -------------------------------------------------------------------------------- /arbitrator/arbutil/src/types.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/arbutil/src/types.rs -------------------------------------------------------------------------------- /arbitrator/brotli/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/brotli/build.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/build.rs -------------------------------------------------------------------------------- /arbitrator/brotli/fuzz/.gitignore: -------------------------------------------------------------------------------- 1 | target 2 | corpus 3 | artifacts 4 | coverage 5 | -------------------------------------------------------------------------------- /arbitrator/brotli/fuzz/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/fuzz/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/brotli/fuzz/README: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/fuzz/README -------------------------------------------------------------------------------- /arbitrator/brotli/fuzz/fuzz_targets/compress.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/fuzz/fuzz_targets/compress.rs -------------------------------------------------------------------------------- /arbitrator/brotli/fuzz/fuzz_targets/decompress.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/fuzz/fuzz_targets/decompress.rs -------------------------------------------------------------------------------- /arbitrator/brotli/fuzz/fuzz_targets/round_trip.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/fuzz/fuzz_targets/round_trip.rs -------------------------------------------------------------------------------- /arbitrator/brotli/src/cgo.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/src/cgo.rs -------------------------------------------------------------------------------- /arbitrator/brotli/src/dicts/mod.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/src/dicts/mod.rs -------------------------------------------------------------------------------- /arbitrator/brotli/src/dicts/stylus-program-11.lz: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/src/dicts/stylus-program-11.lz -------------------------------------------------------------------------------- /arbitrator/brotli/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/brotli/src/types.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/src/types.rs -------------------------------------------------------------------------------- /arbitrator/brotli/src/wasmer_traits.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/brotli/src/wasmer_traits.rs -------------------------------------------------------------------------------- /arbitrator/caller-env/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/caller-env/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/caller-env/src/brotli/mod.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/caller-env/src/brotli/mod.rs -------------------------------------------------------------------------------- /arbitrator/caller-env/src/guest_ptr.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/caller-env/src/guest_ptr.rs -------------------------------------------------------------------------------- /arbitrator/caller-env/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/caller-env/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/caller-env/src/static_caller.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/caller-env/src/static_caller.rs -------------------------------------------------------------------------------- /arbitrator/caller-env/src/wasip1_stub.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/caller-env/src/wasip1_stub.rs -------------------------------------------------------------------------------- /arbitrator/caller-env/src/wasmer_traits.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/caller-env/src/wasmer_traits.rs -------------------------------------------------------------------------------- /arbitrator/jit/.gitignore: -------------------------------------------------------------------------------- 1 | **.wasm 2 | -------------------------------------------------------------------------------- /arbitrator/jit/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/jit/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/jit/programs/print/main.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/programs/print/main.go -------------------------------------------------------------------------------- /arbitrator/jit/programs/pure/main.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/programs/pure/main.wat -------------------------------------------------------------------------------- /arbitrator/jit/programs/time/main.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/programs/time/main.go -------------------------------------------------------------------------------- /arbitrator/jit/src/arbcompress.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/src/arbcompress.rs -------------------------------------------------------------------------------- /arbitrator/jit/src/caller_env.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/src/caller_env.rs -------------------------------------------------------------------------------- /arbitrator/jit/src/machine.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/src/machine.rs -------------------------------------------------------------------------------- /arbitrator/jit/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/src/main.rs -------------------------------------------------------------------------------- /arbitrator/jit/src/program.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/src/program.rs -------------------------------------------------------------------------------- /arbitrator/jit/src/socket.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/src/socket.rs -------------------------------------------------------------------------------- /arbitrator/jit/src/stylus_backend.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/src/stylus_backend.rs -------------------------------------------------------------------------------- /arbitrator/jit/src/test.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/src/test.rs -------------------------------------------------------------------------------- /arbitrator/jit/src/wasip1_stub.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/src/wasip1_stub.rs -------------------------------------------------------------------------------- /arbitrator/jit/src/wavmio.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/jit/src/wavmio.rs -------------------------------------------------------------------------------- /arbitrator/prover/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/prover/fuzz/.gitignore: -------------------------------------------------------------------------------- 1 | target 2 | corpus 3 | artifacts 4 | fuzz*.log 5 | -------------------------------------------------------------------------------- /arbitrator/prover/fuzz/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/fuzz/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/prover/fuzz/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/fuzz/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/prover/fuzz/fuzz_targets/osp.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/fuzz/fuzz_targets/osp.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/binary.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/binary.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/bulk_memory.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/bulk_memory.wat -------------------------------------------------------------------------------- /arbitrator/prover/src/host.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/host.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/kzg-trusted-setup.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/kzg-trusted-setup.json -------------------------------------------------------------------------------- /arbitrator/prover/src/kzg.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/kzg.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/machine.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/machine.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/main.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/memory.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/memory.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/merkle.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/merkle.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/print.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/print.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/programs/config.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/programs/config.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/programs/counter.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/programs/counter.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/programs/depth.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/programs/depth.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/programs/dynamic.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/programs/dynamic.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/programs/heap.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/programs/heap.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/programs/memory.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/programs/memory.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/programs/meter.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/programs/meter.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/programs/mod.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/programs/mod.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/programs/prelude.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/programs/prelude.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/programs/start.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/programs/start.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/reinterpret.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/reinterpret.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/test.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/test.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/utils.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/utils.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/value.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/value.rs -------------------------------------------------------------------------------- /arbitrator/prover/src/wavm.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/src/wavm.rs -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/block.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/block.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/bulk-memory.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/bulk-memory.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/call-indirect.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/call-indirect.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/call.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/call.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/const.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/const.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/div-overflow.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/div-overflow.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/dynamic.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/dynamic.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/float32.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/float32.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/float64.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/float64.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/forward-test.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/forward-test.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/forward/forward.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/forward/forward.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/forward/target.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/forward/target.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/global-state-wavm.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/global-state-wavm.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/global-state-wrapper.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/global-state-wrapper.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/global-state.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/global-state.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/globals.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/globals.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/go/main.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/go/main.go -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/if-else.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/if-else.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/iops.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/iops.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/link.txt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/link.txt -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/link.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/link.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/locals.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/locals.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/loop.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/loop.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/math.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/math.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/memory-grow.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/memory-grow.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/memory.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/memory.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/no-stack-pollution.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/no-stack-pollution.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/read-inboxmsg-10.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/read-inboxmsg-10.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/return.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/return.wat -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/rust/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/rust/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/data/msg0.bin: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/rust/data/msg0.bin -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/data/msg1.bin: -------------------------------------------------------------------------------- 1 |  2 |  -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/src/bin/basics.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/rust/src/bin/basics.rs -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/src/bin/globalstate.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/rust/src/bin/globalstate.rs -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/src/bin/host-io.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/rust/src/bin/host-io.rs -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/src/bin/keccak256.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/rust/src/bin/keccak256.rs -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/src/bin/pi.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/rust/src/bin/pi.rs -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/src/bin/stdlib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/rust/src/bin/stdlib.rs -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/rust/src/lib.rs: -------------------------------------------------------------------------------- 1 | -------------------------------------------------------------------------------- /arbitrator/prover/test-cases/user.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/prover/test-cases/user.wat -------------------------------------------------------------------------------- /arbitrator/stylus/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/cbindgen.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/cbindgen.toml -------------------------------------------------------------------------------- /arbitrator/stylus/src/benchmarks.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/benchmarks.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/cache.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/cache.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/env.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/env.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/evm_api.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/evm_api.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/host.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/host.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/native.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/native.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/run.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/run.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/test/api.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/test/api.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/test/misc.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/test/misc.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/test/mod.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/test/mod.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/test/native.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/test/native.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/test/sdk.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/test/sdk.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/test/timings.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/test/timings.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/test/wavm.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/test/wavm.rs -------------------------------------------------------------------------------- /arbitrator/stylus/src/util.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/src/util.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/.cargo/config.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/.cargo/config.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/add.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/add.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/bad-mods/bad-export.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/bad-mods/bad-export.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/bad-mods/bad-export2.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/bad-mods/bad-export2.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/bad-mods/bad-export3.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/bad-mods/bad-export3.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/bad-mods/bad-export4.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/bad-mods/bad-export4.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/bad-mods/bad-import.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/bad-mods/bad-import.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/bf/.gitignore: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/bf/.gitignore -------------------------------------------------------------------------------- /arbitrator/stylus/tests/bf/cat.b: -------------------------------------------------------------------------------- 1 | ,[.,] 2 | -------------------------------------------------------------------------------- /arbitrator/stylus/tests/bulk-memory-oob.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/bulk-memory-oob.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/clz.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/clz.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/console.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/console.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/create/.cargo/config: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/create/.cargo/config -------------------------------------------------------------------------------- /arbitrator/stylus/tests/create/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/create/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/create/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/create/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/create/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/create/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/depth.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/depth.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/erc20/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/erc20/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/erc20/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/erc20/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/erc20/src/erc20.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/erc20/src/erc20.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/erc20/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/erc20/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/evm-data/.cargo/config: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/evm-data/.cargo/config -------------------------------------------------------------------------------- /arbitrator/stylus/tests/evm-data/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/evm-data/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/evm-data/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/evm-data/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/evm-data/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/evm-data/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/exit-early/exit-early.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/exit-early/exit-early.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/exit-early/panic-after-write.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/exit-early/panic-after-write.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/fallible/.cargo/config: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/fallible/.cargo/config -------------------------------------------------------------------------------- /arbitrator/stylus/tests/fallible/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/fallible/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/fallible/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/fallible/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/fallible/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/fallible/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/grow/fixed.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/grow/fixed.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/grow/grow-120.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/grow/grow-120.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/grow/grow-and-call.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/grow/grow-and-call.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/grow/mem-write.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/grow/mem-write.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/keccak-100/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/keccak-100/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/keccak-100/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/keccak-100/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/keccak-100/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/keccak-100/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/keccak/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/keccak/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/keccak/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/keccak/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/keccak/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/keccak/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/log/.cargo/config: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/log/.cargo/config -------------------------------------------------------------------------------- /arbitrator/stylus/tests/log/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/log/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/log/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/log/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/log/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/log/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/math/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/math/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/math/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/math/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/math/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/math/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/memory.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/memory.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/memory2.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/memory2.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/module-mod.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/module-mod.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/multicall/.cargo/config: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/multicall/.cargo/config -------------------------------------------------------------------------------- /arbitrator/stylus/tests/multicall/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/multicall/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/multicall/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/multicall/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/multicall/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/multicall/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/read-return-data/.cargo/config: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/read-return-data/.cargo/config -------------------------------------------------------------------------------- /arbitrator/stylus/tests/read-return-data/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/read-return-data/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/read-return-data/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/read-return-data/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/read-return-data/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/read-return-data/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/sdk-storage/.cargo/config: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/sdk-storage/.cargo/config -------------------------------------------------------------------------------- /arbitrator/stylus/tests/sdk-storage/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/sdk-storage/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/sdk-storage/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/sdk-storage/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/sdk-storage/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/sdk-storage/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/start.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/start.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/storage/.cargo/config: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/storage/.cargo/config -------------------------------------------------------------------------------- /arbitrator/stylus/tests/storage/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/storage/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/storage/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/storage/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/stylus/tests/storage/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/storage/src/main.rs -------------------------------------------------------------------------------- /arbitrator/stylus/tests/test.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/test.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/block_basefee.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/block_basefee.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/block_coinbase.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/block_coinbase.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/block_gas_limit.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/block_gas_limit.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/block_number.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/block_number.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/block_timestamp.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/block_timestamp.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/chainid.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/chainid.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/contract_address.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/contract_address.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/evm_gas_left.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/evm_gas_left.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/evm_ink_left.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/evm_ink_left.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/keccak.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/keccak.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/msg_sender.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/msg_sender.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/msg_value.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/msg_value.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/null_host.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/null_host.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/read_args.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/read_args.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/return_data_size.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/return_data_size.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/tx_gas_price.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/tx_gas_price.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/tx_ink_price.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/tx_ink_price.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/tx_origin.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/tx_origin.wat -------------------------------------------------------------------------------- /arbitrator/stylus/tests/timings/write_result.wat: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/stylus/tests/timings/write_result.wat -------------------------------------------------------------------------------- /arbitrator/tools/module_roots/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/tools/module_roots/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/tools/module_roots/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/tools/module_roots/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/tools/module_roots/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/tools/module_roots/src/main.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/arbcompress/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/arbcompress/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/arbcompress/build.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/arbcompress/build.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/arbcompress/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/arbcompress/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/forward/.gitignore: -------------------------------------------------------------------------------- 1 | **.wat 2 | -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/forward/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/forward/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/forward/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/forward/src/main.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/host-io/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/host-io/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/host-io/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/host-io/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/program-exec/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/program-exec/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/program-exec/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/program-exec/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/soft-float/bindings32.c: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/soft-float/bindings32.c -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/soft-float/bindings64.c: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/soft-float/bindings64.c -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-host-trait/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-host-trait/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-host-trait/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-host-trait/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-host/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-host/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-host/src/host.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-host/src/host.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-host/src/ink.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-host/src/ink.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-host/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-host/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-host/src/link.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-host/src/link.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-host/src/program.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-host/src/program.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-test/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-test/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-test/src/host.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-test/src/host.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-test/src/ink.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-test/src/ink.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-test/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-test/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/user-test/src/program.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/user-test/src/program.rs -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/wasi-stub/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/wasi-stub/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/wasm-libraries/wasi-stub/src/lib.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-libraries/wasi-stub/src/lib.rs -------------------------------------------------------------------------------- /arbitrator/wasm-testsuite/.gitignore: -------------------------------------------------------------------------------- 1 | tests/* 2 | -------------------------------------------------------------------------------- /arbitrator/wasm-testsuite/Cargo.lock: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-testsuite/Cargo.lock -------------------------------------------------------------------------------- /arbitrator/wasm-testsuite/Cargo.toml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-testsuite/Cargo.toml -------------------------------------------------------------------------------- /arbitrator/wasm-testsuite/check.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-testsuite/check.sh -------------------------------------------------------------------------------- /arbitrator/wasm-testsuite/src/main.rs: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbitrator/wasm-testsuite/src/main.rs -------------------------------------------------------------------------------- /arbnode/api.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/api.go -------------------------------------------------------------------------------- /arbnode/batch_poster.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/batch_poster.go -------------------------------------------------------------------------------- /arbnode/dataposter/data_poster.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/data_poster.go -------------------------------------------------------------------------------- /arbnode/dataposter/dataposter_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/dataposter_test.go -------------------------------------------------------------------------------- /arbnode/dataposter/dbstorage/storage.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/dbstorage/storage.go -------------------------------------------------------------------------------- /arbnode/dataposter/externalsigner/externalsigner.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/externalsigner/externalsigner.go -------------------------------------------------------------------------------- /arbnode/dataposter/externalsigner/externalsigner_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/externalsigner/externalsigner_test.go -------------------------------------------------------------------------------- /arbnode/dataposter/externalsignertest/externalsignertest.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/externalsignertest/externalsignertest.go -------------------------------------------------------------------------------- /arbnode/dataposter/noop/storage.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/noop/storage.go -------------------------------------------------------------------------------- /arbnode/dataposter/redis/redisstorage.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/redis/redisstorage.go -------------------------------------------------------------------------------- /arbnode/dataposter/slice/slicestorage.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/slice/slicestorage.go -------------------------------------------------------------------------------- /arbnode/dataposter/storage/rlp_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/storage/rlp_test.go -------------------------------------------------------------------------------- /arbnode/dataposter/storage/storage.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/storage/storage.go -------------------------------------------------------------------------------- /arbnode/dataposter/storage/time.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/storage/time.go -------------------------------------------------------------------------------- /arbnode/dataposter/storage_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/storage_test.go -------------------------------------------------------------------------------- /arbnode/dataposter/testdata/client.cnf: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/testdata/client.cnf -------------------------------------------------------------------------------- /arbnode/dataposter/testdata/client.crt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/testdata/client.crt -------------------------------------------------------------------------------- /arbnode/dataposter/testdata/client.key: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/testdata/client.key -------------------------------------------------------------------------------- /arbnode/dataposter/testdata/localhost.cnf: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/testdata/localhost.cnf -------------------------------------------------------------------------------- /arbnode/dataposter/testdata/localhost.crt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/testdata/localhost.crt -------------------------------------------------------------------------------- /arbnode/dataposter/testdata/localhost.key: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/dataposter/testdata/localhost.key -------------------------------------------------------------------------------- /arbnode/delayed.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/delayed.go -------------------------------------------------------------------------------- /arbnode/delayed_seq_reorg_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/delayed_seq_reorg_test.go -------------------------------------------------------------------------------- /arbnode/delayed_sequencer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/delayed_sequencer.go -------------------------------------------------------------------------------- /arbnode/inbox_reader.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/inbox_reader.go -------------------------------------------------------------------------------- /arbnode/inbox_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/inbox_test.go -------------------------------------------------------------------------------- /arbnode/inbox_tracker.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/inbox_tracker.go -------------------------------------------------------------------------------- /arbnode/inbox_tracker_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/inbox_tracker_test.go -------------------------------------------------------------------------------- /arbnode/maintenance.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/maintenance.go -------------------------------------------------------------------------------- /arbnode/maintenance_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/maintenance_test.go -------------------------------------------------------------------------------- /arbnode/message_pruner.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/message_pruner.go -------------------------------------------------------------------------------- /arbnode/message_pruner_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/message_pruner_test.go -------------------------------------------------------------------------------- /arbnode/node.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/node.go -------------------------------------------------------------------------------- /arbnode/redislock/redis.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/redislock/redis.go -------------------------------------------------------------------------------- /arbnode/resourcemanager/resource_management.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/resourcemanager/resource_management.go -------------------------------------------------------------------------------- /arbnode/resourcemanager/resource_management_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/resourcemanager/resource_management_test.go -------------------------------------------------------------------------------- /arbnode/schema.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/schema.go -------------------------------------------------------------------------------- /arbnode/seq_coordinator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/seq_coordinator.go -------------------------------------------------------------------------------- /arbnode/seq_coordinator_atomic_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/seq_coordinator_atomic_test.go -------------------------------------------------------------------------------- /arbnode/sequencer_inbox.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/sequencer_inbox.go -------------------------------------------------------------------------------- /arbnode/simple_redis_lock_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/simple_redis_lock_test.go -------------------------------------------------------------------------------- /arbnode/sync_monitor.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/sync_monitor.go -------------------------------------------------------------------------------- /arbnode/transaction_streamer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbnode/transaction_streamer.go -------------------------------------------------------------------------------- /arbos/activate_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/activate_test.go -------------------------------------------------------------------------------- /arbos/addressSet/addressSet.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/addressSet/addressSet.go -------------------------------------------------------------------------------- /arbos/addressSet/addressSet_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/addressSet/addressSet_test.go -------------------------------------------------------------------------------- /arbos/addressTable/addressTable.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/addressTable/addressTable.go -------------------------------------------------------------------------------- /arbos/addressTable/addressTable_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/addressTable/addressTable_test.go -------------------------------------------------------------------------------- /arbos/arbosState/arbosstate.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/arbosState/arbosstate.go -------------------------------------------------------------------------------- /arbos/arbosState/arbosstate_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/arbosState/arbosstate_test.go -------------------------------------------------------------------------------- /arbos/arbosState/common_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/arbosState/common_test.go -------------------------------------------------------------------------------- /arbos/arbosState/initialization_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/arbosState/initialization_test.go -------------------------------------------------------------------------------- /arbos/arbosState/initialize.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/arbosState/initialize.go -------------------------------------------------------------------------------- /arbos/arbostypes/incomingmessage.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/arbostypes/incomingmessage.go -------------------------------------------------------------------------------- /arbos/arbostypes/messagewithmeta.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/arbostypes/messagewithmeta.go -------------------------------------------------------------------------------- /arbos/block_processor.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/block_processor.go -------------------------------------------------------------------------------- /arbos/blockhash/blockhash.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/blockhash/blockhash.go -------------------------------------------------------------------------------- /arbos/blockhash/blockhash_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/blockhash/blockhash_test.go -------------------------------------------------------------------------------- /arbos/burn/burn.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/burn/burn.go -------------------------------------------------------------------------------- /arbos/common_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/common_test.go -------------------------------------------------------------------------------- /arbos/engine.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/engine.go -------------------------------------------------------------------------------- /arbos/extra_transaction_checks.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/extra_transaction_checks.go -------------------------------------------------------------------------------- /arbos/incomingmessage_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/incomingmessage_test.go -------------------------------------------------------------------------------- /arbos/internal_tx.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/internal_tx.go -------------------------------------------------------------------------------- /arbos/l1pricing/batchPoster.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/l1pricing/batchPoster.go -------------------------------------------------------------------------------- /arbos/l1pricing/batchPoster_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/l1pricing/batchPoster_test.go -------------------------------------------------------------------------------- /arbos/l1pricing/common_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/l1pricing/common_test.go -------------------------------------------------------------------------------- /arbos/l1pricing/l1PricingOldVersions.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/l1pricing/l1PricingOldVersions.go -------------------------------------------------------------------------------- /arbos/l1pricing/l1pricing.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/l1pricing/l1pricing.go -------------------------------------------------------------------------------- /arbos/l1pricing/l1pricing_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/l1pricing/l1pricing_test.go -------------------------------------------------------------------------------- /arbos/l1pricing_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/l1pricing_test.go -------------------------------------------------------------------------------- /arbos/l2pricing/l2pricing.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/l2pricing/l2pricing.go -------------------------------------------------------------------------------- /arbos/l2pricing/l2pricing_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/l2pricing/l2pricing_test.go -------------------------------------------------------------------------------- /arbos/l2pricing/model.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/l2pricing/model.go -------------------------------------------------------------------------------- /arbos/merkleAccumulator/merkleAccumulator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/merkleAccumulator/merkleAccumulator.go -------------------------------------------------------------------------------- /arbos/parse_l2.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/parse_l2.go -------------------------------------------------------------------------------- /arbos/programs/api.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/api.go -------------------------------------------------------------------------------- /arbos/programs/constant_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/constant_test.go -------------------------------------------------------------------------------- /arbos/programs/data_pricer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/data_pricer.go -------------------------------------------------------------------------------- /arbos/programs/memory.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/memory.go -------------------------------------------------------------------------------- /arbos/programs/memory_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/memory_test.go -------------------------------------------------------------------------------- /arbos/programs/native.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/native.go -------------------------------------------------------------------------------- /arbos/programs/native_api.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/native_api.go -------------------------------------------------------------------------------- /arbos/programs/params.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/params.go -------------------------------------------------------------------------------- /arbos/programs/programs.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/programs.go -------------------------------------------------------------------------------- /arbos/programs/testconstants.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/testconstants.go -------------------------------------------------------------------------------- /arbos/programs/wasm.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/wasm.go -------------------------------------------------------------------------------- /arbos/programs/wasm_api.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/programs/wasm_api.go -------------------------------------------------------------------------------- /arbos/queue_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/queue_test.go -------------------------------------------------------------------------------- /arbos/retryable_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/retryable_test.go -------------------------------------------------------------------------------- /arbos/retryables/retryable.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/retryables/retryable.go -------------------------------------------------------------------------------- /arbos/storage/queue.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/storage/queue.go -------------------------------------------------------------------------------- /arbos/storage/storage.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/storage/storage.go -------------------------------------------------------------------------------- /arbos/storage/storage_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/storage/storage_test.go -------------------------------------------------------------------------------- /arbos/tx_processor.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/tx_processor.go -------------------------------------------------------------------------------- /arbos/util/retryable_encoding_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/util/retryable_encoding_test.go -------------------------------------------------------------------------------- /arbos/util/tracing.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/util/tracing.go -------------------------------------------------------------------------------- /arbos/util/transfer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/util/transfer.go -------------------------------------------------------------------------------- /arbos/util/util.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbos/util/util.go -------------------------------------------------------------------------------- /arbstate/das_reader.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbstate/das_reader.go -------------------------------------------------------------------------------- /arbstate/inbox.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbstate/inbox.go -------------------------------------------------------------------------------- /arbstate/inbox_fuzz_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbstate/inbox_fuzz_test.go -------------------------------------------------------------------------------- /arbutil/block_message_relation.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbutil/block_message_relation.go -------------------------------------------------------------------------------- /arbutil/correspondingl1blocknumber.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbutil/correspondingl1blocknumber.go -------------------------------------------------------------------------------- /arbutil/format.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbutil/format.go -------------------------------------------------------------------------------- /arbutil/hash.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbutil/hash.go -------------------------------------------------------------------------------- /arbutil/hash_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbutil/hash_test.go -------------------------------------------------------------------------------- /arbutil/preimage_type.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbutil/preimage_type.go -------------------------------------------------------------------------------- /arbutil/transaction_data.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbutil/transaction_data.go -------------------------------------------------------------------------------- /arbutil/unsafe.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbutil/unsafe.go -------------------------------------------------------------------------------- /arbutil/wait_for_l1.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/arbutil/wait_for_l1.go -------------------------------------------------------------------------------- /audits/ConsenSys_Diligence_Arbitrum_Contracts_11_2021.pdf: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/audits/ConsenSys_Diligence_Arbitrum_Contracts_11_2021.pdf -------------------------------------------------------------------------------- /audits/ConsenSys_Diligence_Nitro_Contracts_5_2022.pdf: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/audits/ConsenSys_Diligence_Nitro_Contracts_5_2022.pdf -------------------------------------------------------------------------------- /audits/Trail_Of_Bits_Nitro_10_2022.pdf: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/audits/Trail_Of_Bits_Nitro_10_2022.pdf -------------------------------------------------------------------------------- /blocks_reexecutor/blocks_reexecutor.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/blocks_reexecutor/blocks_reexecutor.go -------------------------------------------------------------------------------- /blsSignatures/blsSignatures.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/blsSignatures/blsSignatures.go -------------------------------------------------------------------------------- /blsSignatures/blsSignatures_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/blsSignatures/blsSignatures_test.go -------------------------------------------------------------------------------- /broadcastclient/broadcastclient.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcastclient/broadcastclient.go -------------------------------------------------------------------------------- /broadcastclient/broadcastclient_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcastclient/broadcastclient_test.go -------------------------------------------------------------------------------- /broadcastclients/broadcastclients.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcastclients/broadcastclients.go -------------------------------------------------------------------------------- /broadcaster/backlog/backlog.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcaster/backlog/backlog.go -------------------------------------------------------------------------------- /broadcaster/backlog/backlog_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcaster/backlog/backlog_test.go -------------------------------------------------------------------------------- /broadcaster/backlog/config.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcaster/backlog/config.go -------------------------------------------------------------------------------- /broadcaster/broadcaster.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcaster/broadcaster.go -------------------------------------------------------------------------------- /broadcaster/broadcaster_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcaster/broadcaster_test.go -------------------------------------------------------------------------------- /broadcaster/message/message.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcaster/message/message.go -------------------------------------------------------------------------------- /broadcaster/message/message_serialization_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcaster/message/message_serialization_test.go -------------------------------------------------------------------------------- /broadcaster/message/message_test_utils.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/broadcaster/message/message_test_utils.go -------------------------------------------------------------------------------- /cmd/chaininfo/arbitrum_chain_info.json: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/chaininfo/arbitrum_chain_info.json -------------------------------------------------------------------------------- /cmd/chaininfo/chain_info.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/chaininfo/chain_info.go -------------------------------------------------------------------------------- /cmd/conf/chain.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/conf/chain.go -------------------------------------------------------------------------------- /cmd/conf/database.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/conf/database.go -------------------------------------------------------------------------------- /cmd/conf/init.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/conf/init.go -------------------------------------------------------------------------------- /cmd/daserver/daserver.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/daserver/daserver.go -------------------------------------------------------------------------------- /cmd/dataavailability/data_availability_check: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/dataavailability/data_availability_check -------------------------------------------------------------------------------- /cmd/dataavailability/data_availability_check.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/dataavailability/data_availability_check.go -------------------------------------------------------------------------------- /cmd/datool/datool.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/datool/datool.go -------------------------------------------------------------------------------- /cmd/deploy/deploy.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/deploy/deploy.go -------------------------------------------------------------------------------- /cmd/genericconf/config.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/genericconf/config.go -------------------------------------------------------------------------------- /cmd/genericconf/filehandler_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/genericconf/filehandler_test.go -------------------------------------------------------------------------------- /cmd/genericconf/getversion17.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/genericconf/getversion17.go -------------------------------------------------------------------------------- /cmd/genericconf/getversion18.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/genericconf/getversion18.go -------------------------------------------------------------------------------- /cmd/genericconf/jwt.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/genericconf/jwt.go -------------------------------------------------------------------------------- /cmd/genericconf/liveconfig.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/genericconf/liveconfig.go -------------------------------------------------------------------------------- /cmd/genericconf/logging.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/genericconf/logging.go -------------------------------------------------------------------------------- /cmd/genericconf/pprof.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/genericconf/pprof.go -------------------------------------------------------------------------------- /cmd/genericconf/server.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/genericconf/server.go -------------------------------------------------------------------------------- /cmd/genericconf/wallet.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/genericconf/wallet.go -------------------------------------------------------------------------------- /cmd/ipfshelper/ipfshelper.bkup_go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/ipfshelper/ipfshelper.bkup_go -------------------------------------------------------------------------------- /cmd/ipfshelper/ipfshelper_stub.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/ipfshelper/ipfshelper_stub.go -------------------------------------------------------------------------------- /cmd/ipfshelper/ipfshelper_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/ipfshelper/ipfshelper_test.go -------------------------------------------------------------------------------- /cmd/nitro-val/config.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/nitro-val/config.go -------------------------------------------------------------------------------- /cmd/nitro-val/nitro_val.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/nitro-val/nitro_val.go -------------------------------------------------------------------------------- /cmd/nitro/config_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/nitro/config_test.go -------------------------------------------------------------------------------- /cmd/nitro/init.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/nitro/init.go -------------------------------------------------------------------------------- /cmd/nitro/nitro.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/nitro/nitro.go -------------------------------------------------------------------------------- /cmd/pruning/pruning.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/pruning/pruning.go -------------------------------------------------------------------------------- /cmd/relay/config_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/relay/config_test.go -------------------------------------------------------------------------------- /cmd/relay/relay.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/relay/relay.go -------------------------------------------------------------------------------- /cmd/replay/db.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/replay/db.go -------------------------------------------------------------------------------- /cmd/replay/main.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/replay/main.go -------------------------------------------------------------------------------- /cmd/seq-coordinator-invalidate/seq-coordinator-invalidate.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/seq-coordinator-invalidate/seq-coordinator-invalidate.go -------------------------------------------------------------------------------- /cmd/seq-coordinator-manager/rediscoordinator/redis_coordinator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/seq-coordinator-manager/rediscoordinator/redis_coordinator.go -------------------------------------------------------------------------------- /cmd/seq-coordinator-manager/seq-coordinator-manager.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/seq-coordinator-manager/seq-coordinator-manager.go -------------------------------------------------------------------------------- /cmd/staterecovery/staterecovery.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/staterecovery/staterecovery.go -------------------------------------------------------------------------------- /cmd/util/chaininfoutil.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/util/chaininfoutil.go -------------------------------------------------------------------------------- /cmd/util/confighelpers/configuration.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/util/confighelpers/configuration.go -------------------------------------------------------------------------------- /cmd/util/keystore.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/util/keystore.go -------------------------------------------------------------------------------- /cmd/util/keystore_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/cmd/util/keystore_test.go -------------------------------------------------------------------------------- /codecov.yml: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/codecov.yml -------------------------------------------------------------------------------- /das/aggregator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/aggregator.go -------------------------------------------------------------------------------- /das/aggregator_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/aggregator_test.go -------------------------------------------------------------------------------- /das/cache_storage_service.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/cache_storage_service.go -------------------------------------------------------------------------------- /das/cache_storage_service_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/cache_storage_service_test.go -------------------------------------------------------------------------------- /das/chain_fetch_das.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/chain_fetch_das.go -------------------------------------------------------------------------------- /das/das.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/das.go -------------------------------------------------------------------------------- /das/dasRpcClient.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/dasRpcClient.go -------------------------------------------------------------------------------- /das/dasRpcServer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/dasRpcServer.go -------------------------------------------------------------------------------- /das/das_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/das_test.go -------------------------------------------------------------------------------- /das/dastree/dastree.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/dastree/dastree.go -------------------------------------------------------------------------------- /das/dastree/dastree_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/dastree/dastree_test.go -------------------------------------------------------------------------------- /das/db_storage_service.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/db_storage_service.go -------------------------------------------------------------------------------- /das/extra_signature_checker_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/extra_signature_checker_test.go -------------------------------------------------------------------------------- /das/factory.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/factory.go -------------------------------------------------------------------------------- /das/fallback_storage_service.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/fallback_storage_service.go -------------------------------------------------------------------------------- /das/fallback_storage_service_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/fallback_storage_service_test.go -------------------------------------------------------------------------------- /das/ipfs_storage_service.bkup_go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/ipfs_storage_service.bkup_go -------------------------------------------------------------------------------- /das/ipfs_storage_service_stub.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/ipfs_storage_service_stub.go -------------------------------------------------------------------------------- /das/ipfs_storage_service_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/ipfs_storage_service_test.go -------------------------------------------------------------------------------- /das/iterable_storage_service.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/iterable_storage_service.go -------------------------------------------------------------------------------- /das/key_utils.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/key_utils.go -------------------------------------------------------------------------------- /das/lifecycle.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/lifecycle.go -------------------------------------------------------------------------------- /das/local_file_storage_service.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/local_file_storage_service.go -------------------------------------------------------------------------------- /das/memory_backed_storage_service.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/memory_backed_storage_service.go -------------------------------------------------------------------------------- /das/panic_wrapper.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/panic_wrapper.go -------------------------------------------------------------------------------- /das/read_limited.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/read_limited.go -------------------------------------------------------------------------------- /das/reader_aggregator_strategies.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/reader_aggregator_strategies.go -------------------------------------------------------------------------------- /das/reader_aggregator_strategies_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/reader_aggregator_strategies_test.go -------------------------------------------------------------------------------- /das/redis_storage_service.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/redis_storage_service.go -------------------------------------------------------------------------------- /das/redis_storage_service_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/redis_storage_service_test.go -------------------------------------------------------------------------------- /das/redundant_storage_service.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/redundant_storage_service.go -------------------------------------------------------------------------------- /das/redundant_storage_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/redundant_storage_test.go -------------------------------------------------------------------------------- /das/regular_sync_storage_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/regular_sync_storage_test.go -------------------------------------------------------------------------------- /das/regularly_sync_storage.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/regularly_sync_storage.go -------------------------------------------------------------------------------- /das/rest_server_list.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/rest_server_list.go -------------------------------------------------------------------------------- /das/restful_client.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/restful_client.go -------------------------------------------------------------------------------- /das/restful_server.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/restful_server.go -------------------------------------------------------------------------------- /das/restful_server_list_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/restful_server_list_test.go -------------------------------------------------------------------------------- /das/restful_server_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/restful_server_test.go -------------------------------------------------------------------------------- /das/rpc_aggregator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/rpc_aggregator.go -------------------------------------------------------------------------------- /das/rpc_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/rpc_test.go -------------------------------------------------------------------------------- /das/s3_storage_service.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/s3_storage_service.go -------------------------------------------------------------------------------- /das/s3_storage_service_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/s3_storage_service_test.go -------------------------------------------------------------------------------- /das/sign_after_store_das_writer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/sign_after_store_das_writer.go -------------------------------------------------------------------------------- /das/simple_das_reader_aggregator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/simple_das_reader_aggregator.go -------------------------------------------------------------------------------- /das/simple_das_reader_aggregator_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/simple_das_reader_aggregator_test.go -------------------------------------------------------------------------------- /das/storage_service.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/storage_service.go -------------------------------------------------------------------------------- /das/store_signing.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/store_signing.go -------------------------------------------------------------------------------- /das/store_signing_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/store_signing_test.go -------------------------------------------------------------------------------- /das/syncing_fallback_storage.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/syncing_fallback_storage.go -------------------------------------------------------------------------------- /das/timeout_wrapper.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/timeout_wrapper.go -------------------------------------------------------------------------------- /das/util.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/das/util.go -------------------------------------------------------------------------------- /deploy/deploy.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/deploy/deploy.go -------------------------------------------------------------------------------- /docs/Nitro-whitepaper.pdf: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/docs/Nitro-whitepaper.pdf -------------------------------------------------------------------------------- /docs/notice.md: -------------------------------------------------------------------------------- 1 | **Note**: Docs now live at https://github.com/OffchainLabs/nitro-docs -------------------------------------------------------------------------------- /execution/gethexec/api.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/api.go -------------------------------------------------------------------------------- /execution/gethexec/arb_interface.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/arb_interface.go -------------------------------------------------------------------------------- /execution/gethexec/block_recorder.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/block_recorder.go -------------------------------------------------------------------------------- /execution/gethexec/blockchain.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/blockchain.go -------------------------------------------------------------------------------- /execution/gethexec/classicMessage.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/classicMessage.go -------------------------------------------------------------------------------- /execution/gethexec/executionengine.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/executionengine.go -------------------------------------------------------------------------------- /execution/gethexec/forwarder.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/forwarder.go -------------------------------------------------------------------------------- /execution/gethexec/node.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/node.go -------------------------------------------------------------------------------- /execution/gethexec/sequencer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/sequencer.go -------------------------------------------------------------------------------- /execution/gethexec/sync_monitor.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/sync_monitor.go -------------------------------------------------------------------------------- /execution/gethexec/tx_pre_checker.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/gethexec/tx_pre_checker.go -------------------------------------------------------------------------------- /execution/interface.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/interface.go -------------------------------------------------------------------------------- /execution/nodeInterface/NodeInterface.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/nodeInterface/NodeInterface.go -------------------------------------------------------------------------------- /execution/nodeInterface/NodeInterfaceDebug.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/nodeInterface/NodeInterfaceDebug.go -------------------------------------------------------------------------------- /execution/nodeInterface/virtual-contracts.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/execution/nodeInterface/virtual-contracts.go -------------------------------------------------------------------------------- /gethhook/geth-hook.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/gethhook/geth-hook.go -------------------------------------------------------------------------------- /gethhook/geth_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/gethhook/geth_test.go -------------------------------------------------------------------------------- /go.mod: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/go.mod -------------------------------------------------------------------------------- /go.sum: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/go.sum -------------------------------------------------------------------------------- /linters/koanf/handlers.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/koanf/handlers.go -------------------------------------------------------------------------------- /linters/koanf/koanf.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/koanf/koanf.go -------------------------------------------------------------------------------- /linters/koanf/koanf_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/koanf/koanf_test.go -------------------------------------------------------------------------------- /linters/linters.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/linters.go -------------------------------------------------------------------------------- /linters/pointercheck/pointercheck.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/pointercheck/pointercheck.go -------------------------------------------------------------------------------- /linters/pointercheck/pointercheck_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/pointercheck/pointercheck_test.go -------------------------------------------------------------------------------- /linters/rightshift/rightshift.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/rightshift/rightshift.go -------------------------------------------------------------------------------- /linters/rightshift/rightshift_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/rightshift/rightshift_test.go -------------------------------------------------------------------------------- /linters/structinit/structinit.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/structinit/structinit.go -------------------------------------------------------------------------------- /linters/structinit/structinit_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/structinit/structinit_test.go -------------------------------------------------------------------------------- /linters/testdata/src/koanf/a/a.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/testdata/src/koanf/a/a.go -------------------------------------------------------------------------------- /linters/testdata/src/koanf/b/b.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/testdata/src/koanf/b/b.go -------------------------------------------------------------------------------- /linters/testdata/src/pointercheck/pointercheck.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/testdata/src/pointercheck/pointercheck.go -------------------------------------------------------------------------------- /linters/testdata/src/rightshift/rightshift.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/testdata/src/rightshift/rightshift.go -------------------------------------------------------------------------------- /linters/testdata/src/structinit/a/a.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/linters/testdata/src/structinit/a/a.go -------------------------------------------------------------------------------- /precompiles/ArbAddressTable.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbAddressTable.go -------------------------------------------------------------------------------- /precompiles/ArbAddressTable_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbAddressTable_test.go -------------------------------------------------------------------------------- /precompiles/ArbAggregator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbAggregator.go -------------------------------------------------------------------------------- /precompiles/ArbAggregator_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbAggregator_test.go -------------------------------------------------------------------------------- /precompiles/ArbBLS.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbBLS.go -------------------------------------------------------------------------------- /precompiles/ArbDebug.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbDebug.go -------------------------------------------------------------------------------- /precompiles/ArbFunctionTable.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbFunctionTable.go -------------------------------------------------------------------------------- /precompiles/ArbGasInfo.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbGasInfo.go -------------------------------------------------------------------------------- /precompiles/ArbInfo.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbInfo.go -------------------------------------------------------------------------------- /precompiles/ArbOwner.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbOwner.go -------------------------------------------------------------------------------- /precompiles/ArbOwnerPublic.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbOwnerPublic.go -------------------------------------------------------------------------------- /precompiles/ArbOwner_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbOwner_test.go -------------------------------------------------------------------------------- /precompiles/ArbRetryableTx.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbRetryableTx.go -------------------------------------------------------------------------------- /precompiles/ArbRetryableTx_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbRetryableTx_test.go -------------------------------------------------------------------------------- /precompiles/ArbStatistics.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbStatistics.go -------------------------------------------------------------------------------- /precompiles/ArbSys.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbSys.go -------------------------------------------------------------------------------- /precompiles/ArbWasm.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbWasm.go -------------------------------------------------------------------------------- /precompiles/ArbWasmCache.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbWasmCache.go -------------------------------------------------------------------------------- /precompiles/ArbosActs.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbosActs.go -------------------------------------------------------------------------------- /precompiles/ArbosTest.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/ArbosTest.go -------------------------------------------------------------------------------- /precompiles/context.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/context.go -------------------------------------------------------------------------------- /precompiles/precompile.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/precompile.go -------------------------------------------------------------------------------- /precompiles/precompile_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/precompile_test.go -------------------------------------------------------------------------------- /precompiles/wrapper.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/precompiles/wrapper.go -------------------------------------------------------------------------------- /pubsub/consumer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/pubsub/consumer.go -------------------------------------------------------------------------------- /pubsub/producer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/pubsub/producer.go -------------------------------------------------------------------------------- /pubsub/pubsub_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/pubsub/pubsub_test.go -------------------------------------------------------------------------------- /relay/relay.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/relay/relay.go -------------------------------------------------------------------------------- /relay/relay_stress_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/relay/relay_stress_test.go -------------------------------------------------------------------------------- /scripts/build-brotli.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/scripts/build-brotli.sh -------------------------------------------------------------------------------- /scripts/create-test-preimages.py: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/scripts/create-test-preimages.py -------------------------------------------------------------------------------- /scripts/download-machine.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/scripts/download-machine.sh -------------------------------------------------------------------------------- /scripts/fuzz.bash: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/scripts/fuzz.bash -------------------------------------------------------------------------------- /scripts/split-val-entry.sh: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/scripts/split-val-entry.sh -------------------------------------------------------------------------------- /scripts/startup-testnode.bash: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/scripts/startup-testnode.bash -------------------------------------------------------------------------------- /solgen/gen.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/solgen/gen.go -------------------------------------------------------------------------------- /staker/assertion.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/assertion.go -------------------------------------------------------------------------------- /staker/block_challenge_backend.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/block_challenge_backend.go -------------------------------------------------------------------------------- /staker/block_validator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/block_validator.go -------------------------------------------------------------------------------- /staker/block_validator_schema.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/block_validator_schema.go -------------------------------------------------------------------------------- /staker/challenge_manager.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/challenge_manager.go -------------------------------------------------------------------------------- /staker/challenge_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/challenge_test.go -------------------------------------------------------------------------------- /staker/common_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/common_test.go -------------------------------------------------------------------------------- /staker/execution_challenge_bakend.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/execution_challenge_bakend.go -------------------------------------------------------------------------------- /staker/l1_validator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/l1_validator.go -------------------------------------------------------------------------------- /staker/rollup_watcher.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/rollup_watcher.go -------------------------------------------------------------------------------- /staker/staker.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/staker.go -------------------------------------------------------------------------------- /staker/stateless_block_validator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/stateless_block_validator.go -------------------------------------------------------------------------------- /staker/txbuilder/builder.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/txbuilder/builder.go -------------------------------------------------------------------------------- /staker/validatorwallet/contract.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/validatorwallet/contract.go -------------------------------------------------------------------------------- /staker/validatorwallet/eoa.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/validatorwallet/eoa.go -------------------------------------------------------------------------------- /staker/validatorwallet/noop.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/staker/validatorwallet/noop.go -------------------------------------------------------------------------------- /statetransfer/data.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/statetransfer/data.go -------------------------------------------------------------------------------- /statetransfer/interface.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/statetransfer/interface.go -------------------------------------------------------------------------------- /statetransfer/jsondatareader.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/statetransfer/jsondatareader.go -------------------------------------------------------------------------------- /statetransfer/memdatareader.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/statetransfer/memdatareader.go -------------------------------------------------------------------------------- /system_tests/aliasing_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/aliasing_test.go -------------------------------------------------------------------------------- /system_tests/arbtrace_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/arbtrace_test.go -------------------------------------------------------------------------------- /system_tests/batch_poster_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/batch_poster_test.go -------------------------------------------------------------------------------- /system_tests/benchmarks_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/benchmarks_test.go -------------------------------------------------------------------------------- /system_tests/block_hash_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/block_hash_test.go -------------------------------------------------------------------------------- /system_tests/block_validator_bench_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/block_validator_bench_test.go -------------------------------------------------------------------------------- /system_tests/block_validator_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/block_validator_test.go -------------------------------------------------------------------------------- /system_tests/blocks_reexecutor_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/blocks_reexecutor_test.go -------------------------------------------------------------------------------- /system_tests/bloom_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/bloom_test.go -------------------------------------------------------------------------------- /system_tests/common_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/common_test.go -------------------------------------------------------------------------------- /system_tests/conditionaltx_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/conditionaltx_test.go -------------------------------------------------------------------------------- /system_tests/contract_tx_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/contract_tx_test.go -------------------------------------------------------------------------------- /system_tests/das_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/das_test.go -------------------------------------------------------------------------------- /system_tests/debug_trace_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/debug_trace_test.go -------------------------------------------------------------------------------- /system_tests/debugapi_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/debugapi_test.go -------------------------------------------------------------------------------- /system_tests/delayedinbox_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/delayedinbox_test.go -------------------------------------------------------------------------------- /system_tests/delayedinboxlong_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/delayedinboxlong_test.go -------------------------------------------------------------------------------- /system_tests/deployment_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/deployment_test.go -------------------------------------------------------------------------------- /system_tests/estimation_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/estimation_test.go -------------------------------------------------------------------------------- /system_tests/eth_sync_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/eth_sync_test.go -------------------------------------------------------------------------------- /system_tests/fees_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/fees_test.go -------------------------------------------------------------------------------- /system_tests/forwarder_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/forwarder_test.go -------------------------------------------------------------------------------- /system_tests/full_challenge_impl_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/full_challenge_impl_test.go -------------------------------------------------------------------------------- /system_tests/full_challenge_mock_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/full_challenge_mock_test.go -------------------------------------------------------------------------------- /system_tests/full_challenge_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/full_challenge_test.go -------------------------------------------------------------------------------- /system_tests/infra_fee_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/infra_fee_test.go -------------------------------------------------------------------------------- /system_tests/initialization_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/initialization_test.go -------------------------------------------------------------------------------- /system_tests/log_subscription_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/log_subscription_test.go -------------------------------------------------------------------------------- /system_tests/meaningless_reorg_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/meaningless_reorg_test.go -------------------------------------------------------------------------------- /system_tests/nodeinterface_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/nodeinterface_test.go -------------------------------------------------------------------------------- /system_tests/outbox_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/outbox_test.go -------------------------------------------------------------------------------- /system_tests/pendingblock_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/pendingblock_test.go -------------------------------------------------------------------------------- /system_tests/precompile_fuzz_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/precompile_fuzz_test.go -------------------------------------------------------------------------------- /system_tests/precompile_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/precompile_test.go -------------------------------------------------------------------------------- /system_tests/program_norace_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/program_norace_test.go -------------------------------------------------------------------------------- /system_tests/program_race_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/program_race_test.go -------------------------------------------------------------------------------- /system_tests/program_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/program_test.go -------------------------------------------------------------------------------- /system_tests/pruning_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/pruning_test.go -------------------------------------------------------------------------------- /system_tests/recreatestate_rpc_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/recreatestate_rpc_test.go -------------------------------------------------------------------------------- /system_tests/reorg_resequencing_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/reorg_resequencing_test.go -------------------------------------------------------------------------------- /system_tests/retryable_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/retryable_test.go -------------------------------------------------------------------------------- /system_tests/rpc_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/rpc_test.go -------------------------------------------------------------------------------- /system_tests/seq_coordinator_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/seq_coordinator_test.go -------------------------------------------------------------------------------- /system_tests/seq_nonce_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/seq_nonce_test.go -------------------------------------------------------------------------------- /system_tests/seq_pause_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/seq_pause_test.go -------------------------------------------------------------------------------- /system_tests/seq_reject_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/seq_reject_test.go -------------------------------------------------------------------------------- /system_tests/seq_whitelist_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/seq_whitelist_test.go -------------------------------------------------------------------------------- /system_tests/seqcompensation_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/seqcompensation_test.go -------------------------------------------------------------------------------- /system_tests/seqfeed_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/seqfeed_test.go -------------------------------------------------------------------------------- /system_tests/seqinbox_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/seqinbox_test.go -------------------------------------------------------------------------------- /system_tests/staker_challenge_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/staker_challenge_test.go -------------------------------------------------------------------------------- /system_tests/staker_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/staker_test.go -------------------------------------------------------------------------------- /system_tests/state_fuzz_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/state_fuzz_test.go -------------------------------------------------------------------------------- /system_tests/staterecovery_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/staterecovery_test.go -------------------------------------------------------------------------------- /system_tests/stylus_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/stylus_test.go -------------------------------------------------------------------------------- /system_tests/test_info.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/test_info.go -------------------------------------------------------------------------------- /system_tests/transfer_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/transfer_test.go -------------------------------------------------------------------------------- /system_tests/triedb_race_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/triedb_race_test.go -------------------------------------------------------------------------------- /system_tests/twonodes_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/twonodes_test.go -------------------------------------------------------------------------------- /system_tests/twonodeslong_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/twonodeslong_test.go -------------------------------------------------------------------------------- /system_tests/unsupported_txtypes_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/unsupported_txtypes_test.go -------------------------------------------------------------------------------- /system_tests/validation_mock_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/validation_mock_test.go -------------------------------------------------------------------------------- /system_tests/validator_reorg_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/validator_reorg_test.go -------------------------------------------------------------------------------- /system_tests/wrap_transaction_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/system_tests/wrap_transaction_test.go -------------------------------------------------------------------------------- /util/arbmath/bips.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/arbmath/bips.go -------------------------------------------------------------------------------- /util/arbmath/bits.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/arbmath/bits.go -------------------------------------------------------------------------------- /util/arbmath/math.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/arbmath/math.go -------------------------------------------------------------------------------- /util/arbmath/math_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/arbmath/math_test.go -------------------------------------------------------------------------------- /util/arbmath/moving_average.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/arbmath/moving_average.go -------------------------------------------------------------------------------- /util/arbmath/moving_average_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/arbmath/moving_average_test.go -------------------------------------------------------------------------------- /util/arbmath/time.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/arbmath/time.go -------------------------------------------------------------------------------- /util/arbmath/uint24.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/arbmath/uint24.go -------------------------------------------------------------------------------- /util/blobs/blobs.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/blobs/blobs.go -------------------------------------------------------------------------------- /util/blobs/blobs_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/blobs/blobs_test.go -------------------------------------------------------------------------------- /util/colors/colors.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/colors/colors.go -------------------------------------------------------------------------------- /util/containers/lru.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/containers/lru.go -------------------------------------------------------------------------------- /util/containers/promise.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/containers/promise.go -------------------------------------------------------------------------------- /util/containers/promise_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/containers/promise_test.go -------------------------------------------------------------------------------- /util/containers/queue.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/containers/queue.go -------------------------------------------------------------------------------- /util/containers/queue_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/containers/queue_test.go -------------------------------------------------------------------------------- /util/containers/syncmap.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/containers/syncmap.go -------------------------------------------------------------------------------- /util/contracts/address_verifier.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/contracts/address_verifier.go -------------------------------------------------------------------------------- /util/headerreader/blob_client.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/headerreader/blob_client.go -------------------------------------------------------------------------------- /util/headerreader/blob_client_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/headerreader/blob_client_test.go -------------------------------------------------------------------------------- /util/headerreader/execution_reverted_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/headerreader/execution_reverted_test.go -------------------------------------------------------------------------------- /util/headerreader/header_reader.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/headerreader/header_reader.go -------------------------------------------------------------------------------- /util/jsonapi/preimages.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/jsonapi/preimages.go -------------------------------------------------------------------------------- /util/jsonapi/preimages_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/jsonapi/preimages_test.go -------------------------------------------------------------------------------- /util/jsonapi/uint64_string.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/jsonapi/uint64_string.go -------------------------------------------------------------------------------- /util/log.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/log.go -------------------------------------------------------------------------------- /util/log_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/log_test.go -------------------------------------------------------------------------------- /util/merkletree/common_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/merkletree/common_test.go -------------------------------------------------------------------------------- /util/merkletree/merkleAccumulator_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/merkletree/merkleAccumulator_test.go -------------------------------------------------------------------------------- /util/merkletree/merkleEventProof.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/merkletree/merkleEventProof.go -------------------------------------------------------------------------------- /util/merkletree/merkleEventProof_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/merkletree/merkleEventProof_test.go -------------------------------------------------------------------------------- /util/merkletree/merkleTree.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/merkletree/merkleTree.go -------------------------------------------------------------------------------- /util/metricsutil/metricsutil.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/metricsutil/metricsutil.go -------------------------------------------------------------------------------- /util/normalizeGas.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/normalizeGas.go -------------------------------------------------------------------------------- /util/pretty/pretty_printing.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/pretty/pretty_printing.go -------------------------------------------------------------------------------- /util/redisutil/redis_coordinator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/redisutil/redis_coordinator.go -------------------------------------------------------------------------------- /util/redisutil/redisutil.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/redisutil/redisutil.go -------------------------------------------------------------------------------- /util/redisutil/test_redis.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/redisutil/test_redis.go -------------------------------------------------------------------------------- /util/rpcclient/rpcclient.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/rpcclient/rpcclient.go -------------------------------------------------------------------------------- /util/rpcclient/rpcclient_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/rpcclient/rpcclient_test.go -------------------------------------------------------------------------------- /util/rpcclient/rpcclient_toxiproxy_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/rpcclient/rpcclient_toxiproxy_test.go -------------------------------------------------------------------------------- /util/sharedmetrics/sharedmetrics.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/sharedmetrics/sharedmetrics.go -------------------------------------------------------------------------------- /util/signature/datasigner.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/signature/datasigner.go -------------------------------------------------------------------------------- /util/signature/sign_verify.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/signature/sign_verify.go -------------------------------------------------------------------------------- /util/signature/sign_verify_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/signature/sign_verify_test.go -------------------------------------------------------------------------------- /util/signature/simple_hmac.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/signature/simple_hmac.go -------------------------------------------------------------------------------- /util/signature/verifier.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/signature/verifier.go -------------------------------------------------------------------------------- /util/signature/verifier_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/signature/verifier_test.go -------------------------------------------------------------------------------- /util/stopwaiter/stopwaiter.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/stopwaiter/stopwaiter.go -------------------------------------------------------------------------------- /util/stopwaiter/stopwaiter_promise_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/stopwaiter/stopwaiter_promise_test.go -------------------------------------------------------------------------------- /util/stopwaiter/stopwaiter_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/stopwaiter/stopwaiter_test.go -------------------------------------------------------------------------------- /util/testhelpers/pseudorandom.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/testhelpers/pseudorandom.go -------------------------------------------------------------------------------- /util/testhelpers/testhelpers.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/util/testhelpers/testhelpers.go -------------------------------------------------------------------------------- /validator/client/redis/producer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/client/redis/producer.go -------------------------------------------------------------------------------- /validator/client/validation_client.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/client/validation_client.go -------------------------------------------------------------------------------- /validator/execution_state.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/execution_state.go -------------------------------------------------------------------------------- /validator/interface.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/interface.go -------------------------------------------------------------------------------- /validator/server_api/json.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_api/json.go -------------------------------------------------------------------------------- /validator/server_arb/execution_run.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_arb/execution_run.go -------------------------------------------------------------------------------- /validator/server_arb/machine.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_arb/machine.go -------------------------------------------------------------------------------- /validator/server_arb/machine_cache.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_arb/machine_cache.go -------------------------------------------------------------------------------- /validator/server_arb/machine_loader.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_arb/machine_loader.go -------------------------------------------------------------------------------- /validator/server_arb/mock_machine.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_arb/mock_machine.go -------------------------------------------------------------------------------- /validator/server_arb/nitro_machine.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_arb/nitro_machine.go -------------------------------------------------------------------------------- /validator/server_arb/preimage_resolver.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_arb/preimage_resolver.go -------------------------------------------------------------------------------- /validator/server_arb/prover_interface.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_arb/prover_interface.go -------------------------------------------------------------------------------- /validator/server_arb/validator_spawner.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_arb/validator_spawner.go -------------------------------------------------------------------------------- /validator/server_common/machine_loader.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_common/machine_loader.go -------------------------------------------------------------------------------- /validator/server_common/machine_locator.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_common/machine_locator.go -------------------------------------------------------------------------------- /validator/server_common/machine_locator_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_common/machine_locator_test.go -------------------------------------------------------------------------------- /validator/server_common/testdata/0x68e4fe5023f792d4ef584796c84d710303a5e12ea02d6e37e2b5e9c4332507c4/module-root.txt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_common/testdata/0x68e4fe5023f792d4ef584796c84d710303a5e12ea02d6e37e2b5e9c4332507c4/module-root.txt -------------------------------------------------------------------------------- /validator/server_common/testdata/0x8b104a2e80ac6165dc58b9048de12f301d70b02a0ab51396c22b4b4b802a16a4/module-root.txt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_common/testdata/0x8b104a2e80ac6165dc58b9048de12f301d70b02a0ab51396c22b4b4b802a16a4/module-root.txt -------------------------------------------------------------------------------- /validator/server_common/testdata/0xf4389b835497a910d7ba3ebfb77aa93da985634f3c052de1290360635be40c4a/module-root.txt: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_common/testdata/0xf4389b835497a910d7ba3ebfb77aa93da985634f3c052de1290360635be40c4a/module-root.txt -------------------------------------------------------------------------------- /validator/server_common/testdata/latest: -------------------------------------------------------------------------------- 1 | 0xf4389b835497a910d7ba3ebfb77aa93da985634f3c052de1290360635be40c4a -------------------------------------------------------------------------------- /validator/server_common/valrun.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_common/valrun.go -------------------------------------------------------------------------------- /validator/server_jit/jit_machine.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_jit/jit_machine.go -------------------------------------------------------------------------------- /validator/server_jit/machine_loader.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_jit/machine_loader.go -------------------------------------------------------------------------------- /validator/server_jit/spawner.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/server_jit/spawner.go -------------------------------------------------------------------------------- /validator/utils.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/utils.go -------------------------------------------------------------------------------- /validator/validation_entry.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/validation_entry.go -------------------------------------------------------------------------------- /validator/valnode/redis/consumer.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/valnode/redis/consumer.go -------------------------------------------------------------------------------- /validator/valnode/validation_api.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/valnode/validation_api.go -------------------------------------------------------------------------------- /validator/valnode/valnode.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/validator/valnode/valnode.go -------------------------------------------------------------------------------- /wavmio/higher.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/wavmio/higher.go -------------------------------------------------------------------------------- /wavmio/raw.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/wavmio/raw.go -------------------------------------------------------------------------------- /wavmio/stub.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/wavmio/stub.go -------------------------------------------------------------------------------- /wsbroadcastserver/clientconnection.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/wsbroadcastserver/clientconnection.go -------------------------------------------------------------------------------- /wsbroadcastserver/clientmanager.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/wsbroadcastserver/clientmanager.go -------------------------------------------------------------------------------- /wsbroadcastserver/connectionlimiter.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/wsbroadcastserver/connectionlimiter.go -------------------------------------------------------------------------------- /wsbroadcastserver/connectionlimiter_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/wsbroadcastserver/connectionlimiter_test.go -------------------------------------------------------------------------------- /wsbroadcastserver/dictionary.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/wsbroadcastserver/dictionary.go -------------------------------------------------------------------------------- /wsbroadcastserver/utils.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/wsbroadcastserver/utils.go -------------------------------------------------------------------------------- /wsbroadcastserver/wsbroadcastserver.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/wsbroadcastserver/wsbroadcastserver.go -------------------------------------------------------------------------------- /zeroheavy/common_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/zeroheavy/common_test.go -------------------------------------------------------------------------------- /zeroheavy/zeroheavy.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/zeroheavy/zeroheavy.go -------------------------------------------------------------------------------- /zeroheavy/zeroheavy_test.go: -------------------------------------------------------------------------------- https://raw.githubusercontent.com/OffchainLabs/stylus/HEAD/zeroheavy/zeroheavy_test.go --------------------------------------------------------------------------------