## Nim-Codex ## Copyright (c) 2021 Status Research & Development GmbH ## Licensed under either of ## * Apache License, version 2.0, ([LICENSE-APACHE](LICENSE-APACHE)) ## * MIT license ([LICENSE-MIT](LICENSE-MIT)) ## at your option. ## This file may not be copied, modified, or distributed except according to ## those terms. import std/options import std/tables import std/sequtils import std/strformat import std/sugar import pkg/questionable import pkg/questionable/results import pkg/chronicles import pkg/chronos import pkg/libp2p/[switch, multicodec, multihash] import pkg/libp2p/stream/bufferstream # TODO: remove once exported by libp2p import pkg/libp2p/routing_record import pkg/libp2p/signed_envelope import ./chunker import ./blocktype as bt import ./manifest import ./merkletree import ./stores/blockstore import ./blockexchange import ./streams import ./erasure import ./discovery import ./contracts import ./node/batch import ./utils export batch logScope: topics = "codex node" const FetchBatch = 200 type CodexError = object of CatchableError Contracts* = tuple client: ?ClientInteractions host: ?HostInteractions validator: ?ValidatorInteractions CodexNodeRef* = ref object switch*: Switch networkId*: PeerId blockStore*: BlockStore engine*: BlockExcEngine erasure*: Erasure discovery*: Discovery contracts*: Contracts OnManifest* = proc(cid: Cid, manifest: Manifest): void {.gcsafe, closure.} proc findPeer*( node: CodexNodeRef, peerId: PeerId): Future[?PeerRecord] {.async.} = ## Find peer using the discovery service from the given CodexNode ## return await node.discovery.findPeer(peerId) proc connect*( node: CodexNodeRef, peerId: PeerId, addrs: seq[MultiAddress] ): Future[void] = node.switch.connect(peerId, addrs) proc fetchManifest*( node: CodexNodeRef, cid: Cid): Future[?!Manifest] {.async.} = ## Fetch and decode a manifest block ## if err =? cid.isManifest.errorOption: return failure "CID has invalid content type for manifest {$cid}" trace "Retrieving manifest for cid", cid without blk =? await node.blockStore.getBlock(BlockAddress.init(cid)), err: trace "Error retrieve manifest block", cid, err = err.msg return failure err trace "Decoding manifest for cid", cid without manifest =? Manifest.decode(blk), err: trace "Unable to decode as manifest", err = err.msg return failure("Unable to decode as manifest") trace "Decoded manifest", cid return manifest.success proc fetchBatched*( node: CodexNodeRef, manifest: Manifest, batchSize = FetchBatch, onBatch: BatchProc = nil): Future[?!void] {.async, gcsafe.} = ## Fetch manifest in batches of `batchSize` ## let batchCount = divUp(manifest.blocksCount, batchSize) trace "Fetching blocks in batches of", size = batchSize let iter = Iter.fromSlice(0.. node.blockStore.getBlock(BlockAddress.init(manifest.treeCid, i))) for batchNum in 0.. 0): trace "Got data from stream", len = chunk.len without mhash =? MultiHash.digest($hcodec, chunk).mapFailure, err: return failure(err) without cid =? Cid.init(CIDv1, dataCodec, mhash).mapFailure, err: return failure(err) without blk =? bt.Block.new(cid, chunk, verify = false): return failure("Unable to init block from chunk!") cids.add(cid) if err =? (await self.blockStore.putBlock(blk)).errorOption: trace "Unable to store block", cid = blk.cid, err = err.msg return failure(&"Unable to store block {blk.cid}") except CancelledError as exc: raise exc except CatchableError as exc: return failure(exc.msg) finally: await stream.close() without tree =? MerkleTree.init(cids), err: return failure(err) without treeCid =? tree.rootCid(CIDv1, dataCodec), err: return failure(err) for index, cid in cids: without proof =? tree.getProof(index), err: return failure(err) if err =? (await self.blockStore.putBlockCidAndProof(treeCid, index, cid, proof)).errorOption: # TODO add log here return failure(err) let manifest = Manifest.new( treeCid = treeCid, blockSize = blockSize, datasetSize = NBytes(chunker.offset), version = CIDv1, hcodec = hcodec, codec = dataCodec ) # Generate manifest without data =? manifest.encode(), err: return failure( newException(CodexError, "Error encoding manifest: " & err.msg)) # Store as a dag-pb block without manifestBlk =? bt.Block.new(data = data, codec = DagPBCodec): trace "Unable to init block from manifest data!" return failure("Unable to init block from manifest data!") if isErr (await self.blockStore.putBlock(manifestBlk)): trace "Unable to store manifest", cid = manifestBlk.cid return failure("Unable to store manifest " & $manifestBlk.cid) info "Stored data", manifestCid = manifestBlk.cid, treeCid = treeCid, blocks = manifest.blocksCount, datasetSize = manifest.datasetSize # Announce manifest await self.discovery.provide(manifestBlk.cid) await self.discovery.provide(treeCid) return manifestBlk.cid.success proc iterateManifests*(node: CodexNodeRef, onManifest: OnManifest) {.async.} = without cids =? await node.blockStore.listBlocks(BlockType.Manifest): warn "Failed to listBlocks" return for c in cids: if cid =? await c: without blk =? await node.blockStore.getBlock(cid): warn "Failed to get manifest block by cid", cid return without manifest =? Manifest.decode(blk): warn "Failed to decode manifest", cid return onManifest(cid, manifest) proc requestStorage*( self: CodexNodeRef, cid: Cid, duration: UInt256, proofProbability: UInt256, nodes: uint, tolerance: uint, reward: UInt256, collateral: UInt256, expiry = UInt256.none): Future[?!PurchaseId] {.async.} = ## Initiate a request for storage sequence, this might ## be a multistep procedure. ## ## Roughly the flow is as follows: ## - Get the original cid from the store (should have already been uploaded) ## - Erasure code it according to the nodes and tolerance parameters ## - Run the PoR setup on the erasure dataset ## - Call into the marketplace and purchasing contracts ## trace "Received a request for storage!", cid, duration, nodes, tolerance, reward, proofProbability, collateral, expiry without contracts =? self.contracts.client: trace "Purchasing not available" return failure "Purchasing not available" without manifest =? await self.fetchManifest(cid), error: trace "Unable to fetch manifest for cid", cid raise error # Erasure code the dataset according to provided parameters without encoded =? (await self.erasure.encode(manifest, nodes.int, tolerance.int)), error: trace "Unable to erasure code dataset", cid return failure(error) without encodedData =? encoded.encode(), error: trace "Unable to encode protected manifest" return failure(error) without encodedBlk =? bt.Block.new(data = encodedData, codec = DagPBCodec), error: trace "Unable to create block from encoded manifest" return failure(error) if isErr (await self.blockStore.putBlock(encodedBlk)): trace "Unable to store encoded manifest block", cid = encodedBlk.cid return failure("Unable to store encoded manifest block") let request = StorageRequest( ask: StorageAsk( slots: nodes + tolerance, # TODO: Specify slot-specific size (as below) once dispersal is # implemented. The current implementation downloads the entire dataset, so # it is currently set to be the size of the entire dataset. This is # because the slotSize is used to determine the amount of bytes to reserve # in a Reservations # TODO: slotSize: (encoded.blockSize.int * encoded.steps).u256, slotSize: (encoded.blockSize.int * encoded.blocksCount).u256, duration: duration, proofProbability: proofProbability, reward: reward, collateral: collateral, maxSlotLoss: tolerance ), content: StorageContent( cid: $encodedBlk.cid, erasure: StorageErasure( totalChunks: encoded.blocksCount.uint64, ), por: StoragePoR( u: @[], # TODO: PoR setup publicKey: @[], # TODO: PoR setup name: @[] # TODO: PoR setup ) ), expiry: expiry |? 0.u256 ) let purchase = await contracts.purchasing.purchase(request) return success purchase.id proc new*( T: type CodexNodeRef, switch: Switch, store: BlockStore, engine: BlockExcEngine, erasure: Erasure, discovery: Discovery, contracts = Contracts.default): CodexNodeRef = ## Create new instance of a Codex node, call `start` to run it ## CodexNodeRef( switch: switch, blockStore: store, engine: engine, erasure: erasure, discovery: discovery, contracts: contracts) proc start*(node: CodexNodeRef) {.async.} = if not node.engine.isNil: await node.engine.start() if not node.erasure.isNil: await node.erasure.start() if not node.discovery.isNil: await node.discovery.start() if hostContracts =? node.contracts.host: # TODO: remove Sales callbacks, pass BlockStore and StorageProofs instead hostContracts.sales.onStore = proc(request: StorageRequest, slot: UInt256, onBatch: BatchProc): Future[?!void] {.async.} = ## store data in local storage ## without cid =? Cid.init(request.content.cid): trace "Unable to parse Cid", cid let error = newException(CodexError, "Unable to parse Cid") return failure(error) without manifest =? await node.fetchManifest(cid), error: trace "Unable to fetch manifest for cid", cid return failure(error) trace "Fetching block for manifest", cid # TODO: This will probably require a call to `getBlock` either way, # since fetching of blocks will have to be selective according # to a combination of parameters, such as node slot position # and dataset geometry if fetchErr =? (await node.fetchBatched(manifest, onBatch = onBatch)).errorOption: let error = newException(CodexError, "Unable to retrieve blocks") error.parent = fetchErr return failure(error) return success() hostContracts.sales.onClear = proc(request: StorageRequest, slotIndex: UInt256) = # TODO: remove data from local storage discard hostContracts.sales.onProve = proc(slot: Slot): Future[seq[byte]] {.async.} = # TODO: generate proof return @[42'u8] try: await hostContracts.start() except CatchableError as error: error "Unable to start host contract interactions: ", error=error.msg node.contracts.host = HostInteractions.none if clientContracts =? node.contracts.client: try: await clientContracts.start() except CatchableError as error: error "Unable to start client contract interactions: ", error=error.msg node.contracts.client = ClientInteractions.none if validatorContracts =? node.contracts.validator: try: await validatorContracts.start() except CatchableError as error: error "Unable to start validator contract interactions: ", error=error.msg node.contracts.validator = ValidatorInteractions.none node.networkId = node.switch.peerInfo.peerId notice "Started codex node", id = $node.networkId, addrs = node.switch.peerInfo.addrs proc stop*(node: CodexNodeRef) {.async.} = trace "Stopping node" if not node.engine.isNil: await node.engine.stop() if not node.erasure.isNil: await node.erasure.stop() if not node.discovery.isNil: await node.discovery.stop() if clientContracts =? node.contracts.client: await clientContracts.stop() if hostContracts =? node.contracts.host: await hostContracts.stop() if validatorContracts =? node.contracts.validator: await validatorContracts.stop() if not node.blockStore.isNil: await node.blockStore.close