| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293 |
- // Copyright 2016 The go-ethereum Authors
- // This file is part of the go-ethereum library.
- //
- // The go-ethereum library is free software: you can redistribute it and/or modify
- // it under the terms of the GNU Lesser General Public License as published by
- // the Free Software Foundation, either version 3 of the License, or
- // (at your option) any later version.
- //
- // The go-ethereum library 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 Lesser General Public License for more details.
- //
- // You should have received a copy of the GNU Lesser General Public License
- // along with the go-ethereum library. If not, see <http://www.gnu.org/licenses/>.
- package storage
- import (
- "bytes"
- "context"
- "crypto/rand"
- "flag"
- "fmt"
- "io"
- "io/ioutil"
- "os"
- "sync"
- "testing"
- "time"
- "github.com/ethereum/go-ethereum/log"
- ch "github.com/ethereum/go-ethereum/swarm/chunk"
- colorable "github.com/mattn/go-colorable"
- )
- var (
- loglevel = flag.Int("loglevel", 3, "verbosity of logs")
- getTimeout = 30 * time.Second
- )
- func init() {
- flag.Parse()
- log.PrintOrigins(true)
- log.Root().SetHandler(log.LvlFilterHandler(log.Lvl(*loglevel), log.StreamHandler(colorable.NewColorableStderr(), log.TerminalFormat(true))))
- }
- type brokenLimitedReader struct {
- lr io.Reader
- errAt int
- off int
- size int
- }
- func brokenLimitReader(data io.Reader, size int, errAt int) *brokenLimitedReader {
- return &brokenLimitedReader{
- lr: data,
- errAt: errAt,
- size: size,
- }
- }
- func newLDBStore(t *testing.T) (*LDBStore, func()) {
- dir, err := ioutil.TempDir("", "bzz-storage-test")
- if err != nil {
- t.Fatal(err)
- }
- log.Trace("memstore.tempdir", "dir", dir)
- ldbparams := NewLDBStoreParams(NewDefaultStoreParams(), dir)
- db, err := NewLDBStore(ldbparams)
- if err != nil {
- t.Fatal(err)
- }
- cleanup := func() {
- db.Close()
- err := os.RemoveAll(dir)
- if err != nil {
- t.Fatal(err)
- }
- }
- return db, cleanup
- }
- func mputRandomChunks(store ChunkStore, n int, chunksize int64) ([]Chunk, error) {
- return mput(store, n, GenerateRandomChunk)
- }
- func mputChunks(store ChunkStore, chunks ...Chunk) error {
- i := 0
- f := func(n int64) Chunk {
- chunk := chunks[i]
- i++
- return chunk
- }
- _, err := mput(store, len(chunks), f)
- return err
- }
- func mput(store ChunkStore, n int, f func(i int64) Chunk) (hs []Chunk, err error) {
- // put to localstore and wait for stored channel
- // does not check delivery error state
- errc := make(chan error)
- ctx, cancel := context.WithTimeout(context.Background(), 30*time.Second)
- defer cancel()
- for i := int64(0); i < int64(n); i++ {
- chunk := f(ch.DefaultSize)
- go func() {
- select {
- case errc <- store.Put(ctx, chunk):
- case <-ctx.Done():
- }
- }()
- hs = append(hs, chunk)
- }
- // wait for all chunks to be stored
- for i := 0; i < n; i++ {
- err := <-errc
- if err != nil {
- return nil, err
- }
- }
- return hs, nil
- }
- func mget(store ChunkStore, hs []Address, f func(h Address, chunk Chunk) error) error {
- wg := sync.WaitGroup{}
- wg.Add(len(hs))
- errc := make(chan error)
- for _, k := range hs {
- go func(h Address) {
- defer wg.Done()
- // TODO: write timeout with context
- chunk, err := store.Get(context.TODO(), h)
- if err != nil {
- errc <- err
- return
- }
- if f != nil {
- err = f(h, chunk)
- if err != nil {
- errc <- err
- return
- }
- }
- }(k)
- }
- go func() {
- wg.Wait()
- close(errc)
- }()
- var err error
- select {
- case err = <-errc:
- case <-time.NewTimer(5 * time.Second).C:
- err = fmt.Errorf("timed out after 5 seconds")
- }
- return err
- }
- func testDataReader(l int) (r io.Reader) {
- return io.LimitReader(rand.Reader, int64(l))
- }
- func (r *brokenLimitedReader) Read(buf []byte) (int, error) {
- if r.off+len(buf) > r.errAt {
- return 0, fmt.Errorf("Broken reader")
- }
- r.off += len(buf)
- return r.lr.Read(buf)
- }
- func testStoreRandom(m ChunkStore, n int, chunksize int64, t *testing.T) {
- chunks, err := mputRandomChunks(m, n, chunksize)
- if err != nil {
- t.Fatalf("expected no error, got %v", err)
- }
- err = mget(m, chunkAddresses(chunks), nil)
- if err != nil {
- t.Fatalf("testStore failed: %v", err)
- }
- }
- func testStoreCorrect(m ChunkStore, n int, chunksize int64, t *testing.T) {
- chunks, err := mputRandomChunks(m, n, chunksize)
- if err != nil {
- t.Fatalf("expected no error, got %v", err)
- }
- f := func(h Address, chunk Chunk) error {
- if !bytes.Equal(h, chunk.Address()) {
- return fmt.Errorf("key does not match retrieved chunk Address")
- }
- hasher := MakeHashFunc(DefaultHash)()
- hasher.ResetWithLength(chunk.SpanBytes())
- hasher.Write(chunk.Payload())
- exp := hasher.Sum(nil)
- if !bytes.Equal(h, exp) {
- return fmt.Errorf("key is not hash of chunk data")
- }
- return nil
- }
- err = mget(m, chunkAddresses(chunks), f)
- if err != nil {
- t.Fatalf("testStore failed: %v", err)
- }
- }
- func benchmarkStorePut(store ChunkStore, n int, chunksize int64, b *testing.B) {
- chunks := make([]Chunk, n)
- i := 0
- f := func(dataSize int64) Chunk {
- chunk := GenerateRandomChunk(dataSize)
- chunks[i] = chunk
- i++
- return chunk
- }
- mput(store, n, f)
- f = func(dataSize int64) Chunk {
- chunk := chunks[i]
- i++
- return chunk
- }
- b.ReportAllocs()
- b.ResetTimer()
- for j := 0; j < b.N; j++ {
- i = 0
- mput(store, n, f)
- }
- }
- func benchmarkStoreGet(store ChunkStore, n int, chunksize int64, b *testing.B) {
- chunks, err := mputRandomChunks(store, n, chunksize)
- if err != nil {
- b.Fatalf("expected no error, got %v", err)
- }
- b.ReportAllocs()
- b.ResetTimer()
- addrs := chunkAddresses(chunks)
- for i := 0; i < b.N; i++ {
- err := mget(store, addrs, nil)
- if err != nil {
- b.Fatalf("mget failed: %v", err)
- }
- }
- }
- // MapChunkStore is a very simple ChunkStore implementation to store chunks in a map in memory.
- type MapChunkStore struct {
- chunks map[string]Chunk
- mu sync.RWMutex
- }
- func NewMapChunkStore() *MapChunkStore {
- return &MapChunkStore{
- chunks: make(map[string]Chunk),
- }
- }
- func (m *MapChunkStore) Put(_ context.Context, ch Chunk) error {
- m.mu.Lock()
- defer m.mu.Unlock()
- m.chunks[ch.Address().Hex()] = ch
- return nil
- }
- func (m *MapChunkStore) Get(_ context.Context, ref Address) (Chunk, error) {
- m.mu.RLock()
- defer m.mu.RUnlock()
- chunk := m.chunks[ref.Hex()]
- if chunk == nil {
- return nil, ErrChunkNotFound
- }
- return chunk, nil
- }
- func (m *MapChunkStore) Close() {
- }
- func chunkAddresses(chunks []Chunk) []Address {
- addrs := make([]Address, len(chunks))
- for i, ch := range chunks {
- addrs[i] = ch.Address()
- }
- return addrs
- }
|