fix variable name
[electrum-server.git] / backends / bitcoind / blockchain_processor.py
index e21ed89..421f385 100644 (file)
+import ast
+import hashlib
 from json import dumps, loads
-import leveldb, urllib
-import deserialize
-import ast, time, threading, hashlib
+import os
 from Queue import Queue
-import traceback, sys, os
-
-
-
-Hash = lambda x: hashlib.sha256(hashlib.sha256(x).digest()).digest()
-hash_encode = lambda x: x[::-1].encode('hex')
-hash_decode = lambda x: x.decode('hex')[::-1]
-
-
-
-def rev_hex(s):
-    return s.decode('hex')[::-1].encode('hex')
-
-
-def int_to_hex(i, length=1):
-    s = hex(i)[2:].rstrip('L')
-    s = "0"*(2*length - len(s)) + s
-    return rev_hex(s)
-
-def header_to_string(res):
-    pbh = res.get('prev_block_hash')
-    if pbh is None: pbh = '0'*64
-    s = int_to_hex(res.get('version'),4) \
-        + rev_hex(pbh) \
-        + rev_hex(res.get('merkle_root')) \
-        + int_to_hex(int(res.get('timestamp')),4) \
-        + int_to_hex(int(res.get('bits')),4) \
-        + int_to_hex(int(res.get('nonce')),4)
-    return s
-
-def header_from_string( s):
-    hex_to_int = lambda s: eval('0x' + s[::-1].encode('hex'))
-    h = {}
-    h['version'] = hex_to_int(s[0:4])
-    h['prev_block_hash'] = hash_encode(s[4:36])
-    h['merkle_root'] = hash_encode(s[36:68])
-    h['timestamp'] = hex_to_int(s[68:72])
-    h['bits'] = hex_to_int(s[72:76])
-    h['nonce'] = hex_to_int(s[76:80])
-    return h
-
-
+import random
+import sys
+import time
+import threading
+import traceback
+import urllib
+
+from backends.bitcoind import deserialize
+from processor import Processor, print_log
+from utils import *
 
+from storage import Storage
 
-from processor import Processor, print_log
 
 class BlockchainProcessor(Processor):
 
     def __init__(self, config, shared):
         Processor.__init__(self)
 
+        self.mtimes = {} # monitoring
         self.shared = shared
+        self.config = config
         self.up_to_date = False
-        self.watched_addresses = []
+
+        self.watch_lock = threading.Lock()
+        self.watch_blocks = []
+        self.watch_headers = []
+        self.watched_addresses = {}
+
         self.history_cache = {}
         self.chunk_cache = {}
         self.cache_lock = threading.Lock()
         self.headers_data = ''
+        self.headers_path = config.get('leveldb', 'path_fulltree')
 
         self.mempool_addresses = {}
         self.mempool_hist = {}
-        self.mempool_hashes = []
+        self.mempool_hashes = set([])
         self.mempool_lock = threading.Lock()
 
         self.address_queue = Queue()
-        self.dbpath = config.get('leveldb', 'path')
 
-        self.dblock = threading.Lock()
         try:
-            self.db = leveldb.LevelDB(self.dbpath)
+            self.test_reorgs = config.getboolean('leveldb', 'test_reorgs')   # simulate random blockchain reorgs
         except:
-            traceback.print_exc(file=sys.stdout)
-            self.shared.stop()
+            self.test_reorgs = False
+        self.storage = Storage(config, shared, self.test_reorgs)
+
+        self.dblock = threading.Lock()
 
         self.bitcoind_url = 'http://%s:%s@%s:%s/' % (
-            config.get('bitcoind','user'),
-            config.get('bitcoind','password'),
-            config.get('bitcoind','host'),
-            config.get('bitcoind','port'))
+            config.get('bitcoind', 'user'),
+            config.get('bitcoind', 'password'),
+            config.get('bitcoind', 'host'),
+            config.get('bitcoind', 'port'))
+
+        while True:
+            try:
+                self.bitcoind('getinfo')
+                break
+            except:
+                print_log('cannot contact bitcoind...')
+                time.sleep(5)
+                continue
 
-        self.height = 0
         self.sent_height = 0
         self.sent_header = None
 
-
-        try:
-            hist = self.deserialize(self.db.Get('0'))
-            self.last_hash, self.height, _ = hist[0] 
-            print_log( "hist", hist )
-        except:
-            #traceback.print_exc(file=sys.stdout)
-            print_log('initializing database')
-            self.height = 0
-            self.last_hash = '000000000019d6689c085ae165831e934ff763ae46a2a6c172b3f1b60a8ce26f'
-
         # catch_up headers
-        self.init_headers(self.height)
+        self.init_headers(self.storage.height)
 
         threading.Timer(0, lambda: self.catch_up(sync=False)).start()
         while not shared.stopped() and not self.up_to_date:
@@ -110,53 +83,62 @@ class BlockchainProcessor(Processor):
                 shared.stop()
                 sys.exit(0)
 
-        print_log( "blockchain is up to date." )
+        print_log("Blockchain is up to date.")
+        self.memorypool_update()
+        print_log("Memory pool initialized.")
 
         threading.Timer(10, self.main_iteration).start()
 
 
 
