2020-07-01 18:44:59 +00:00
|
|
|
// Copyright © 2020 Vulcanize, Inc
|
|
|
|
//
|
|
|
|
// This program is free software: you can redistribute it and/or modify
|
|
|
|
// it under the terms of the GNU Affero General Public License as published by
|
|
|
|
// the Free Software Foundation, either version 3 of the License, or
|
|
|
|
// (at your option) any later version.
|
|
|
|
//
|
|
|
|
// This program is distributed in the hope that it will be useful,
|
|
|
|
// but WITHOUT ANY WARRANTY; without even the implied warranty of
|
|
|
|
// MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the
|
|
|
|
// GNU Affero General Public License for more details.
|
|
|
|
//
|
|
|
|
// You should have received a copy of the GNU Affero General Public License
|
|
|
|
// along with this program. If not, see <http://www.gnu.org/licenses/>.
|
|
|
|
|
2022-02-09 15:19:10 +00:00
|
|
|
package pg
|
2020-07-01 18:44:59 +00:00
|
|
|
|
|
|
|
import (
|
2022-02-09 15:19:10 +00:00
|
|
|
"context"
|
2021-12-15 07:23:18 +00:00
|
|
|
"fmt"
|
2021-12-23 07:52:44 +00:00
|
|
|
"sync/atomic"
|
|
|
|
"time"
|
2020-07-01 23:07:56 +00:00
|
|
|
|
2021-12-15 07:23:18 +00:00
|
|
|
"github.com/ethereum/go-ethereum/common"
|
2020-07-01 18:44:59 +00:00
|
|
|
"github.com/ethereum/go-ethereum/core/types"
|
2022-02-09 15:19:10 +00:00
|
|
|
"github.com/ipfs/go-cid"
|
|
|
|
blockstore "github.com/ipfs/go-ipfs-blockstore"
|
|
|
|
dshelp "github.com/ipfs/go-ipfs-ds-help"
|
2020-07-01 18:44:59 +00:00
|
|
|
"github.com/multiformats/go-multihash"
|
2022-03-09 13:37:33 +00:00
|
|
|
log "github.com/sirupsen/logrus"
|
2020-07-01 18:44:59 +00:00
|
|
|
|
2022-02-09 15:19:10 +00:00
|
|
|
"github.com/ethereum/go-ethereum/statediff/indexer/database/sql"
|
|
|
|
"github.com/ethereum/go-ethereum/statediff/indexer/database/sql/postgres"
|
|
|
|
"github.com/ethereum/go-ethereum/statediff/indexer/ipld"
|
2021-12-13 15:01:32 +00:00
|
|
|
"github.com/ethereum/go-ethereum/statediff/indexer/shared"
|
2022-03-30 23:57:30 +00:00
|
|
|
snapt "github.com/vulcanize/ipld-eth-state-snapshot/pkg/types"
|
2020-07-01 18:44:59 +00:00
|
|
|
)
|
|
|
|
|
2022-02-09 15:19:10 +00:00
|
|
|
var _ snapt.Publisher = (*publisher)(nil)
|
|
|
|
|
2021-12-23 14:34:34 +00:00
|
|
|
const logInterval = 1 * time.Minute
|
2021-12-23 07:52:44 +00:00
|
|
|
|
2021-12-14 06:50:19 +00:00
|
|
|
// Publisher is wrapper around DB.
|
2022-01-11 23:49:04 +00:00
|
|
|
type publisher struct {
|
2021-12-29 05:22:01 +00:00
|
|
|
db *postgres.DB
|
|
|
|
currBatchSize uint
|
2021-12-23 07:52:44 +00:00
|
|
|
stateNodeCounter uint64
|
2021-12-29 05:22:01 +00:00
|
|
|
storageNodeCounter uint64
|
|
|
|
codeNodeCounter uint64
|
|
|
|
startTime time.Time
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
|
|
|
|
2021-12-14 06:50:19 +00:00
|
|
|
// NewPublisher creates Publisher
|
2022-01-11 23:49:04 +00:00
|
|
|
func NewPublisher(db *postgres.DB) *publisher {
|
|
|
|
return &publisher{
|
2022-02-09 15:19:10 +00:00
|
|
|
db: db,
|
|
|
|
startTime: time.Now(),
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2022-02-09 15:19:10 +00:00
|
|
|
type pubTx struct {
|
|
|
|
sql.Tx
|
|
|
|
callback func()
|
|
|
|
}
|
|
|
|
|
|
|
|
func (tx pubTx) Rollback() error { return tx.Tx.Rollback(context.Background()) }
|
|
|
|
func (tx pubTx) Commit() error {
|
|
|
|
if tx.callback != nil {
|
|
|
|
defer tx.callback()
|
|
|
|
}
|
|
|
|
return tx.Tx.Commit(context.Background())
|
|
|
|
}
|
|
|
|
func (tx pubTx) Exec(sql string, args ...interface{}) (sql.Result, error) {
|
|
|
|
return tx.Tx.Exec(context.Background(), sql, args...)
|
|
|
|
}
|
|
|
|
|
|
|
|
func (p *publisher) BeginTx() (snapt.Tx, error) {
|
|
|
|
tx, err := p.db.Begin(context.Background())
|
2022-01-11 23:49:04 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
go p.logNodeCounters()
|
2022-02-09 15:19:10 +00:00
|
|
|
return pubTx{tx, func() {
|
2022-03-09 13:37:33 +00:00
|
|
|
p.printNodeCounters("final stats")
|
2022-02-09 15:19:10 +00:00
|
|
|
}}, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// PublishRaw derives a cid from raw bytes and provided codec and multihash type, and writes it to the db tx
|
|
|
|
// returns the CID and blockstore prefixed multihash key
|
2022-04-19 10:19:49 +00:00
|
|
|
func (tx pubTx) publishRaw(codec uint64, raw []byte, height uint64) (cid, prefixedKey string, err error) {
|
2022-02-09 15:19:10 +00:00
|
|
|
c, err := ipld.RawdataToCid(codec, raw, multihash.KECCAK_256)
|
|
|
|
if err != nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
cid = c.String()
|
2022-04-19 10:19:49 +00:00
|
|
|
prefixedKey, err = tx.publishIPLD(c, raw, height)
|
2022-02-09 15:19:10 +00:00
|
|
|
return
|
2022-01-11 23:49:04 +00:00
|
|
|
}
|
|
|
|
|
2022-04-19 10:19:49 +00:00
|
|
|
func (tx pubTx) publishIPLD(c cid.Cid, raw []byte, height uint64) (string, error) {
|
2022-02-09 15:19:10 +00:00
|
|
|
dbKey := dshelp.MultihashToDsKey(c.Hash())
|
|
|
|
prefixedKey := blockstore.BlockPrefix.String() + dbKey.String()
|
2022-04-19 10:19:49 +00:00
|
|
|
_, err := tx.Exec(snapt.TableIPLDBlock.ToInsertStatement(), height, prefixedKey, raw)
|
2022-02-09 15:19:10 +00:00
|
|
|
return prefixedKey, err
|
2022-01-11 23:49:04 +00:00
|
|
|
}
|
|
|
|
|
2020-07-31 05:31:34 +00:00
|
|
|
// PublishHeader writes the header to the ipfs backing pg datastore and adds secondary indexes in the header_cids table
|
2022-02-09 15:19:10 +00:00
|
|
|
func (p *publisher) PublishHeader(header *types.Header) (err error) {
|
2020-07-01 18:44:59 +00:00
|
|
|
headerNode, err := ipld.NewEthHeader(header)
|
|
|
|
if err != nil {
|
2022-02-09 15:19:10 +00:00
|
|
|
return err
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
2021-12-13 15:01:32 +00:00
|
|
|
|
2022-02-16 11:27:02 +00:00
|
|
|
snapTx, err := p.db.Begin(context.Background())
|
2020-07-01 18:44:59 +00:00
|
|
|
if err != nil {
|
2022-02-09 15:19:10 +00:00
|
|
|
return err
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
2022-02-16 11:27:02 +00:00
|
|
|
tx := pubTx{snapTx, nil}
|
2022-02-09 15:19:10 +00:00
|
|
|
defer func() { err = snapt.CommitOrRollback(tx, err) }()
|
2021-12-13 15:01:32 +00:00
|
|
|
|
2022-04-19 10:19:49 +00:00
|
|
|
if _, err = tx.publishIPLD(headerNode.Cid(), headerNode.RawData(), header.Number.Uint64()); err != nil {
|
2022-02-09 15:19:10 +00:00
|
|
|
return err
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
2021-12-13 15:01:32 +00:00
|
|
|
|
2022-02-09 15:19:10 +00:00
|
|
|
mhKey := shared.MultihashKeyFromCID(headerNode.Cid())
|
|
|
|
_, err = tx.Exec(snapt.TableHeader.ToInsertStatement(), header.Number.Uint64(), header.Hash().Hex(),
|
|
|
|
header.ParentHash.Hex(), headerNode.Cid().String(), "0", p.db.NodeID(), "0",
|
|
|
|
header.Root.Hex(), header.TxHash.Hex(), header.ReceiptHash.Hex(), header.UncleHash.Hex(),
|
|
|
|
header.Bloom.Bytes(), header.Time, mhKey, 0, header.Coinbase.String())
|
|
|
|
return err
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
|
|
|
|
2020-07-31 05:31:34 +00:00
|
|
|
// PublishStateNode writes the state node to the ipfs backing datastore and adds secondary indexes in the state_cids table
|
2022-04-19 10:19:49 +00:00
|
|
|
func (p *publisher) PublishStateNode(node *snapt.Node, headerID string, height uint64, snapTx snapt.Tx) error {
|
2020-07-01 18:44:59 +00:00
|
|
|
var stateKey string
|
2022-02-09 15:19:10 +00:00
|
|
|
if !snapt.IsNullHash(node.Key) {
|
2022-01-11 23:49:04 +00:00
|
|
|
stateKey = node.Key.Hex()
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
2021-12-13 15:01:32 +00:00
|
|
|
|
2022-02-16 11:27:02 +00:00
|
|
|
tx := snapTx.(pubTx)
|
2022-04-19 10:19:49 +00:00
|
|
|
stateCIDStr, mhKey, err := tx.publishRaw(ipld.MEthStateTrie, node.Value, height)
|
2020-07-01 18:44:59 +00:00
|
|
|
if err != nil {
|
2022-02-09 15:19:10 +00:00
|
|
|
return err
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
2021-12-13 15:01:32 +00:00
|
|
|
|
2022-02-09 15:19:10 +00:00
|
|
|
_, err = tx.Exec(snapt.TableStateNode.ToInsertStatement(),
|
2022-04-19 10:19:49 +00:00
|
|
|
height, headerID, stateKey, stateCIDStr, node.Path, node.NodeType, false, mhKey)
|
2022-02-09 15:19:10 +00:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2021-12-23 07:52:44 +00:00
|
|
|
// increment state node counter.
|
|
|
|
atomic.AddUint64(&p.stateNodeCounter, 1)
|
|
|
|
|
|
|
|
// increment current batch size counter
|
2021-12-13 15:01:32 +00:00
|
|
|
p.currBatchSize += 2
|
2022-02-09 15:19:10 +00:00
|
|
|
return err
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
|
|
|
|
2020-07-31 05:31:34 +00:00
|
|
|
// PublishStorageNode writes the storage node to the ipfs backing pg datastore and adds secondary indexes in the storage_cids table
|
2022-04-19 10:19:49 +00:00
|
|
|
func (p *publisher) PublishStorageNode(node *snapt.Node, headerID string, height uint64, statePath []byte, snapTx snapt.Tx) error {
|
2020-07-01 18:44:59 +00:00
|
|
|
var storageKey string
|
2022-02-09 15:19:10 +00:00
|
|
|
if !snapt.IsNullHash(node.Key) {
|
2022-01-11 23:49:04 +00:00
|
|
|
storageKey = node.Key.Hex()
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
2021-12-13 15:01:32 +00:00
|
|
|
|
2022-02-16 11:27:02 +00:00
|
|
|
tx := snapTx.(pubTx)
|
2022-04-19 10:19:49 +00:00
|
|
|
storageCIDStr, mhKey, err := tx.publishRaw(ipld.MEthStorageTrie, node.Value, height)
|
2020-07-01 18:44:59 +00:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2021-12-13 15:01:32 +00:00
|
|
|
|
2022-02-09 15:19:10 +00:00
|
|
|
_, err = tx.Exec(snapt.TableStorageNode.ToInsertStatement(),
|
2022-04-19 10:19:49 +00:00
|
|
|
height, headerID, statePath, storageKey, storageCIDStr, node.Path, node.NodeType, false, mhKey)
|
2021-12-13 15:01:32 +00:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2021-12-23 07:52:44 +00:00
|
|
|
// increment storage node counter.
|
|
|
|
atomic.AddUint64(&p.storageNodeCounter, 1)
|
|
|
|
|
|
|
|
// increment current batch size counter
|
2021-12-13 15:01:32 +00:00
|
|
|
p.currBatchSize += 2
|
2022-02-09 15:19:10 +00:00
|
|
|
return err
|
2020-07-01 18:44:59 +00:00
|
|
|
}
|
2020-07-31 05:31:34 +00:00
|
|
|
|
|
|
|
// PublishCode writes code to the ipfs backing pg datastore
|
2022-04-19 10:19:49 +00:00
|
|
|
func (p *publisher) PublishCode(height uint64, codeHash common.Hash, codeBytes []byte, snapTx snapt.Tx) error {
|
2020-07-31 05:31:34 +00:00
|
|
|
// no codec for code, doesn't matter though since blockstore key is multihash-derived
|
2021-12-15 07:23:18 +00:00
|
|
|
mhKey, err := shared.MultihashKeyFromKeccak256(codeHash)
|
2020-07-31 05:31:34 +00:00
|
|
|
if err != nil {
|
2021-12-15 07:23:18 +00:00
|
|
|
return fmt.Errorf("error deriving multihash key from codehash: %v", err)
|
2020-07-31 05:31:34 +00:00
|
|
|
}
|
2021-12-13 15:01:32 +00:00
|
|
|
|
2022-02-16 11:27:02 +00:00
|
|
|
tx := snapTx.(pubTx)
|
2022-04-19 10:19:49 +00:00
|
|
|
if _, err = tx.Exec(snapt.TableIPLDBlock.ToInsertStatement(), height, mhKey, codeBytes); err != nil {
|
2021-12-15 07:23:18 +00:00
|
|
|
return fmt.Errorf("error publishing code IPLD: %v", err)
|
2021-12-13 15:01:32 +00:00
|
|
|
}
|
|
|
|
|
2021-12-29 05:22:01 +00:00
|
|
|
// increment code node counter.
|
|
|
|
atomic.AddUint64(&p.codeNodeCounter, 1)
|
2021-12-23 07:52:44 +00:00
|
|
|
|
2021-12-13 15:01:32 +00:00
|
|
|
p.currBatchSize++
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2022-02-09 15:19:10 +00:00
|
|
|
func (p *publisher) PrepareTxForBatch(tx snapt.Tx, maxBatchSize uint) (snapt.Tx, error) {
|
2021-12-13 15:01:32 +00:00
|
|
|
var err error
|
|
|
|
// maximum batch size reached, commit the current transaction and begin a new transaction.
|
|
|
|
if maxBatchSize <= p.currBatchSize {
|
|
|
|
if err = tx.Commit(); err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
2022-02-16 11:27:02 +00:00
|
|
|
snapTx, err := p.db.Begin(context.Background())
|
|
|
|
tx = pubTx{Tx: snapTx}
|
2021-12-13 15:01:32 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
p.currBatchSize = 0
|
|
|
|
}
|
|
|
|
|
|
|
|
return tx, nil
|
2020-07-31 05:31:34 +00:00
|
|
|
}
|
2021-12-23 07:52:44 +00:00
|
|
|
|
2021-12-29 05:42:19 +00:00
|
|
|
// logNodeCounters periodically logs the number of node processed.
|
2022-01-11 23:49:04 +00:00
|
|
|
func (p *publisher) logNodeCounters() {
|
2021-12-23 14:34:34 +00:00
|
|
|
t := time.NewTicker(logInterval)
|
2021-12-23 07:52:44 +00:00
|
|
|
for range t.C {
|
2022-03-09 13:37:33 +00:00
|
|
|
p.printNodeCounters("progress")
|
2021-12-23 07:52:44 +00:00
|
|
|
}
|
|
|
|
}
|
2021-12-29 05:42:19 +00:00
|
|
|
|
2022-03-09 13:37:33 +00:00
|
|
|
func (p *publisher) printNodeCounters(msg string) {
|
|
|
|
log.WithFields(log.Fields{
|
|
|
|
"runtime": time.Now().Sub(p.startTime).String(),
|
|
|
|
"state nodes": atomic.LoadUint64(&p.stateNodeCounter),
|
|
|
|
"storage nodes": atomic.LoadUint64(&p.storageNodeCounter),
|
|
|
|
"code nodes": atomic.LoadUint64(&p.codeNodeCounter),
|
|
|
|
}).Info(msg)
|
2021-12-29 05:42:19 +00:00
|
|
|
}
|