| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363 |
- // Copyright 2014 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 filters
- import (
- "context"
- "errors"
- "math/big"
- "github.com/ethereum/go-ethereum/common"
- "github.com/ethereum/go-ethereum/core/bloombits"
- "github.com/ethereum/go-ethereum/core/types"
- "github.com/ethereum/go-ethereum/rpc"
- )
- // Filter can be used to retrieve and filter logs.
- type Filter struct {
- sys *FilterSystem
- addresses []common.Address
- topics [][]common.Hash
- block common.Hash // Block hash if filtering a single block
- begin, end int64 // Range interval if filtering multiple blocks
- matcher *bloombits.Matcher
- }
- // NewRangeFilter creates a new filter which uses a bloom filter on blocks to
- // figure out whether a particular block is interesting or not.
- func (sys *FilterSystem) NewRangeFilter(begin, end int64, addresses []common.Address, topics [][]common.Hash) *Filter {
- // Flatten the address and topic filter clauses into a single bloombits filter
- // system. Since the bloombits are not positional, nil topics are permitted,
- // which get flattened into a nil byte slice.
- var filters [][][]byte
- if len(addresses) > 0 {
- filter := make([][]byte, len(addresses))
- for i, address := range addresses {
- filter[i] = address.Bytes()
- }
- filters = append(filters, filter)
- }
- for _, topicList := range topics {
- filter := make([][]byte, len(topicList))
- for i, topic := range topicList {
- filter[i] = topic.Bytes()
- }
- filters = append(filters, filter)
- }
- size, _ := sys.backend.BloomStatus()
- // Create a generic filter and convert it into a range filter
- filter := newFilter(sys, addresses, topics)
- filter.matcher = bloombits.NewMatcher(size, filters)
- filter.begin = begin
- filter.end = end
- return filter
- }
- // NewBlockFilter creates a new filter which directly inspects the contents of
- // a block to figure out whether it is interesting or not.
- func (sys *FilterSystem) NewBlockFilter(block common.Hash, addresses []common.Address, topics [][]common.Hash) *Filter {
- // Create a generic filter and convert it into a block filter
- filter := newFilter(sys, addresses, topics)
- filter.block = block
- return filter
- }
- // newFilter creates a generic filter that can either filter based on a block hash,
- // or based on range queries. The search criteria needs to be explicitly set.
- func newFilter(sys *FilterSystem, addresses []common.Address, topics [][]common.Hash) *Filter {
- return &Filter{
- sys: sys,
- addresses: addresses,
- topics: topics,
- }
- }
- // Logs searches the blockchain for matching log entries, returning all from the
- // first block that contains matches, updating the start of the filter accordingly.
- func (f *Filter) Logs(ctx context.Context) ([]*types.Log, error) {
- // If we're doing singleton block filtering, execute and return
- if f.block != (common.Hash{}) {
- header, err := f.sys.backend.HeaderByHash(ctx, f.block)
- if err != nil {
- return nil, err
- }
- if header == nil {
- return nil, errors.New("unknown block")
- }
- return f.blockLogs(ctx, header, false)
- }
- // Short-cut if all we care about is pending logs
- if f.begin == rpc.PendingBlockNumber.Int64() {
- if f.end != rpc.PendingBlockNumber.Int64() {
- return nil, errors.New("invalid block range")
- }
- return f.pendingLogs()
- }
- // Figure out the limits of the filter range
- header, _ := f.sys.backend.HeaderByNumber(ctx, rpc.LatestBlockNumber)
- if header == nil {
- return nil, nil
- }
- var (
- head = header.Number.Uint64()
- end = uint64(f.end)
- pending = f.end == rpc.PendingBlockNumber.Int64()
- )
- if f.begin == rpc.LatestBlockNumber.Int64() {
- f.begin = int64(head)
- }
- if f.end == rpc.LatestBlockNumber.Int64() || f.end == rpc.PendingBlockNumber.Int64() {
- end = head
- }
- // Gather all indexed logs, and finish with non indexed ones
- var (
- logs []*types.Log
- err error
- size, sections = f.sys.backend.BloomStatus()
- )
- if indexed := sections * size; indexed > uint64(f.begin) {
- if indexed > end {
- logs, err = f.indexedLogs(ctx, end)
- } else {
- logs, err = f.indexedLogs(ctx, indexed-1)
- }
- if err != nil {
- return logs, err
- }
- }
- rest, err := f.unindexedLogs(ctx, end)
- logs = append(logs, rest...)
- if pending {
- pendingLogs, err := f.pendingLogs()
- if err != nil {
- return nil, err
- }
- logs = append(logs, pendingLogs...)
- }
- return logs, err
- }
- // indexedLogs returns the logs matching the filter criteria based on the bloom
- // bits indexed available locally or via the network.
- func (f *Filter) indexedLogs(ctx context.Context, end uint64) ([]*types.Log, error) {
- // Create a matcher session and request servicing from the backend
- matches := make(chan uint64, 64)
- session, err := f.matcher.Start(ctx, uint64(f.begin), end, matches)
- if err != nil {
- return nil, err
- }
- defer session.Close()
- f.sys.backend.ServiceFilter(ctx, session)
- // Iterate over the matches until exhausted or context closed
- var logs []*types.Log
- for {
- select {
- case number, ok := <-matches:
- // Abort if all matches have been fulfilled
- if !ok {
- err := session.Error()
- if err == nil {
- f.begin = int64(end) + 1
- }
- return logs, err
- }
- f.begin = int64(number) + 1
- // Retrieve the suggested block and pull any truly matching logs
- header, err := f.sys.backend.HeaderByNumber(ctx, rpc.BlockNumber(number))
- if header == nil || err != nil {
- return logs, err
- }
- found, err := f.blockLogs(ctx, header, true)
- if err != nil {
- return logs, err
- }
- logs = append(logs, found...)
- case <-ctx.Done():
- return logs, ctx.Err()
- }
- }
- }
- // unindexedLogs returns the logs matching the filter criteria based on raw block
- // iteration and bloom matching.
- func (f *Filter) unindexedLogs(ctx context.Context, end uint64) ([]*types.Log, error) {
- var logs []*types.Log
- for ; f.begin <= int64(end); f.begin++ {
- header, err := f.sys.backend.HeaderByNumber(ctx, rpc.BlockNumber(f.begin))
- if header == nil || err != nil {
- return logs, err
- }
- found, err := f.blockLogs(ctx, header, false)
- if err != nil {
- return logs, err
- }
- logs = append(logs, found...)
- }
- return logs, nil
- }
- // blockLogs returns the logs matching the filter criteria within a single block.
- func (f *Filter) blockLogs(ctx context.Context, header *types.Header, skipBloom bool) ([]*types.Log, error) {
- // Fast track: no filtering criteria
- if len(f.addresses) == 0 && len(f.topics) == 0 {
- list, err := f.sys.cachedGetLogs(ctx, header.Hash(), header.Number.Uint64())
- if err != nil {
- return nil, err
- }
- return flatten(list), nil
- } else if skipBloom || bloomFilter(header.Bloom, f.addresses, f.topics) {
- return f.checkMatches(ctx, header)
- }
- return nil, nil
- }
- // checkMatches checks if the receipts belonging to the given header contain any log events that
- // match the filter criteria. This function is called when the bloom filter signals a potential match.
- func (f *Filter) checkMatches(ctx context.Context, header *types.Header) ([]*types.Log, error) {
- logsList, err := f.sys.cachedGetLogs(ctx, header.Hash(), header.Number.Uint64())
- if err != nil {
- return nil, err
- }
- unfiltered := flatten(logsList)
- logs := filterLogs(unfiltered, nil, nil, f.addresses, f.topics)
- if len(logs) > 0 {
- // We have matching logs, check if we need to resolve full logs via the light client
- if logs[0].TxHash == (common.Hash{}) {
- receipts, err := f.sys.backend.GetReceipts(ctx, header.Hash())
- if err != nil {
- return nil, err
- }
- unfiltered = unfiltered[:0]
- for _, receipt := range receipts {
- unfiltered = append(unfiltered, receipt.Logs...)
- }
- logs = filterLogs(unfiltered, nil, nil, f.addresses, f.topics)
- }
- return logs, nil
- }
- return nil, nil
- }
- // pendingLogs returns the logs matching the filter criteria within the pending block.
- func (f *Filter) pendingLogs() ([]*types.Log, error) {
- block, receipts := f.sys.backend.PendingBlockAndReceipts()
- if bloomFilter(block.Bloom(), f.addresses, f.topics) {
- var unfiltered []*types.Log
- for _, r := range receipts {
- unfiltered = append(unfiltered, r.Logs...)
- }
- return filterLogs(unfiltered, nil, nil, f.addresses, f.topics), nil
- }
- return nil, nil
- }
- func includes(addresses []common.Address, a common.Address) bool {
- for _, addr := range addresses {
- if addr == a {
- return true
- }
- }
- return false
- }
- // filterLogs creates a slice of logs matching the given criteria.
- func filterLogs(logs []*types.Log, fromBlock, toBlock *big.Int, addresses []common.Address, topics [][]common.Hash) []*types.Log {
- var ret []*types.Log
- Logs:
- for _, log := range logs {
- if fromBlock != nil && fromBlock.Int64() >= 0 && fromBlock.Uint64() > log.BlockNumber {
- continue
- }
- if toBlock != nil && toBlock.Int64() >= 0 && toBlock.Uint64() < log.BlockNumber {
- continue
- }
- if len(addresses) > 0 && !includes(addresses, log.Address) {
- continue
- }
- // If the to filtered topics is greater than the amount of topics in logs, skip.
- if len(topics) > len(log.Topics) {
- continue
- }
- for i, sub := range topics {
- match := len(sub) == 0 // empty rule set == wildcard
- for _, topic := range sub {
- if log.Topics[i] == topic {
- match = true
- break
- }
- }
- if !match {
- continue Logs
- }
- }
- ret = append(ret, log)
- }
- return ret
- }
- func bloomFilter(bloom types.Bloom, addresses []common.Address, topics [][]common.Hash) bool {
- if len(addresses) > 0 {
- var included bool
- for _, addr := range addresses {
- if types.BloomLookup(bloom, addr) {
- included = true
- break
- }
- }
- if !included {
- return false
- }
- }
- for _, sub := range topics {
- included := len(sub) == 0 // empty rule set == wildcard
- for _, topic := range sub {
- if types.BloomLookup(bloom, topic) {
- included = true
- break
- }
- }
- if !included {
- return false
- }
- }
- return true
- }
- func flatten(list [][]*types.Log) []*types.Log {
- var flat []*types.Log
- for _, logs := range list {
- flat = append(flat, logs...)
- }
- return flat
- }
|