-    def bitcoind(self, method, params=[]):
-        postdata = dumps({"method": method, 'params': params, 'id':'jsonrpc'})
-        respdata = urllib.urlopen(self.bitcoind_url, postdata).read()
-        r = loads(respdata)
-        if r['error'] != None:
-            raise BaseException(r['error'])
-        return r.get('result')
-    
+    def mtime(self, name):
+        now = time.time()
+        if name != '':
+            delta = now - self.now
+            t = self.mtimes.get(name, 0)
+            self.mtimes[name] = t + delta
+        self.now = now
 
-    def serialize(self, h):
+    def print_mtime(self):
         s = ''
-        for txid, txpos, height in h:
-            s += txid + int_to_hex(txpos, 4) + int_to_hex(height, 4)
-        return s.decode('hex')
+        for k, v in self.mtimes.items():
+            s += k+':'+"%.2f"%v+' '
+        print_log(s)
 
 
-    def deserialize(self, s):
-        h = []
-        while s:
-            txid = s[0:32].encode('hex')
-            txpos = int( rev_hex( s[32:36].encode('hex') ), 16 )
-            height = int( rev_hex( s[36:40].encode('hex') ), 16 )
-            h.append( ( txid, txpos, height ) )
-            s = s[40:]
-        return h
+    def bitcoind(self, method, params=[]):
+        postdata = dumps({"method": method, 'params': params, 'id': 'jsonrpc'})
+        try:
+            respdata = urllib.urlopen(self.bitcoind_url, postdata).read()
+        except:
+            traceback.print_exc(file=sys.stdout)
+            self.shared.stop()
+
+        r = loads(respdata)
+        if r['error'] is not None:
+            raise BaseException(r['error'])
+        return r.get('result')
 
 
     def block2header(self, b):
-        return {"block_height":b.get('height'), "version":b.get('version'), "prev_block_hash":b.get('previousblockhash'), 
-                "merkle_root":b.get('merkleroot'), "timestamp":b.get('time'), "bits":int(b.get('bits'),16), "nonce":b.get('nonce')}
-
+        return {
+            "block_height": b.get('height'),
+            "version": b.get('version'),
+            "prev_block_hash": b.get('previousblockhash'),
+            "merkle_root": b.get('merkleroot'),
+            "timestamp": b.get('time'),
+            "bits": int(b.get('bits'), 16),
+            "nonce": b.get('nonce'),
+        }
 
     def get_header(self, height):
         block_hash = self.bitcoind('getblockhash', [height])
         b = self.bitcoind('getblock', [block_hash])
         return self.block2header(b)
-    
 
     def init_headers(self, db_height):
         self.chunk_cache = {}
-        self.headers_filename = os.path.join( self.dbpath, 'blockchain_headers')
+        self.headers_filename = os.path.join(self.headers_path, 'blockchain_headers')
 
         if os.path.exists(self.headers_filename):
             height = os.path.getsize(self.headers_filename)/80 - 1   # the current height
@@ -165,52 +147,47 @@ class BlockchainProcessor(Processor):
             else:
                 prev_hash = None
         else:
-            open(self.headers_filename,'wb').close()
+            open(self.headers_filename, 'wb').close()
             prev_hash = None
             height = -1
 
         if height < db_height:
-            print_log( "catching up missing headers:", height, db_height)
+            print_log("catching up missing headers:", height, db_height)
 
         try:
-            while height != db_height:
+            while height < db_height:
                 height = height + 1
                 header = self.get_header(height)
-                if height>1: 
+                if height > 1:
                     assert prev_hash == header.get('prev_block_hash')
                 self.write_header(header, sync=False)
                 prev_hash = self.hash_header(header)
-                if height%1000==0: print_log("headers file:",height)
+                if (height % 1000) == 0:
+                    print_log("headers file:", height)
         except KeyboardInterrupt:
             self.flush_headers()
             sys.exit()
 
         self.flush_headers()
 
-
     def hash_header(self, header):
         return rev_hex(Hash(header_to_string(header).decode('hex')).encode('hex'))
 
-
     def read_header(self, block_height):
         if os.path.exists(self.headers_filename):
-            f = open(self.headers_filename,'rb')
-            f.seek(block_height*80)
-            h = f.read(80)
-            f.close()
+            with open(self.headers_filename, 'rb') as f:
+                f.seek(block_height * 80)
+                h = f.read(80)
             if len(h) == 80:
                 h = header_from_string(h)
                 return h
 
-
     def read_chunk(self, index):
-        f = open(self.headers_filename,'rb')
-        f.seek(index*2016*80)
-        chunk = f.read(2016*80)
-        f.close()
+        with open(self.headers_filename, 'rb') as f:
+            f.seek(index*2016*80)
+            chunk = f.read(2016*80)
         return chunk.encode('hex')
 
-
     def write_header(self, header, sync=True):
         if not self.headers_data:
             self.headers_offset = header.get('block_height')
@@ -219,78 +196,97 @@ class BlockchainProcessor(Processor):
         if sync or len(self.headers_data) > 40*100:
             self.flush_headers()
 
+        with self.cache_lock:
+            chunk_index = header.get('block_height')/2016
+            if self.chunk_cache.get(chunk_index):
+                self.chunk_cache.pop(chunk_index)
+
     def pop_header(self):
         # we need to do this only if we have not flushed
         if self.headers_data:
             self.headers_data = self.headers_data[:-40]
 
     def flush_headers(self):
-        if not self.headers_data: return
-        f = open(self.headers_filename,'rb+')
-        f.seek(self.headers_offset*80)
-        f.write(self.headers_data)
-        f.close()
+        if not self.headers_data:
+            return
+        with open(self.headers_filename, 'rb+') as f:
+            f.seek(self.headers_offset*80)
+            f.write(self.headers_data)
         self.headers_data = ''
 
-
     def get_chunk(self, i):
         # store them on disk; store the current chunk in memory
-        chunk = self.chunk_cache.get(i)
-        if not chunk:
-            chunk = self.read_chunk(i)
-            self.chunk_cache[i] = chunk
+        with self.cache_lock:
+            chunk = self.chunk_cache.get(i)
+            if not chunk:
+                chunk = self.read_chunk(i)
+                self.chunk_cache[i] = chunk
+
         return chunk
 
+    def get_mempool_transaction(self, txid):
+        try:
+            raw_tx = self.bitcoind('getrawtransaction', [txid, 0])
+        except:
+            return None
 
-    def get_transaction(self, txid, block_height=-1, is_coinbase = False):
-        raw_tx = self.bitcoind('getrawtransaction', [txid, 0, block_height])
         vds = deserialize.BCDataStream()
         vds.write(raw_tx.decode('hex'))
-        out = deserialize.parse_Transaction(vds, is_coinbase)
-        return out
+        try:
+            return deserialize.parse_Transaction(vds, is_coinbase=False)
+        except:
+            print_log("ERROR: cannot parse", txid)
+            return None
 
 
     def get_history(self, addr, cache_only=False):
-        with self.cache_lock: hist = self.history_cache.get( addr )
-        if hist is not None: return hist
-        if cache_only: return -1
+        with self.cache_lock:
+            hist = self.history_cache.get(addr)
+        if hist is not None:
+            return hist
+        if cache_only:
+            return -1
 
         with self.dblock:
             try:
-                hist = self.deserialize(self.db.Get(addr))
+                hist = self.storage.get_history(addr)
                 is_known = True
-            except: 
+            except:
+                self.shared.stop()
+                raise
+            if hist:
+                is_known = True
+            else:
                 hist = []
                 is_known = False
 
-        # should not be necessary
-        hist.sort( key=lambda tup: tup[1])
-        # check uniqueness too...
-
         # add memory pool
         with self.mempool_lock:
-            for txid in self.mempool_hist.get(addr,[]):
-                hist.append((txid, 0, 0))
+            for txid in self.mempool_hist.get(addr, []):
+                hist.append({'tx_hash':txid, 'height':0})
 
-        hist = map(lambda x: {'tx_hash':x[0], 'height':x[2]}, hist)
         # add something to distinguish between unused and empty addresses
-        if hist == [] and is_known: hist = ['*']
+        if hist == [] and is_known:
+            hist = ['*']
 
-        with self.cache_lock: self.history_cache[addr] = hist
+        with self.cache_lock:
+            self.history_cache[addr] = hist
         return hist
 
 
     def get_status(self, addr, cache_only=False):
         tx_points = self.get_history(addr, cache_only)
-        if cache_only and tx_points == -1: return -1
+        if cache_only and tx_points == -1:
+            return -1
 
-        if not tx_points: return None
-        if tx_points == ['*']: return '*'
+        if not tx_points:
+            return None
+        if tx_points == ['*']:
+            return '*'
         status = ''
         for tx in tx_points:
             status += tx.get('tx_hash') + ':%d:' % tx.get('height')
-        return hashlib.sha256( status ).digest().encode('hex')
-
+        return hashlib.sha256(status).digest().encode('hex')
 
     def get_merkle(self, tx_hash, height):
 
@@ -298,59 +294,55 @@ class BlockchainProcessor(Processor):
         b = self.bitcoind('getblock', [block_hash])
         tx_list = b.get('tx')
         tx_pos = tx_list.index(tx_hash)
-        
+
         merkle = map(hash_decode, tx_list)
         target_hash = hash_decode(tx_hash)
         s = []
         while len(merkle) != 1:
-            if len(merkle)%2: merkle.append( merkle[-1] )
+            if len(merkle) % 2:
+                merkle.append(merkle[-1])
             n = []
             while merkle:
-                new_hash = Hash( merkle[0] + merkle[1] )
+                new_hash = Hash(merkle[0] + merkle[1])
                 if merkle[0] == target_hash:
-                    s.append( hash_encode( merkle[1]))
+                    s.append(hash_encode(merkle[1]))
                     target_hash = new_hash
                 elif merkle[1] == target_hash:
-                    s.append( hash_encode( merkle[0]))
+                    s.append(hash_encode(merkle[0]))
                     target_hash = new_hash
-                n.append( new_hash )
+                n.append(new_hash)
                 merkle = merkle[2:]
             merkle = n
 
-        return {"block_height":height, "merkle":s, "pos":tx_pos}
+        return {"block_height": height, "merkle": s, "pos": tx_pos}
 
-        
-    def add_to_batch(self, addr, tx_hash, tx_pos, tx_height):
 
-        # we do it chronologically, so nothing wrong can happen...
-        s = (tx_hash + int_to_hex(tx_pos, 4) + int_to_hex(tx_height, 4)).decode('hex')
-        self.batch_list[addr] += s
+    def add_to_history(self, addr, tx_hash, tx_pos, tx_height):
+        # keep it sorted
+        s = self.serialize_item(tx_hash, tx_pos, tx_height) + 40*chr(0)
+        assert len(s) == 80
+
+        serialized_hist = self.batch_list[addr]
+
+        l = len(serialized_hist)/80
+        for i in range(l-1, -1, -1):
+            item = serialized_hist[80*i:80*(i+1)]
+            item_height = int(rev_hex(item[36:39].encode('hex')), 16)
+            if item_height <= tx_height:
+                serialized_hist = serialized_hist[0:80*(i+1)] + s + serialized_hist[80*(i+1):]
+                break
+        else:
+            serialized_hist = s + serialized_hist
+
+        self.batch_list[addr] = serialized_hist
 
         # backlink
         txo = (tx_hash + int_to_hex(tx_pos, 4)).decode('hex')
         self.batch_txio[txo] = addr
 
 
-    def remove_from_batch(self, tx_hash, tx_pos):
-                    
-        txi = (tx_hash + int_to_hex(tx_pos, 4)).decode('hex')
-        try:
-            addr = self.batch_txio[txi]
-        except:
-            #raise BaseException(tx_hash, tx_pos)
-            print "WARNING: cannot find address for", (tx_hash, tx_pos)
-            return
 
-        serialized_hist = self.batch_list[addr]
 
-        l = len(serialized_hist)/40
-        for i in range(l):
-            if serialized_hist[40*i:40*i+36] == txi:
-                serialized_hist = serialized_hist[0:40*i] + serialized_hist[40*(i+1):]
-                break
-        else:
-            raise BaseException("prevout not found", addr, hist, tx_hash, tx_pos)
-        self.batch_list[addr] = serialized_hist
 
 
     def deserialize_block(self, block):
@@ -360,182 +352,200 @@ class BlockchainProcessor(Processor):
         is_coinbase = True
         for raw_tx in txlist:
             tx_hash = hash_encode(Hash(raw_tx.decode('hex')))
-            tx_hashes.append(tx_hash)
             vds = deserialize.BCDataStream()
             vds.write(raw_tx.decode('hex'))
-            tx = deserialize.parse_Transaction(vds, is_coinbase)
+            try:
+                tx = deserialize.parse_Transaction(vds, is_coinbase)
+            except:
+                print_log("ERROR: cannot parse", tx_hash)
+                continue
+            tx_hashes.append(tx_hash)
             txdict[tx_hash] = tx
             is_coinbase = False
         return tx_hashes, txdict
 
 
-    def import_block(self, block, block_hash, block_height, sync, revert=False):
 
-        self.batch_list = {}  # address -> history
-        self.batch_txio = {}  # transaction i/o -> address
+    def import_block(self, block, block_hash, block_height, sync, revert=False):
 
-        inputs_to_read = []
-        addr_to_read = []
+        touched_addr = set([])
 
         # deserialize transactions
-        t0 = time.time()
         tx_hashes, txdict = self.deserialize_block(block)
 
-        # read addresses of tx inputs
-        t00 = time.time()
-        for tx in txdict.values():
-            for x in tx.get('inputs'):
-                txi = (x.get('prevout_hash') + int_to_hex(x.get('prevout_n'), 4)).decode('hex')
-                inputs_to_read.append(txi)
-
-        inputs_to_read.sort()
-        for txi in inputs_to_read:
-            try:
-                addr = self.db.Get(txi)    
-            except:
-                # the input could come from the same block
-                continue
-            self.batch_txio[txi] = addr
-            addr_to_read.append(addr)
-
-        # read histories of addresses
-        for txid, tx in txdict.items():
-            for x in tx.get('outputs'):
-                addr_to_read.append(x.get('address'))
+        # undo info
+        if revert:
+            undo_info = self.storage.get_undo_info(block_height)
+            tx_hashes.reverse()
+        else:
+            undo_info = {}
 
-        addr_to_read.sort()
-        for addr in addr_to_read:
-            try:
-                self.batch_list[addr] = self.db.Get(addr)
-            except: 
-                self.batch_list[addr] = ''
-              
-        # process
-        t1 = time.time()
-
-        for txid in tx_hashes: # must be ordered
+        for txid in tx_hashes:  # must be ordered
             tx = txdict[txid]
             if not revert:
-                for x in tx.get('inputs'):
-                    self.remove_from_batch( x.get('prevout_hash'), x.get('prevout_n'))
-                for x in tx.get('outputs'):
-                    self.add_to_batch( x.get('address'), txid, x.get('index'), block_height)
+                undo = self.storage.import_transaction(txid, tx, block_height, touched_addr)
+                undo_info[txid] = undo
             else:
-                for x in tx.get('outputs'):
-                    self.remove_from_batch( x.get('prevout_hash'), x.get('prevout_n'))
-                for x in tx.get('inputs'):
-                    self.add_to_batch( x.get('address'), txid, x.get('index'), block_height)
-
-        # write
-        max_len = 0
-        max_addr = ''
-        t2 = time.time()
-
-        batch = leveldb.WriteBatch()
-        for addr, serialized_hist in self.batch_list.items():
-            batch.Put(addr, serialized_hist)
-            l = len(serialized_hist)
-            if l > max_len:
-                max_len = l
-                max_addr = addr
-
-        for txio, addr in self.batch_txio.items():
-            batch.Put(txio, addr)
-        # delete spent inputs
-        for txi in inputs_to_read:
-            batch.Delete(txi)
-        batch.Put('0', self.serialize( [(block_hash, block_height, 0)] ) )
-
-        # actual write
-        self.db.Write(batch, sync = sync)
-
-        t3 = time.time()
-        if t3 - t0 > 10 and not sync: 
-            print_log("block", block_height, 
-                      "parse:%0.2f "%(t00 - t0), 
-                      "read:%0.2f "%(t1 - t00), 
-                      "proc:%.2f "%(t2-t1), 
-                      "write:%.2f "%(t3-t2), 
-                      "max:", max_len, max_addr)
-
-        for addr in self.batch_list.keys(): self.invalidate_cache(addr)
-
-
-
-    def add_request(self, request):
+                undo = undo_info.pop(txid)
+                self.storage.revert_transaction(txid, tx, block_height, touched_addr, undo)
+
+        if revert: 
+            assert undo_info == {}
+
+        # add undo info
+        if not revert:
+            self.storage.write_undo_info(block_height, self.bitcoind_height, undo_info)
+
+        # add the max
+        self.storage.db_undo.put('height', repr( (block_hash, block_height, self.storage.db_version) ))
+
+        for addr in touched_addr:
+            self.invalidate_cache(addr)
+
+        self.storage.update_hashes()
+
+
+    def add_request(self, session, request):
         # see if we can get if from cache. if not, add to queue
-        if self.process( request, cache_only = True) == -1:
-            self.queue.put(request)
+        if self.process(session, request, cache_only=True) == -1:
+            self.queue.put((session, request))
 
 
+    def do_subscribe(self, method, params, session):
+        with self.watch_lock:
+            if method == 'blockchain.numblocks.subscribe':
+                if session not in self.watch_blocks:
+                    self.watch_blocks.append(session)
 
-    def process(self, request, cache_only = False):
-        #print "abe process", request
+            elif method == 'blockchain.headers.subscribe':
+                if session not in self.watch_headers:
+                    self.watch_headers.append(session)
 
+            elif method == 'blockchain.address.subscribe':
+                address = params[0]
+                l = self.watched_addresses.get(address)
+                if l is None:
+                    self.watched_addresses[address] = [session]
+                elif session not in l:
+                    l.append(session)
+
+
+    def do_unsubscribe(self, method, params, session):
+        with self.watch_lock:
+            if method == 'blockchain.numblocks.subscribe':
+                if session in self.watch_blocks:
+                    self.watch_blocks.remove(session)
+            elif method == 'blockchain.headers.subscribe':
+                if session in self.watch_headers:
+                    self.watch_headers.remove(session)
+            elif method == "blockchain.address.subscribe":
+                addr = params[0]
+                l = self.watched_addresses.get(addr)
+                if not l:
+                    return
+                if session in l:
+                    l.remove(session)
+                if session in l:
+                    print "error rc!!"
+                    self.shared.stop()
+                if l == []:
+                    self.watched_addresses.pop(addr)
+
+
+    def process(self, session, request, cache_only=False):
+        
         message_id = request['id']
         method = request['method']
-        params = request.get('params',[])
+        params = request.get('params', [])
         result = None
         error = None
 
         if method == 'blockchain.numblocks.subscribe':
-            result = self.height
+            result = self.storage.height
 
         elif method == 'blockchain.headers.subscribe':
             result = self.header
 
         elif method == 'blockchain.address.subscribe':
             try:
-                address = params[0]
+                address = str(params[0])
                 result = self.get_status(address, cache_only)
-                self.watch_address(address)
             except BaseException, e:
                 error = str(e) + ': ' + address
-                print_log( "error:", error )
+                print_log("error:", error)
 
-        elif method == 'blockchain.address.subscribe2':
+        elif method == 'blockchain.address.get_history':
             try:
-                address = params[0]
-                result = self.get_status(address, cache_only)
-                self.watch_address(address)
+                address = str(params[0])
+                result = self.get_history(address, cache_only)
             except BaseException, e:
                 error = str(e) + ': ' + address
-                print_log( "error:", error )
+                print_log("error:", error)
 
-        elif method == 'blockchain.address.get_history2':
+        elif method == 'blockchain.address.get_balance':
             try:
-                address = params[0]
-                result = self.get_history( address, cache_only )
+                address = str(params[0])
+                result = self.storage.get_balance(address)
+            except BaseException, e:
+                error = str(e) + ': ' + address
+                print_log("error:", error)
+
+        elif method == 'blockchain.address.get_proof':
+            try:
+                address = str(params[0])
+                result = self.storage.get_proof(address)
             except BaseException, e:
                 error = str(e) + ': ' + address
-                print_log( "error:", error )
+                print_log("error:", error)
+
+        elif method == 'blockchain.address.listunspent':
+            try:
+                address = str(params[0])
+                result = self.storage.listunspent(address)
+            except BaseException, e:
+                error = str(e) + ': ' + address
+                print_log("error:", error)
+
+        elif method == 'blockchain.utxo.get_address':
+            try:
+                txid = str(params[0])
+                pos = int(params[1])
+                txi = (txid + int_to_hex(pos, 4)).decode('hex')
+                result = self.storage.get_address(txi)
+            except BaseException, e:
+                error = str(e)
+                print_log("error:", error, txid, pos)
 
         elif method == 'blockchain.block.get_header':
-            if cache_only: 
+            if cache_only:
                 result = -1
             else:
                 try:
-                    height = params[0]
-                    result = self.get_header( height ) 
+                    height = int(params[0])
+                    result = self.get_header(height)
                 except BaseException, e:
-                    error = str(e) + ': %d'% height
-                    print_log( "error:", error )
-                    
+                    error = str(e) + ': %d' % height
+                    print_log("error:", error)
+
         elif method == 'blockchain.block.get_chunk':
             if cache_only:
                 result = -1
             else:
                 try:
-                    index = params[0]
-                    result = self.get_chunk( index ) 
+                    index = int(params[0])
+                    result = self.get_chunk(index)
                 except BaseException, e:
-                    error = str(e) + ': %d'% index
-                    print_log( "error:", error)
+                    error = str(e) + ': %d' % index
+                    print_log("error:", error)
 
         elif method == 'blockchain.transaction.broadcast':
-            txo = self.bitcoind('sendrawtransaction', params)
-            print_log( "sent tx:", txo )
-            result = txo 
+            try:
+                txo = self.bitcoind('sendrawtransaction', params)
+                print_log("sent tx:", txo)
+                result = txo
+            except BaseException, e:
+                result = str(e)  # do not send an error
+                print_log("error:", result, params)
 
         elif method == 'blockchain.transaction.get_merkle':
             if cache_only:
@@ -544,126 +554,159 @@ class BlockchainProcessor(Processor):
                 try:
                     tx_hash = params[0]
                     tx_height = params[1]
-                    result = self.get_merkle(tx_hash, tx_height) 
+                    result = self.get_merkle(tx_hash, tx_height)
                 except BaseException, e:
-                    error = str(e) + ': ' + tx_hash
-                    print_log( "error:", error )
-                    
+                    error = str(e) + ': ' + repr(params)
+                    print_log("get_merkle error:", error)
+
         elif method == 'blockchain.transaction.get':
             try:
                 tx_hash = params[0]
-                height = params[1]
-                result = self.bitcoind('getrawtransaction', [tx_hash, 0, height] ) 
+                result = self.bitcoind('getrawtransaction', [tx_hash, 0])
             except BaseException, e:
-                error = str(e) + ': ' + tx_hash
-                print_log( "error:", error )
+                error = str(e) + ': ' + repr(params)
+                print_log("tx get error:", error)
 
         else:
-            error = "unknown method:%s"%method
+            error = "unknown method:%s" % method
 
-        if cache_only and result == -1: return -1
+        if cache_only and result == -1:
+            return -1
 
         if error:
-            response = { 'id':message_id, 'error':error }
-            self.push_response(response)
+            self.push_response(session, {'id': message_id, 'error': error})
         elif result != '':
-            response = { 'id':message_id, 'result':result }
-            self.push_response(response)
-
-
-    def watch_address(self, addr):
-        if addr not in self.watched_addresses:
-            self.watched_addresses.append(addr)
-
+            self.push_response(session, {'id': message_id, 'result': result})
 
 
-    def catch_up(self, sync = True):
-        #        
-        #                     -------> F ------> G -------> H
-        #                    /
-        #                   /
-        #        A ------> B --------> C ------> E
-        #        
-        #        we always compare the hash in the headers file to the hash returned by bitcoind
+    def getfullblock(self, block_hash):
+        block = self.bitcoind('getblock', [block_hash])
 
+        rawtxreq = []
+        i = 0
+        for txid in block['tx']:
+            rawtxreq.append({
+                "method": "getrawtransaction",
+                "params": [txid],
+                "id": i,
+            })
+            i += 1
 
-        t1 = time.time()
+        postdata = dumps(rawtxreq)
+        try:
+            respdata = urllib.urlopen(self.bitcoind_url, postdata).read()
+        except:
+            traceback.print_exc(file=sys.stdout)
+            self.shared.stop()
 
+        r = loads(respdata)
+        rawtxdata = []
+        for ir in r:
+            if ir['error'] is not None:
+                self.shared.stop()
+                print_log("Error: make sure you run bitcoind with txindex=1; use -reindex if needed.")
+                raise BaseException(ir['error'])
+            rawtxdata.append(ir['result'])
+        block['tx'] = rawtxdata
+        return block
+
+    def catch_up(self, sync=True):
+
+        prev_root_hash = None
         while not self.shared.stopped():
 
+            self.mtime('')
+
             # are we done yet?
             info = self.bitcoind('getinfo')
-            bitcoind_height = info.get('blocks')
-            bitcoind_block_hash = self.bitcoind('getblockhash', [bitcoind_height])
-            if self.last_hash == bitcoind_block_hash: 
+            self.bitcoind_height = info.get('blocks')
+            bitcoind_block_hash = self.bitcoind('getblockhash', [self.bitcoind_height])
+            if self.storage.last_hash == bitcoind_block_hash:
                 self.up_to_date = True
                 break
 
             # not done..
             self.up_to_date = False
-            next_block_hash = self.bitcoind('getblockhash', [self.height+1])
-            next_block = self.bitcoind('getblock', [next_block_hash, 1])
+            next_block_hash = self.bitcoind('getblockhash', [self.storage.height + 1])
+            next_block = self.getfullblock(next_block_hash)
+            self.mtime('daemon')
+
+            # fixme: this is unsafe, if we revert when the undo info is not yet written
+            revert = (random.randint(1, 100) == 1) if self.test_reorgs else False
+
+            if (next_block.get('previousblockhash') == self.storage.last_hash) and not revert:
 
-            if next_block.get('previousblockhash') == self.last_hash:
+                prev_root_hash = self.storage.get_root_hash()
 
-                self.import_block(next_block, next_block_hash, self.height+1, sync)
-                self.height = self.height + 1
+                self.import_block(next_block, next_block_hash, self.storage.height+1, sync)
+                self.storage.height = self.storage.height + 1
                 self.write_header(self.block2header(next_block), sync)
-                self.last_hash = next_block_hash
+                self.storage.last_hash = next_block_hash
+                self.mtime('import')
+            
+                if self.storage.height % 1000 == 0 and not sync:
+                    t_daemon = self.mtimes.get('daemon')
+                    t_import = self.mtimes.get('import')
+                    print_log("catch_up: block %d (%.3fs %.3fs)" % (self.storage.height, t_daemon, t_import), self.storage.get_root_hash().encode('hex'))
+                    self.mtimes['daemon'] = 0
+                    self.mtimes['import'] = 0
 
-                if (self.height+1)%100 == 0 and not sync: 
-                    t2 = time.time()
-                    print_log( "catch_up: block %d (%.3fs)"%( self.height, t2 - t1 ) )
-                    t1 = t2
-                    
             else:
+
                 # revert current block
-                block = self.bitcoind('getblock', [self.last_hash, 1])
-                print_log( "bc2: reorg", self.height, block.get('previousblockhash'), self.last_hash )
-                self.import_block(block, self.last_hash, self.height, revert=True)
+                block = self.getfullblock(self.storage.last_hash)
+                print_log("blockchain reorg", self.storage.height, block.get('previousblockhash'), self.storage.last_hash)
+                self.import_block(block, self.storage.last_hash, self.storage.height, sync, revert=True)
                 self.pop_header()
+                self.flush_headers()
 
-                self.height = self.height -1
+                self.storage.height -= 1
 
                 # read previous header from disk
-                self.header = self.read_header(self.height) 
-                self.last_hash = self.hash_header(self.header)
-        
+                self.header = self.read_header(self.storage.height)
+                self.storage.last_hash = self.hash_header(self.header)
 
-        self.header = self.block2header(self.bitcoind('getblock', [self.last_hash]))
+                if prev_root_hash:
+                    assert prev_root_hash == self.storage.get_root_hash()
+                    prev_root_hash = None
 
 
+        self.header = self.block2header(self.bitcoind('getblock', [self.storage.last_hash]))
+        self.header['utxo_root'] = self.storage.get_root_hash().encode('hex')
+
+        if self.shared.stopped(): 
+            print_log( "closing database" )
+            self.storage.close()
 
-            
-    def memorypool_update(self):
 
-        mempool_hashes = self.bitcoind('getrawmempool')
+    def memorypool_update(self):
+        mempool_hashes = set(self.bitcoind('getrawmempool'))
+        touched_addresses = set([])
 
         for tx_hash in mempool_hashes:
-            if tx_hash in self.mempool_hashes: continue
+            if tx_hash in self.mempool_hashes:
+                continue
 
-            tx = self.get_transaction(tx_hash)
-            if not tx: continue
+            tx = self.get_mempool_transaction(tx_hash)
+            if not tx:
+                continue
 
+            mpa = self.mempool_addresses.get(tx_hash, [])
             for x in tx.get('inputs'):
-                txi = (x.get('prevout_hash') + int_to_hex(x.get('prevout_n'), 4)).decode('hex')
-                try:
-                    addr = self.db.Get(txi)    
-                except:
-                    continue
-                l = self.mempool_addresses.get(tx_hash, [])
-                if addr not in l: 
-                    l.append( addr )
-                    self.mempool_addresses[tx_hash] = l
+                # we assume that the input address can be parsed by deserialize(); this is true for Electrum transactions
+                addr = x.get('address')
+                if addr and addr not in mpa:
+                    mpa.append(addr)
+                    touched_addresses.add(addr)
 
             for x in tx.get('outputs'):
                 addr = x.get('address')
-                l = self.mempool_addresses.get(tx_hash, [])
-                if addr not in l: 
-                    l.append( addr )
-                    self.mempool_addresses[tx_hash] = l
+                if addr and addr not in mpa:
+                    mpa.append(addr)
+                    touched_addresses.add(addr)
 
-            self.mempool_hashes.append(tx_hash)
+            self.mempool_addresses[tx_hash] = mpa
+            self.mempool_hashes.add(tx_hash)
 
         # remove older entries from mempool_hashes
         self.mempool_hashes = mempool_hashes
@@ -672,43 +715,43 @@ class BlockchainProcessor(Processor):
         for tx_hash, addresses in self.mempool_addresses.items():
             if tx_hash not in self.mempool_hashes:
                 self.mempool_addresses.pop(tx_hash)
+                for addr in addresses:
+                    touched_addresses.add(addr)
 
-        # rebuild histories
+        # rebuild mempool histories
         new_mempool_hist = {}
         for tx_hash, addresses in self.mempool_addresses.items():
             for addr in addresses:
                 h = new_mempool_hist.get(addr, [])
-                if tx_hash not in h: 
-                    h.append( tx_hash )
+                if tx_hash not in h:
+                    h.append(tx_hash)
                 new_mempool_hist[addr] = h
 
-        for addr in new_mempool_hist.keys():
-            if addr in self.mempool_hist.keys():
-                if self.mempool_hist[addr] != new_mempool_hist[addr]: 
-                    self.invalidate_cache(addr)
-            else:
-                self.invalidate_cache(addr)
-
         with self.mempool_lock:
             self.mempool_hist = new_mempool_hist
 
+        # invalidate cache for touched addresses
+        for addr in touched_addresses:
+            self.invalidate_cache(addr)
 
 
     def invalidate_cache(self, address):
         with self.cache_lock:
-            if self.history_cache.has_key(address):
-                print_log( "cache: invalidating", address )
+            if address in self.history_cache:
+                print_log("cache: invalidating", address)
                 self.history_cache.pop(address)
 
-        if address in self.watched_addresses:
-            self.address_queue.put(address)
-
+        with self.watch_lock:
+            sessions = self.watched_addresses.get(address)
 
+        if sessions:
+            # TODO: update cache here. if new value equals cached value, do not send notification
+            self.address_queue.put((address,sessions))
 
     def main_iteration(self):
-
-        if self.shared.stopped(): 
-            print_log( "blockchain processor terminating" )
+        if self.shared.stopped():
+            print_log("blockchain processor terminating")
+            self.storage.close()
             return
 
         with self.dblock:
@@ -717,35 +760,41 @@ class BlockchainProcessor(Processor):
             t2 = time.time()
 
         self.memorypool_update()
-        t3 = time.time()
-        # print "mempool:", len(self.mempool_addresses), len(self.mempool_hist), "%.3fs"%(t3 - t2)
 
-
-        if self.sent_height != self.height:
-            self.sent_height = self.height
-            self.push_response({ 'id': None, 'method':'blockchain.numblocks.subscribe', 'params':[self.height] })
+        if self.sent_height != self.storage.height:
+            self.sent_height = self.storage.height
+            for session in self.watch_blocks:
+                self.push_response(session, {
+                        'id': None,
+                        'method': 'blockchain.numblocks.subscribe',
+                        'params': [self.storage.height],
+                        })
 
         if self.sent_header != self.header:
-            print_log( "blockchain: %d (%.3fs)"%( self.height, t2 - t1 ) )
+            print_log("blockchain: %d (%.3fs)" % (self.storage.height, t2 - t1))
             self.sent_header = self.header
-            self.push_response({ 'id': None, 'method':'blockchain.headers.subscribe', 'params':[self.header] })
+            for session in self.watch_headers:
+                self.push_response(session, {
+                        'id': None,
+                        'method': 'blockchain.headers.subscribe',
+                        'params': [self.header],
+                        })
 
         while True:
             try:
-                addr = self.address_queue.get(False)
+                addr, sessions = self.address_queue.get(False)
             except:
                 break
-            if addr in self.watched_addresses:
-                status = self.get_status( addr )
-                self.push_response({ 'id': None, 'method':'blockchain.address.subscribe', 'params':[addr, status] })
-                self.push_response({ 'id': None, 'method':'blockchain.address.subscribe2', 'params':[addr, status] })
 
+            status = self.get_status(addr)
+            for session in sessions:
+                self.push_response(session, {
+                        'id': None,
+                        'method': 'blockchain.address.subscribe',
+                        'params': [addr, status],
+                        })
 
-        if not self.shared.stopped(): 
+        if not self.shared.stopped():
             threading.Timer(10, self.main_iteration).start()
         else:
-            print_log( "blockchain processor terminating" )
-
-
-
-
+            print_log("blockchain processor terminating")