2014-01-01 17:16:15 +01:00
|
|
|
// Copyright (c) 2013-2014 Conformal Systems LLC.
|
2013-12-31 20:15:44 +01:00
|
|
|
// Use of this source code is governed by an ISC
|
|
|
|
// license that can be found in the LICENSE file.
|
|
|
|
|
|
|
|
package main
|
|
|
|
|
|
|
|
import (
|
|
|
|
"bytes"
|
|
|
|
"container/list"
|
2014-01-22 21:10:04 +01:00
|
|
|
"crypto/subtle"
|
|
|
|
"encoding/base64"
|
2014-01-08 17:40:27 +01:00
|
|
|
"encoding/hex"
|
2013-12-31 20:15:44 +01:00
|
|
|
"encoding/json"
|
2014-02-24 15:10:59 +01:00
|
|
|
"errors"
|
2013-12-31 20:15:44 +01:00
|
|
|
"fmt"
|
2014-07-02 15:50:08 +02:00
|
|
|
"io"
|
|
|
|
"sync"
|
|
|
|
"time"
|
|
|
|
|
|
|
|
"code.google.com/p/go.crypto/ripemd160"
|
2013-12-31 20:15:44 +01:00
|
|
|
"github.com/conformal/btcjson"
|
|
|
|
"github.com/conformal/btcscript"
|
|
|
|
"github.com/conformal/btcutil"
|
|
|
|
"github.com/conformal/btcwire"
|
|
|
|
"github.com/conformal/btcws"
|
2014-05-01 17:36:41 +02:00
|
|
|
"github.com/conformal/fastsha256"
|
2014-06-07 07:35:34 +02:00
|
|
|
"github.com/conformal/websocket"
|
2013-12-31 20:15:44 +01:00
|
|
|
)
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
const (
|
|
|
|
// websocketSendBufferSize is the number of elements the send channel
|
|
|
|
// can queue before blocking. Note that this only applies to requests
|
|
|
|
// handled directly in the websocket client input handler or the async
|
|
|
|
// handler since notifications have their own queueing mechanism
|
|
|
|
// independent of the send channel buffer.
|
|
|
|
websocketSendBufferSize = 50
|
|
|
|
)
|
2014-01-08 17:40:27 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// timeZeroVal is simply the zero value for a time.Time and is used to avoid
|
|
|
|
// creating multiple instances.
|
|
|
|
var timeZeroVal time.Time
|
2014-01-14 21:59:31 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// wsCommandHandler describes a callback function used to handle a specific
|
|
|
|
// command.
|
|
|
|
type wsCommandHandler func(*wsClient, btcjson.Cmd) (interface{}, *btcjson.Error)
|
2013-12-31 21:48:50 +01:00
|
|
|
|
|
|
|
// wsHandlers maps RPC command strings to appropriate websocket handler
|
|
|
|
// functions.
|
|
|
|
var wsHandlers = map[string]wsCommandHandler{
|
2014-04-15 07:29:49 +02:00
|
|
|
"notifyblocks": handleNotifyBlocks,
|
|
|
|
"notifynewtransactions": handleNotifyNewTransactions,
|
|
|
|
"notifyreceived": handleNotifyReceived,
|
|
|
|
"notifyspent": handleNotifySpent,
|
|
|
|
"rescan": handleRescan,
|
2013-12-31 21:48:50 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// wsAsyncHandlers holds the websocket commands which should be run
|
|
|
|
// asynchronously to the main input handler goroutine. This allows long-running
|
|
|
|
// operations to run concurrently (and one at a time) while still responding
|
|
|
|
// to the majority of normal requests which can be answered quickly.
|
2014-07-02 16:45:17 +02:00
|
|
|
var wsAsyncHandlers = map[string]struct{}{
|
|
|
|
"rescan": struct{}{},
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// WebsocketHandler handles a new websocket client by creating a new wsClient,
|
|
|
|
// starting it, and blocking until the connection closes. Since it blocks, it
|
|
|
|
// must be run in a separate goroutine. It should be invoked from the websocket
|
|
|
|
// server handler which runs each new connection in a new goroutine thereby
|
|
|
|
// satisfying the requirement.
|
|
|
|
func (s *rpcServer) WebsocketHandler(conn *websocket.Conn, remoteAddr string,
|
|
|
|
authenticated bool) {
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Clear the read deadline that was set before the websocket hijacked
|
|
|
|
// the connection.
|
|
|
|
conn.SetReadDeadline(timeZeroVal)
|
|
|
|
|
|
|
|
// Limit max number of websocket clients.
|
|
|
|
rpcsLog.Infof("New websocket client %s", remoteAddr)
|
2014-02-19 04:05:42 +01:00
|
|
|
if s.ntfnMgr.NumClients()+1 > cfg.RPCMaxWebsockets {
|
2014-02-19 00:23:33 +01:00
|
|
|
rpcsLog.Infof("Max websocket clients exceeded [%d] - "+
|
2014-02-19 04:05:42 +01:00
|
|
|
"disconnecting client %s", cfg.RPCMaxWebsockets,
|
2014-02-19 00:23:33 +01:00
|
|
|
remoteAddr)
|
|
|
|
conn.Close()
|
|
|
|
return
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Create a new websocket client to handle the new websocket connection
|
|
|
|
// and wait for it to shutdown. Once it has shutdown (and hence
|
|
|
|
// disconnected), remove it and any notifications it registered for.
|
|
|
|
client := newWebsocketClient(s, conn, remoteAddr, authenticated)
|
|
|
|
s.ntfnMgr.AddClient(client)
|
|
|
|
client.Start()
|
|
|
|
client.WaitForShutdown()
|
|
|
|
s.ntfnMgr.RemoveClient(client)
|
|
|
|
rpcsLog.Infof("Disconnected websocket client %s", remoteAddr)
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// wsNotificationManager is a connection and notification manager used for
|
|
|
|
// websockets. It allows websocket clients to register for notifications they
|
|
|
|
// are interested in. When an event happens elsewhere in the code such as
|
|
|
|
// transactions being added to the memory pool or block connects/disconnects,
|
|
|
|
// the notification manager is provided with the relevant details needed to
|
|
|
|
// figure out which websocket clients need to be notified based on what they
|
|
|
|
// have registered for and notifies them accordingly. It is also used to keep
|
|
|
|
// track of all connected websocket clients.
|
|
|
|
type wsNotificationManager struct {
|
|
|
|
// server is the RPC server the notification manager is associated with.
|
|
|
|
server *rpcServer
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// queueNotification queues a notification for handling.
|
|
|
|
queueNotification chan interface{}
|
|
|
|
|
|
|
|
// notificationMsgs feeds notificationHandler with notifications
|
|
|
|
// and client (un)registeration requests from a queue as well as
|
|
|
|
// registeration and unregisteration requests from clients.
|
|
|
|
notificationMsgs chan interface{}
|
|
|
|
|
|
|
|
// Access channel for current number of connected clients.
|
|
|
|
numClients chan int
|
|
|
|
|
|
|
|
// Shutdown handling
|
|
|
|
wg sync.WaitGroup
|
|
|
|
quit chan struct{}
|
|
|
|
}
|
|
|
|
|
|
|
|
// queueHandler manages a queue of empty interfaces, reading from in and
|
|
|
|
// sending the oldest unsent to out. This handler stops when either of the
|
|
|
|
// in or quit channels are closed, and closes out before returning, without
|
|
|
|
// waiting to send any variables still remaining in the queue.
|
|
|
|
func queueHandler(in <-chan interface{}, out chan<- interface{}, quit <-chan struct{}) {
|
|
|
|
var q []interface{}
|
|
|
|
var dequeue chan<- interface{}
|
|
|
|
skipQueue := out
|
|
|
|
var next interface{}
|
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case n, ok := <-in:
|
|
|
|
if !ok {
|
|
|
|
// Sender closed input channel.
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
|
|
|
|
// Either send to out immediately if skipQueue is
|
|
|
|
// non-nil (queue is empty) and reader is ready,
|
|
|
|
// or append to the queue and send later.
|
|
|
|
select {
|
|
|
|
case skipQueue <- n:
|
|
|
|
default:
|
|
|
|
q = append(q, n)
|
|
|
|
dequeue = out
|
|
|
|
skipQueue = nil
|
|
|
|
next = q[0]
|
|
|
|
}
|
|
|
|
|
|
|
|
case dequeue <- next:
|
|
|
|
copy(q, q[1:])
|
|
|
|
q[len(q)-1] = nil // avoid leak
|
|
|
|
q = q[:len(q)-1]
|
|
|
|
if len(q) == 0 {
|
|
|
|
dequeue = nil
|
|
|
|
skipQueue = out
|
2014-07-25 15:20:58 +02:00
|
|
|
} else {
|
|
|
|
next = q[0]
|
2014-03-04 17:15:25 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
case <-quit:
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
}
|
|
|
|
close(out)
|
|
|
|
}
|
|
|
|
|
|
|
|
// queueHandler maintains a queue of notifications and notification handler
|
|
|
|
// control messages.
|
|
|
|
func (m *wsNotificationManager) queueHandler() {
|
|
|
|
queueHandler(m.queueNotification, m.notificationMsgs, m.quit)
|
|
|
|
m.wg.Done()
|
|
|
|
}
|
|
|
|
|
|
|
|
// NotifyBlockConnected passes a block newly-connected to the best chain
|
|
|
|
// to the notification manager for block and transaction notification
|
|
|
|
// processing.
|
|
|
|
func (m *wsNotificationManager) NotifyBlockConnected(block *btcutil.Block) {
|
2014-03-22 00:07:36 +01:00
|
|
|
// As NotifyBlockConnected will be called by the block manager
|
|
|
|
// and the RPC server may no longer be running, use a select
|
|
|
|
// statement to unblock enqueueing the notification once the RPC
|
|
|
|
// server has begun shutting down.
|
|
|
|
select {
|
|
|
|
case m.queueNotification <- (*notificationBlockConnected)(block):
|
|
|
|
case <-m.quit:
|
|
|
|
}
|
2014-03-04 17:15:25 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
// NotifyBlockDisconnected passes a block disconnected from the best chain
|
|
|
|
// to the notification manager for block notification processing.
|
|
|
|
func (m *wsNotificationManager) NotifyBlockDisconnected(block *btcutil.Block) {
|
2014-03-22 00:07:36 +01:00
|
|
|
// As NotifyBlockDisconnected will be called by the block manager
|
|
|
|
// and the RPC server may no longer be running, use a select
|
|
|
|
// statement to unblock enqueueing the notification once the RPC
|
|
|
|
// server has begun shutting down.
|
|
|
|
select {
|
|
|
|
case m.queueNotification <- (*notificationBlockDisconnected)(block):
|
|
|
|
case <-m.quit:
|
|
|
|
}
|
2014-03-04 17:15:25 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
// NotifyMempoolTx passes a transaction accepted by mempool to the
|
|
|
|
// notification manager for transaction notification processing. If
|
|
|
|
// isNew is true, the tx is is a new transaction, rather than one
|
|
|
|
// added to the mempool during a reorg.
|
|
|
|
func (m *wsNotificationManager) NotifyMempoolTx(tx *btcutil.Tx, isNew bool) {
|
2014-03-22 00:07:36 +01:00
|
|
|
n := ¬ificationTxAcceptedByMempool{
|
2014-03-04 17:15:25 +01:00
|
|
|
isNew: isNew,
|
|
|
|
tx: tx,
|
|
|
|
}
|
2014-03-22 00:07:36 +01:00
|
|
|
|
|
|
|
// As NotifyMempoolTx will be called by mempool and the RPC server
|
|
|
|
// may no longer be running, use a select statement to unblock
|
|
|
|
// enqueueing the notification once the RPC server has begun
|
|
|
|
// shutting down.
|
|
|
|
select {
|
|
|
|
case m.queueNotification <- n:
|
|
|
|
case <-m.quit:
|
|
|
|
}
|
2014-03-04 17:15:25 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
// Notification types
|
|
|
|
type notificationBlockConnected btcutil.Block
|
|
|
|
type notificationBlockDisconnected btcutil.Block
|
|
|
|
type notificationTxAcceptedByMempool struct {
|
|
|
|
isNew bool
|
|
|
|
tx *btcutil.Tx
|
|
|
|
}
|
|
|
|
|
|
|
|
// Notification control requests
|
|
|
|
type notificationRegisterClient wsClient
|
|
|
|
type notificationUnregisterClient wsClient
|
|
|
|
type notificationRegisterBlocks wsClient
|
|
|
|
type notificationUnregisterBlocks wsClient
|
|
|
|
type notificationRegisterNewMempoolTxs wsClient
|
|
|
|
type notificationUnregisterNewMempoolTxs wsClient
|
|
|
|
type notificationRegisterSpent struct {
|
|
|
|
wsc *wsClient
|
|
|
|
op *btcwire.OutPoint
|
|
|
|
}
|
|
|
|
type notificationUnregisterSpent struct {
|
|
|
|
wsc *wsClient
|
|
|
|
op *btcwire.OutPoint
|
|
|
|
}
|
|
|
|
type notificationRegisterAddr struct {
|
|
|
|
wsc *wsClient
|
|
|
|
addr string
|
|
|
|
}
|
|
|
|
type notificationUnregisterAddr struct {
|
|
|
|
wsc *wsClient
|
|
|
|
addr string
|
|
|
|
}
|
|
|
|
|
|
|
|
// notificationHandler reads notifications and control messages from the queue
|
|
|
|
// handler and processes one at a time.
|
|
|
|
func (m *wsNotificationManager) notificationHandler() {
|
2014-02-19 00:23:33 +01:00
|
|
|
// clients is a map of all currently connected websocket clients.
|
2014-07-02 17:31:10 +02:00
|
|
|
clients := make(map[chan struct{}]*wsClient)
|
2014-02-19 00:23:33 +01:00
|
|
|
|
|
|
|
// Maps used to hold lists of websocket clients to be notified on
|
|
|
|
// certain events. Each websocket client also keeps maps for the events
|
|
|
|
// which have multiple triggers to make removal from these lists on
|
|
|
|
// connection close less horrendously expensive.
|
2014-03-04 17:15:25 +01:00
|
|
|
//
|
|
|
|
// Where possible, the quit channel is used as the unique id for a client
|
|
|
|
// since it is quite a bit more efficient than using the entire struct.
|
2014-07-02 17:31:10 +02:00
|
|
|
blockNotifications := make(map[chan struct{}]*wsClient)
|
|
|
|
txNotifications := make(map[chan struct{}]*wsClient)
|
|
|
|
watchedOutPoints := make(map[btcwire.OutPoint]map[chan struct{}]*wsClient)
|
|
|
|
watchedAddrs := make(map[string]map[chan struct{}]*wsClient)
|
2014-03-04 17:15:25 +01:00
|
|
|
|
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case n, ok := <-m.notificationMsgs:
|
|
|
|
if !ok {
|
|
|
|
// queueHandler quit.
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
switch n := n.(type) {
|
|
|
|
case *notificationBlockConnected:
|
|
|
|
block := (*btcutil.Block)(n)
|
|
|
|
if len(blockNotifications) != 0 {
|
|
|
|
m.notifyBlockConnected(blockNotifications,
|
|
|
|
block)
|
|
|
|
}
|
|
|
|
|
|
|
|
// Skip iterating through all txs if no
|
|
|
|
// tx notification requests exist.
|
|
|
|
if len(watchedOutPoints) == 0 && len(watchedAddrs) == 0 {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, tx := range block.Transactions() {
|
|
|
|
m.notifyForTx(watchedOutPoints,
|
|
|
|
watchedAddrs, tx, block)
|
|
|
|
}
|
|
|
|
|
|
|
|
case *notificationBlockDisconnected:
|
|
|
|
m.notifyBlockDisconnected(blockNotifications,
|
|
|
|
(*btcutil.Block)(n))
|
|
|
|
|
|
|
|
case *notificationTxAcceptedByMempool:
|
|
|
|
if n.isNew && len(txNotifications) != 0 {
|
|
|
|
m.notifyForNewTx(txNotifications, n.tx)
|
|
|
|
}
|
|
|
|
m.notifyForTx(watchedOutPoints, watchedAddrs, n.tx, nil)
|
|
|
|
|
|
|
|
case *notificationRegisterBlocks:
|
|
|
|
wsc := (*wsClient)(n)
|
|
|
|
blockNotifications[wsc.quit] = wsc
|
|
|
|
|
2014-03-05 03:36:48 +01:00
|
|
|
case *notificationUnregisterBlocks:
|
|
|
|
wsc := (*wsClient)(n)
|
|
|
|
delete(blockNotifications, wsc.quit)
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
case *notificationRegisterClient:
|
|
|
|
wsc := (*wsClient)(n)
|
|
|
|
clients[wsc.quit] = wsc
|
|
|
|
|
|
|
|
case *notificationUnregisterClient:
|
|
|
|
wsc := (*wsClient)(n)
|
|
|
|
// Remove any requests made by the client as well as
|
|
|
|
// the client itself.
|
|
|
|
delete(blockNotifications, wsc.quit)
|
|
|
|
delete(txNotifications, wsc.quit)
|
|
|
|
for k := range wsc.spentRequests {
|
|
|
|
op := k
|
|
|
|
m.removeSpentRequest(watchedOutPoints, wsc, &op)
|
|
|
|
}
|
|
|
|
for addr := range wsc.addrRequests {
|
|
|
|
m.removeAddrRequest(watchedAddrs, wsc, addr)
|
|
|
|
}
|
|
|
|
delete(clients, wsc.quit)
|
|
|
|
|
|
|
|
case *notificationRegisterSpent:
|
|
|
|
m.addSpentRequest(watchedOutPoints, n.wsc, n.op)
|
|
|
|
|
|
|
|
case *notificationUnregisterSpent:
|
|
|
|
m.removeSpentRequest(watchedOutPoints, n.wsc, n.op)
|
|
|
|
|
|
|
|
case *notificationRegisterAddr:
|
|
|
|
m.addAddrRequest(watchedAddrs, n.wsc, n.addr)
|
|
|
|
|
|
|
|
case *notificationUnregisterAddr:
|
|
|
|
m.removeAddrRequest(watchedAddrs, n.wsc, n.addr)
|
|
|
|
|
2014-03-05 03:36:48 +01:00
|
|
|
case *notificationRegisterNewMempoolTxs:
|
|
|
|
wsc := (*wsClient)(n)
|
|
|
|
txNotifications[wsc.quit] = wsc
|
|
|
|
|
|
|
|
case *notificationUnregisterNewMempoolTxs:
|
|
|
|
wsc := (*wsClient)(n)
|
|
|
|
delete(txNotifications, wsc.quit)
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
default:
|
|
|
|
rpcsLog.Warn("Unhandled notification type")
|
|
|
|
}
|
|
|
|
|
|
|
|
case m.numClients <- len(clients):
|
|
|
|
|
|
|
|
case <-m.quit:
|
|
|
|
// RPC server shutting down.
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
for _, c := range clients {
|
|
|
|
c.Disconnect()
|
|
|
|
}
|
|
|
|
m.wg.Done()
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// NumClients returns the number of clients actively being served.
|
2014-03-22 00:07:36 +01:00
|
|
|
func (m *wsNotificationManager) NumClients() (n int) {
|
|
|
|
select {
|
|
|
|
case n = <-m.numClients:
|
|
|
|
case <-m.quit: // Use default n (0) if server has shut down.
|
|
|
|
}
|
|
|
|
return
|
2014-01-17 22:00:46 +01:00
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// RegisterBlockUpdates requests block update notifications to the passed
|
2014-02-19 00:23:33 +01:00
|
|
|
// websocket client.
|
2014-03-04 17:15:25 +01:00
|
|
|
func (m *wsNotificationManager) RegisterBlockUpdates(wsc *wsClient) {
|
|
|
|
m.queueNotification <- (*notificationRegisterBlocks)(wsc)
|
2014-02-08 23:15:17 +01:00
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// UnregisterBlockUpdates removes block update notifications for the passed
|
2014-02-19 00:23:33 +01:00
|
|
|
// websocket client.
|
2014-03-04 17:15:25 +01:00
|
|
|
func (m *wsNotificationManager) UnregisterBlockUpdates(wsc *wsClient) {
|
|
|
|
m.queueNotification <- (*notificationUnregisterBlocks)(wsc)
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// notifyBlockConnected notifies websocket clients that have registered for
|
2014-02-19 00:23:33 +01:00
|
|
|
// block updates when a block is connected to the main chain.
|
2014-07-02 17:31:10 +02:00
|
|
|
func (*wsNotificationManager) notifyBlockConnected(clients map[chan struct{}]*wsClient,
|
2014-03-04 17:15:25 +01:00
|
|
|
block *btcutil.Block) {
|
2014-02-12 04:39:11 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
hash, err := block.Sha()
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Error("Bad block; connected block notification dropped")
|
|
|
|
return
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Notify interested websocket clients about the connected block.
|
|
|
|
ntfn := btcws.NewBlockConnectedNtfn(hash.String(), int32(block.Height()))
|
|
|
|
marshalledJSON, err := json.Marshal(ntfn)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Error("Failed to marshal block connected notification: "+
|
|
|
|
"%v", err)
|
|
|
|
return
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
2014-03-04 17:15:25 +01:00
|
|
|
for _, wsc := range clients {
|
2014-02-19 00:23:33 +01:00
|
|
|
wsc.QueueNotification(marshalledJSON)
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// notifyBlockDisconnected notifies websocket clients that have registered for
|
2014-02-19 00:23:33 +01:00
|
|
|
// block updates when a block is disconnected from the main chain (due to a
|
|
|
|
// reorganize).
|
2014-07-02 17:31:10 +02:00
|
|
|
func (*wsNotificationManager) notifyBlockDisconnected(clients map[chan struct{}]*wsClient, block *btcutil.Block) {
|
2014-03-04 17:15:25 +01:00
|
|
|
// Skip notification creation if no clients have requested block
|
|
|
|
// connected/disconnected notifications.
|
|
|
|
if len(clients) == 0 {
|
2014-02-12 04:39:11 +01:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
hash, err := block.Sha()
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Error("Bad block; disconnected block notification " +
|
|
|
|
"dropped")
|
|
|
|
return
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Notify interested websocket clients about the disconnected block.
|
|
|
|
ntfn := btcws.NewBlockDisconnectedNtfn(hash.String(),
|
|
|
|
int32(block.Height()))
|
|
|
|
marshalledJSON, err := json.Marshal(ntfn)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Error("Failed to marshal block disconnected "+
|
|
|
|
"notification: %v", err)
|
|
|
|
return
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
2014-03-04 17:15:25 +01:00
|
|
|
for _, wsc := range clients {
|
2014-02-19 00:23:33 +01:00
|
|
|
wsc.QueueNotification(marshalledJSON)
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// RegisterNewMempoolTxsUpdates requests notifications to the passed websocket
|
|
|
|
// client when new transactions are added to the memory pool.
|
|
|
|
func (m *wsNotificationManager) RegisterNewMempoolTxsUpdates(wsc *wsClient) {
|
|
|
|
m.queueNotification <- (*notificationRegisterNewMempoolTxs)(wsc)
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// UnregisterNewMempoolTxsUpdates removes notifications to the passed websocket
|
|
|
|
// client when new transaction are added to the memory pool.
|
|
|
|
func (m *wsNotificationManager) UnregisterNewMempoolTxsUpdates(wsc *wsClient) {
|
|
|
|
m.queueNotification <- (*notificationUnregisterNewMempoolTxs)(wsc)
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// notifyForNewTx notifies websocket clients that have registerd for updates
|
2014-02-19 00:23:33 +01:00
|
|
|
// when a new transaction is added to the memory pool.
|
2014-07-02 17:31:10 +02:00
|
|
|
func (m *wsNotificationManager) notifyForNewTx(clients map[chan struct{}]*wsClient, tx *btcutil.Tx) {
|
2014-03-04 17:15:25 +01:00
|
|
|
txShaStr := tx.Sha().String()
|
2014-02-19 00:23:33 +01:00
|
|
|
mtx := tx.MsgTx()
|
|
|
|
|
|
|
|
var amount int64
|
|
|
|
for _, txOut := range mtx.TxOut {
|
|
|
|
amount += txOut.Value
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-04-15 07:29:49 +02:00
|
|
|
ntfn := btcws.NewTxAcceptedNtfn(txShaStr, amount)
|
2014-02-19 00:23:33 +01:00
|
|
|
marshalledJSON, err := json.Marshal(ntfn)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal tx notification: %s", err.Error())
|
|
|
|
return
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-04-15 07:29:49 +02:00
|
|
|
var verboseNtfn *btcws.TxAcceptedVerboseNtfn
|
2014-02-19 00:23:33 +01:00
|
|
|
var marshalledJSONVerbose []byte
|
2014-03-04 17:15:25 +01:00
|
|
|
for _, wsc := range clients {
|
2014-02-19 00:23:33 +01:00
|
|
|
if wsc.verboseTxUpdates {
|
|
|
|
if verboseNtfn == nil {
|
2014-05-28 00:44:55 +02:00
|
|
|
net := m.server.server.netParams
|
2014-03-04 17:15:25 +01:00
|
|
|
rawTx, err := createTxRawResult(net, txShaStr,
|
|
|
|
mtx, nil, 0, nil)
|
2014-02-19 00:23:33 +01:00
|
|
|
if err != nil {
|
|
|
|
return
|
|
|
|
}
|
2014-04-15 07:29:49 +02:00
|
|
|
verboseNtfn = btcws.NewTxAcceptedVerboseNtfn(rawTx)
|
2014-02-19 00:23:33 +01:00
|
|
|
marshalledJSONVerbose, err = json.Marshal(verboseNtfn)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal verbose tx notification: %s", err.Error())
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
}
|
|
|
|
wsc.QueueNotification(marshalledJSONVerbose)
|
|
|
|
} else {
|
|
|
|
wsc.QueueNotification(marshalledJSON)
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// RegisterSpentRequest requests an notification when the passed outpoint is
|
|
|
|
// confirmed spent (contained in a block connected to the main chain) for the
|
|
|
|
// passed websocket client. The request is automatically removed once the
|
|
|
|
// notification has been sent.
|
|
|
|
func (m *wsNotificationManager) RegisterSpentRequest(wsc *wsClient, op *btcwire.OutPoint) {
|
|
|
|
m.queueNotification <- ¬ificationRegisterSpent{
|
|
|
|
wsc: wsc,
|
|
|
|
op: op,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// addSpentRequest modifies a map of watched outpoints to sets of websocket
|
|
|
|
// clients to add a new request watch the outpoint op and create and send
|
|
|
|
// a notification when spent to the websocket client wsc.
|
2014-07-02 17:31:10 +02:00
|
|
|
func (*wsNotificationManager) addSpentRequest(ops map[btcwire.OutPoint]map[chan struct{}]*wsClient,
|
2014-03-04 17:15:25 +01:00
|
|
|
wsc *wsClient, op *btcwire.OutPoint) {
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Track the request in the client as well so it can be quickly be
|
|
|
|
// removed on disconnect.
|
|
|
|
wsc.spentRequests[*op] = struct{}{}
|
|
|
|
|
|
|
|
// Add the client to the list to notify when the outpoint is seen.
|
|
|
|
// Create the list as needed.
|
2014-03-04 17:15:25 +01:00
|
|
|
cmap, ok := ops[*op]
|
2014-02-19 00:23:33 +01:00
|
|
|
if !ok {
|
2014-07-02 17:31:10 +02:00
|
|
|
cmap = make(map[chan struct{}]*wsClient)
|
2014-03-04 17:15:25 +01:00
|
|
|
ops[*op] = cmap
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
|
|
|
cmap[wsc.quit] = wsc
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// UnregisterSpentRequest removes a request from the passed websocket client
|
|
|
|
// to be notified when the passed outpoint is confirmed spent (contained in a
|
|
|
|
// block connected to the main chain).
|
|
|
|
func (m *wsNotificationManager) UnregisterSpentRequest(wsc *wsClient, op *btcwire.OutPoint) {
|
|
|
|
m.queueNotification <- ¬ificationUnregisterSpent{
|
|
|
|
wsc: wsc,
|
|
|
|
op: op,
|
|
|
|
}
|
2014-02-24 15:10:59 +01:00
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// removeSpentRequest modifies a map of watched outpoints to remove the
|
|
|
|
// websocket client wsc from the set of clients to be notified when a
|
|
|
|
// watched outpoint is spent. If wsc is the last client, the outpoint
|
|
|
|
// key is removed from the map.
|
2014-07-02 17:31:10 +02:00
|
|
|
func (*wsNotificationManager) removeSpentRequest(ops map[btcwire.OutPoint]map[chan struct{}]*wsClient,
|
2014-03-04 17:15:25 +01:00
|
|
|
wsc *wsClient, op *btcwire.OutPoint) {
|
|
|
|
|
2014-02-19 16:13:49 +01:00
|
|
|
// Remove the request tracking from the client.
|
|
|
|
delete(wsc.spentRequests, *op)
|
|
|
|
|
|
|
|
// Remove the client from the list to notify.
|
2014-03-04 17:15:25 +01:00
|
|
|
notifyMap, ok := ops[*op]
|
2014-02-12 04:39:11 +01:00
|
|
|
if !ok {
|
2014-02-19 00:23:33 +01:00
|
|
|
rpcsLog.Warnf("Attempt to remove nonexistent spent request "+
|
|
|
|
"for websocket client %s", wsc.addr)
|
2014-02-12 04:39:11 +01:00
|
|
|
return
|
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
delete(notifyMap, wsc.quit)
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// Remove the map entry altogether if there are
|
|
|
|
// no more clients interested in it.
|
2014-02-19 00:23:33 +01:00
|
|
|
if len(notifyMap) == 0 {
|
2014-03-04 17:15:25 +01:00
|
|
|
delete(ops, *op)
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-24 15:10:59 +01:00
|
|
|
// txHexString returns the serialized transaction encoded in hexadecimal.
|
|
|
|
func txHexString(tx *btcutil.Tx) string {
|
2014-03-20 20:33:09 +01:00
|
|
|
buf := bytes.NewBuffer(make([]byte, 0, tx.MsgTx().SerializeSize()))
|
2014-02-24 15:10:59 +01:00
|
|
|
// Ignore Serialize's error, as writing to a bytes.buffer cannot fail.
|
2014-03-20 20:33:09 +01:00
|
|
|
tx.MsgTx().Serialize(buf)
|
2014-02-24 15:10:59 +01:00
|
|
|
return hex.EncodeToString(buf.Bytes())
|
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// blockDetails creates a BlockDetails struct to include in btcws notifications
|
|
|
|
// from a block and a transaction's block index.
|
|
|
|
func blockDetails(block *btcutil.Block, txIndex int) *btcws.BlockDetails {
|
|
|
|
if block == nil {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
blockSha, _ := block.Sha() // never errors
|
|
|
|
return &btcws.BlockDetails{
|
|
|
|
Height: int32(block.Height()),
|
|
|
|
Hash: blockSha.String(),
|
|
|
|
Index: txIndex,
|
|
|
|
Time: block.MsgBlock().Header.Timestamp.Unix(),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// newRedeemingTxNotification returns a new marshalled redeemingtx notification
|
|
|
|
// with the passed parameters.
|
|
|
|
func newRedeemingTxNotification(txHex string, index int, block *btcutil.Block) ([]byte, error) {
|
|
|
|
// Create and marshal the notification.
|
|
|
|
ntfn := btcws.NewRedeemingTxNtfn(txHex, blockDetails(block, index))
|
|
|
|
return json.Marshal(ntfn)
|
|
|
|
}
|
|
|
|
|
2014-02-24 15:10:59 +01:00
|
|
|
// notifyForTxOuts examines each transaction output, notifying interested
|
|
|
|
// websocket clients of the transaction if an output spends to a watched
|
|
|
|
// address. A spent notification request is automatically registered for
|
|
|
|
// the client for each matching output.
|
2014-07-02 17:31:10 +02:00
|
|
|
func (m *wsNotificationManager) notifyForTxOuts(ops map[btcwire.OutPoint]map[chan struct{}]*wsClient,
|
|
|
|
addrs map[string]map[chan struct{}]*wsClient, tx *btcutil.Tx, block *btcutil.Block) {
|
2014-03-04 17:15:25 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Nothing to do if nobody is listening for address notifications.
|
2014-03-04 17:15:25 +01:00
|
|
|
if len(addrs) == 0 {
|
2014-02-19 00:23:33 +01:00
|
|
|
return
|
2014-01-17 20:04:57 +01:00
|
|
|
}
|
|
|
|
|
2014-02-24 15:10:59 +01:00
|
|
|
txHex := ""
|
2014-07-02 17:31:10 +02:00
|
|
|
wscNotified := make(map[chan struct{}]struct{})
|
2014-02-24 15:10:59 +01:00
|
|
|
for i, txOut := range tx.MsgTx().TxOut {
|
2014-03-04 17:15:25 +01:00
|
|
|
_, txAddrs, _, err := btcscript.ExtractPkScriptAddrs(
|
2014-05-28 00:44:55 +02:00
|
|
|
txOut.PkScript, m.server.server.netParams)
|
2014-02-19 00:23:33 +01:00
|
|
|
if err != nil {
|
|
|
|
continue
|
|
|
|
}
|
2014-01-22 21:10:04 +01:00
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
for _, txAddr := range txAddrs {
|
|
|
|
cmap, ok := addrs[txAddr.EncodeAddress()]
|
2014-02-19 00:23:33 +01:00
|
|
|
if !ok {
|
|
|
|
continue
|
|
|
|
}
|
2014-01-22 21:10:04 +01:00
|
|
|
|
2014-02-24 15:10:59 +01:00
|
|
|
if txHex == "" {
|
|
|
|
txHex = txHexString(tx)
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2014-02-24 15:10:59 +01:00
|
|
|
ntfn := btcws.NewRecvTxNtfn(txHex, blockDetails(block, tx.Index()))
|
2014-02-08 23:15:17 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
marshalledJSON, err := json.Marshal(ntfn)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal processedtx notification: %v", err)
|
2014-02-24 15:10:59 +01:00
|
|
|
continue
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2014-02-08 23:15:17 +01:00
|
|
|
|
2014-02-24 15:10:59 +01:00
|
|
|
op := btcwire.NewOutPoint(tx.Sha(), uint32(i))
|
|
|
|
for wscQuit, wsc := range cmap {
|
2014-03-04 17:15:25 +01:00
|
|
|
m.addSpentRequest(ops, wsc, op)
|
2014-02-24 15:10:59 +01:00
|
|
|
|
2014-07-02 16:45:17 +02:00
|
|
|
if _, ok := wscNotified[wscQuit]; !ok {
|
|
|
|
wscNotified[wscQuit] = struct{}{}
|
2014-02-24 15:10:59 +01:00
|
|
|
wsc.QueueNotification(marshalledJSON)
|
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2014-01-08 17:40:27 +01:00
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// notifyForTx examines the inputs and outputs of the passed transaction,
|
2014-02-24 15:10:59 +01:00
|
|
|
// notifying websocket clients of outputs spending to a watched address
|
|
|
|
// and inputs spending a watched outpoint.
|
2014-07-02 17:31:10 +02:00
|
|
|
func (m *wsNotificationManager) notifyForTx(ops map[btcwire.OutPoint]map[chan struct{}]*wsClient,
|
|
|
|
addrs map[string]map[chan struct{}]*wsClient, tx *btcutil.Tx, block *btcutil.Block) {
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
if len(ops) != 0 {
|
|
|
|
m.notifyForTxIns(ops, tx, block)
|
|
|
|
}
|
|
|
|
if len(addrs) != 0 {
|
|
|
|
m.notifyForTxOuts(ops, addrs, tx, block)
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-24 15:10:59 +01:00
|
|
|
// notifyForTxIns examines the inputs of the passed transaction and sends
|
|
|
|
// interested websocket clients a redeemingtx notification if any inputs
|
|
|
|
// spend a watched output. If block is non-nil, any matching spent
|
|
|
|
// requests are removed.
|
2014-07-02 17:31:10 +02:00
|
|
|
func (m *wsNotificationManager) notifyForTxIns(ops map[btcwire.OutPoint]map[chan struct{}]*wsClient,
|
2014-03-04 17:15:25 +01:00
|
|
|
tx *btcutil.Tx, block *btcutil.Block) {
|
|
|
|
|
|
|
|
// Nothing to do if nobody is watching outpoints.
|
|
|
|
if len(ops) == 0 {
|
2014-02-19 00:23:33 +01:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2014-02-24 15:10:59 +01:00
|
|
|
txHex := ""
|
2014-07-02 17:31:10 +02:00
|
|
|
wscNotified := make(map[chan struct{}]struct{})
|
2014-02-19 00:23:33 +01:00
|
|
|
for _, txIn := range tx.MsgTx().TxIn {
|
|
|
|
prevOut := &txIn.PreviousOutpoint
|
2014-03-04 17:15:25 +01:00
|
|
|
if cmap, ok := ops[*prevOut]; ok {
|
2014-02-24 15:10:59 +01:00
|
|
|
if txHex == "" {
|
|
|
|
txHex = txHexString(tx)
|
|
|
|
}
|
|
|
|
marshalledJSON, err := newRedeemingTxNotification(txHex, tx.Index(), block)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Warnf("Failed to marshal redeemingtx notification: %v", err)
|
2014-02-19 00:23:33 +01:00
|
|
|
continue
|
|
|
|
}
|
2014-02-24 15:10:59 +01:00
|
|
|
for wscQuit, wsc := range cmap {
|
|
|
|
if block != nil {
|
2014-03-04 17:15:25 +01:00
|
|
|
m.removeSpentRequest(ops, wsc, prevOut)
|
2014-02-24 15:10:59 +01:00
|
|
|
}
|
|
|
|
|
2014-07-02 16:45:17 +02:00
|
|
|
if _, ok := wscNotified[wscQuit]; !ok {
|
|
|
|
wscNotified[wscQuit] = struct{}{}
|
2014-02-24 15:10:59 +01:00
|
|
|
wsc.QueueNotification(marshalledJSON)
|
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// RegisterTxOutAddressRequest requests notifications to the passed websocket
|
|
|
|
// client when a transaction output spends to the passed address.
|
|
|
|
func (m *wsNotificationManager) RegisterTxOutAddressRequest(wsc *wsClient, addr string) {
|
|
|
|
m.queueNotification <- ¬ificationRegisterAddr{
|
|
|
|
wsc: wsc,
|
|
|
|
addr: addr,
|
2014-02-24 15:10:59 +01:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// addAddrRequest adds the websocket client wsc to the address to client set
|
|
|
|
// addrs so wsc will be notified for any mempool or block transaction outputs
|
|
|
|
// spending to addr.
|
2014-07-02 17:31:10 +02:00
|
|
|
func (*wsNotificationManager) addAddrRequest(addrs map[string]map[chan struct{}]*wsClient,
|
2014-03-04 17:15:25 +01:00
|
|
|
wsc *wsClient, addr string) {
|
2014-02-19 00:23:33 +01:00
|
|
|
|
|
|
|
// Track the request in the client as well so it can be quickly be
|
|
|
|
// removed on disconnect.
|
|
|
|
wsc.addrRequests[addr] = struct{}{}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// Add the client to the set of clients to notify when the outpoint is
|
|
|
|
// seen. Create map as needed.
|
|
|
|
cmap, ok := addrs[addr]
|
2014-02-19 00:23:33 +01:00
|
|
|
if !ok {
|
2014-07-02 17:31:10 +02:00
|
|
|
cmap = make(map[chan struct{}]*wsClient)
|
2014-03-04 17:15:25 +01:00
|
|
|
addrs[addr] = cmap
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
|
|
|
cmap[wsc.quit] = wsc
|
2014-01-17 22:00:46 +01:00
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// UnregisterTxOutAddressRequest removes a request from the passed websocket
|
|
|
|
// client to be notified when a transaction spends to the passed address.
|
|
|
|
func (m *wsNotificationManager) UnregisterTxOutAddressRequest(wsc *wsClient, addr string) {
|
|
|
|
m.queueNotification <- ¬ificationUnregisterAddr{
|
|
|
|
wsc: wsc,
|
|
|
|
addr: addr,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// removeAddrRequest removes the websocket client wsc from the address to
|
|
|
|
// client set addrs so it will no longer receive notification updates for
|
|
|
|
// any transaction outputs send to addr.
|
2014-07-02 17:31:10 +02:00
|
|
|
func (*wsNotificationManager) removeAddrRequest(addrs map[string]map[chan struct{}]*wsClient,
|
2014-03-04 17:15:25 +01:00
|
|
|
wsc *wsClient, addr string) {
|
|
|
|
|
2014-02-19 16:13:49 +01:00
|
|
|
// Remove the request tracking from the client.
|
|
|
|
delete(wsc.addrRequests, addr)
|
|
|
|
|
|
|
|
// Remove the client from the list to notify.
|
2014-03-04 17:15:25 +01:00
|
|
|
cmap, ok := addrs[addr]
|
2013-12-31 21:39:17 +01:00
|
|
|
if !ok {
|
2014-02-19 00:23:33 +01:00
|
|
|
rpcsLog.Warnf("Attempt to remove nonexistent addr request "+
|
|
|
|
"<%s> for websocket client %s", addr, wsc.addr)
|
|
|
|
return
|
2013-12-31 21:39:17 +01:00
|
|
|
}
|
2014-03-04 17:15:25 +01:00
|
|
|
delete(cmap, wsc.quit)
|
2014-01-03 19:22:28 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Remove the map entry altogether if there are no more clients
|
|
|
|
// interested in it.
|
2014-03-04 17:15:25 +01:00
|
|
|
if len(cmap) == 0 {
|
|
|
|
delete(addrs, addr)
|
2013-12-31 21:39:17 +01:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// AddClient adds the passed websocket client to the notification manager.
|
|
|
|
func (m *wsNotificationManager) AddClient(wsc *wsClient) {
|
2014-03-04 17:15:25 +01:00
|
|
|
m.queueNotification <- (*notificationRegisterClient)(wsc)
|
2013-12-31 21:39:17 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// RemoveClient removes the passed websocket client and all notifications
|
|
|
|
// registered for it.
|
|
|
|
func (m *wsNotificationManager) RemoveClient(wsc *wsClient) {
|
2014-03-04 17:31:44 +01:00
|
|
|
select {
|
|
|
|
case m.queueNotification <- (*notificationUnregisterClient)(wsc):
|
|
|
|
case <-m.quit:
|
|
|
|
}
|
2014-03-04 17:15:25 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
// Start starts the goroutines required for the manager to queue and process
|
|
|
|
// websocket client notifications.
|
|
|
|
func (m *wsNotificationManager) Start() {
|
|
|
|
m.wg.Add(2)
|
|
|
|
go m.queueHandler()
|
|
|
|
go m.notificationHandler()
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
// WaitForShutdown blocks until all notification manager goroutines have
|
|
|
|
// finished.
|
|
|
|
func (m *wsNotificationManager) WaitForShutdown() {
|
|
|
|
m.wg.Wait()
|
|
|
|
}
|
|
|
|
|
|
|
|
// Shutdown shuts down the manager, stopping the notification queue and
|
|
|
|
// notification handler goroutines.
|
2014-02-19 00:23:33 +01:00
|
|
|
func (m *wsNotificationManager) Shutdown() {
|
2014-03-04 17:15:25 +01:00
|
|
|
close(m.quit)
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// newWsNotificationManager returns a new notification manager ready for use.
|
|
|
|
// See wsNotificationManager for more details.
|
|
|
|
func newWsNotificationManager(server *rpcServer) *wsNotificationManager {
|
|
|
|
return &wsNotificationManager{
|
2014-03-04 17:15:25 +01:00
|
|
|
server: server,
|
|
|
|
queueNotification: make(chan interface{}),
|
|
|
|
notificationMsgs: make(chan interface{}),
|
|
|
|
numClients: make(chan int),
|
|
|
|
quit: make(chan struct{}),
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// wsResponse houses a message to send to the a connected websocket client as
|
|
|
|
// well as a channel to reply on when the message is sent.
|
|
|
|
type wsResponse struct {
|
|
|
|
msg []byte
|
|
|
|
doneChan chan bool
|
|
|
|
}
|
2014-01-14 21:59:31 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// createMarshalledReply returns a new marshalled btcjson.Reply given the
|
|
|
|
// passed parameters. It will automatically convert errors that are not of
|
|
|
|
// the type *btcjson.Error to the appropriate type as needed.
|
|
|
|
func createMarshalledReply(id, result interface{}, replyErr error) ([]byte, error) {
|
|
|
|
var jsonErr *btcjson.Error
|
|
|
|
if replyErr != nil {
|
2014-04-25 09:51:03 +02:00
|
|
|
if jErr, ok := replyErr.(*btcjson.Error); ok {
|
|
|
|
jsonErr = jErr
|
|
|
|
} else {
|
2014-02-19 00:23:33 +01:00
|
|
|
jsonErr = &btcjson.Error{
|
|
|
|
Code: btcjson.ErrInternal.Code,
|
2014-04-25 09:51:03 +02:00
|
|
|
Message: replyErr.Error(),
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
response := btcjson.Reply{
|
|
|
|
Id: &id,
|
|
|
|
Result: result,
|
|
|
|
Error: jsonErr,
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
marshalledJSON, err := json.Marshal(response)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
return marshalledJSON, nil
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// wsClient provides an abstraction for handling a websocket client. The
|
|
|
|
// overall data flow is split into 3 main goroutines, a possible 4th goroutine
|
|
|
|
// for long-running operations (only started if request is made), and a
|
|
|
|
// websocket manager which is used to allow things such as broadcasting
|
|
|
|
// requested notifications to all connected websocket clients. Inbound
|
|
|
|
// messages are read via the inHandler goroutine and generally dispatched to
|
|
|
|
// their own handler. However, certain potentially long-running operations such
|
|
|
|
// as rescans, are sent to the asyncHander goroutine and are limited to one at a
|
|
|
|
// time. There are two outbound message types - one for responding to client
|
|
|
|
// requests and another for async notifications. Responses to client requests
|
|
|
|
// use SendMessage which employs a buffered channel thereby limiting the number
|
|
|
|
// of outstanding requests that can be made. Notifications are sent via
|
|
|
|
// QueueNotification which implements a queue via notificationQueueHandler to
|
|
|
|
// ensure sending notifications from other subsystems can't block. Ultimately,
|
|
|
|
// all messages are sent via the outHandler.
|
|
|
|
type wsClient struct {
|
2014-02-25 06:57:36 +01:00
|
|
|
sync.Mutex
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// server is the RPC server that is servicing the client.
|
|
|
|
server *rpcServer
|
|
|
|
|
|
|
|
// conn is the underlying websocket connection.
|
|
|
|
conn *websocket.Conn
|
|
|
|
|
2014-02-25 06:57:36 +01:00
|
|
|
// disconnected indicated whether or not the websocket client is
|
|
|
|
// disconnected.
|
|
|
|
disconnected bool
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// addr is the remote address of the client.
|
|
|
|
addr string
|
2014-01-14 21:59:31 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// authenticated specifies whether a client has been authenticated
|
|
|
|
// and therefore is allowed to communicated over the websocket.
|
|
|
|
authenticated bool
|
2014-01-14 21:59:31 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// verboseTxUpdates specifies whether a client has requested verbose
|
|
|
|
// information about all new transactions.
|
|
|
|
verboseTxUpdates bool
|
2014-01-14 21:59:31 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// addrRequests is a set of addresses the caller has requested to be
|
|
|
|
// notified about. It is maintained here so all requests can be removed
|
|
|
|
// when a wallet disconnects. Owned by the notification manager.
|
|
|
|
addrRequests map[string]struct{}
|
2014-01-14 21:59:31 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// spentRequests is a set of unspent Outpoints a wallet has requested
|
|
|
|
// notifications for when they are spent by a processed transaction.
|
|
|
|
// Owned by the notification manager.
|
|
|
|
spentRequests map[btcwire.OutPoint]struct{}
|
2014-01-14 21:59:31 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Networking infrastructure.
|
|
|
|
asyncStarted bool
|
|
|
|
asyncChan chan btcjson.Cmd
|
|
|
|
ntfnChan chan []byte
|
|
|
|
sendChan chan wsResponse
|
2014-07-02 17:31:10 +02:00
|
|
|
quit chan struct{}
|
2014-02-19 00:23:33 +01:00
|
|
|
wg sync.WaitGroup
|
|
|
|
}
|
2014-01-14 21:59:31 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// handleMessage is the main handler for incoming requests. It enforces
|
|
|
|
// authentication, parses the incoming json, looks up and executes handlers
|
|
|
|
// (including pass through for standard RPC commands), sends the appropriate
|
|
|
|
// response. It also detects commands which are marked as long-running and
|
|
|
|
// sends them off to the asyncHander for processing.
|
2014-06-07 07:35:34 +02:00
|
|
|
func (c *wsClient) handleMessage(msg []byte) {
|
2014-02-19 00:23:33 +01:00
|
|
|
if !c.authenticated {
|
|
|
|
// Disconnect immediately if the provided command fails to
|
|
|
|
// parse when the client is not already authenticated.
|
2014-06-07 07:35:34 +02:00
|
|
|
cmd, jsonErr := parseCmd(msg)
|
2014-02-19 00:23:33 +01:00
|
|
|
if jsonErr != nil {
|
|
|
|
c.Disconnect()
|
|
|
|
return
|
2014-01-14 21:59:31 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Disconnect immediately if the first command is not
|
|
|
|
// authenticate when not already authenticated.
|
|
|
|
authCmd, ok := cmd.(*btcws.AuthenticateCmd)
|
|
|
|
if !ok {
|
|
|
|
rpcsLog.Warnf("Unauthenticated websocket message " +
|
|
|
|
"received")
|
|
|
|
c.Disconnect()
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
// Check credentials.
|
|
|
|
login := authCmd.Username + ":" + authCmd.Passphrase
|
|
|
|
auth := "Basic " + base64.StdEncoding.EncodeToString([]byte(login))
|
2014-05-01 17:36:41 +02:00
|
|
|
authSha := fastsha256.Sum256([]byte(auth))
|
2014-02-19 00:23:33 +01:00
|
|
|
cmp := subtle.ConstantTimeCompare(authSha[:], c.server.authsha[:])
|
|
|
|
if cmp != 1 {
|
|
|
|
rpcsLog.Warnf("Auth failure.")
|
|
|
|
c.Disconnect()
|
|
|
|
return
|
2014-01-21 00:07:17 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
c.authenticated = true
|
|
|
|
|
|
|
|
// Marshal and send response.
|
|
|
|
reply, err := createMarshalledReply(authCmd.Id(), nil, nil)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal authenticate reply: "+
|
|
|
|
"%v", err.Error())
|
|
|
|
return
|
2014-01-21 00:07:17 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
c.SendMessage(reply, nil)
|
|
|
|
return
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Attmpt to parse the raw json into a known btcjson.Cmd.
|
2014-06-07 07:35:34 +02:00
|
|
|
cmd, jsonErr := parseCmd(msg)
|
2014-02-19 00:23:33 +01:00
|
|
|
if jsonErr != nil {
|
|
|
|
// Use the provided id for errors when a valid JSON-RPC message
|
|
|
|
// was parsed. Requests with no IDs are ignored.
|
|
|
|
var id interface{}
|
|
|
|
if cmd != nil {
|
|
|
|
id = cmd.Id()
|
|
|
|
if id == nil {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Marshal and send response.
|
|
|
|
reply, err := createMarshalledReply(id, nil, jsonErr)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal parse failure "+
|
|
|
|
"reply: %v", err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
c.SendMessage(reply, nil)
|
|
|
|
return
|
2014-01-22 21:10:04 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
rpcsLog.Debugf("Received command <%s> from %s", cmd.Method(), c.addr)
|
|
|
|
|
|
|
|
// Disconnect if already authenticated and another authenticate command
|
|
|
|
// is received.
|
|
|
|
if _, ok := cmd.(*btcws.AuthenticateCmd); ok {
|
|
|
|
rpcsLog.Warnf("Websocket client %s is already authenticated",
|
|
|
|
c.addr)
|
|
|
|
c.Disconnect()
|
|
|
|
return
|
2014-01-22 21:10:04 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// When the command is marked as a long-running command, send it off
|
|
|
|
// to the asyncHander goroutine for processing.
|
|
|
|
if _, ok := wsAsyncHandlers[cmd.Method()]; ok {
|
|
|
|
// Start up the async goroutine for handling long-running
|
|
|
|
// requests asynchonrously if needed.
|
|
|
|
if !c.asyncStarted {
|
|
|
|
rpcsLog.Tracef("Starting async handler for %s", c.addr)
|
|
|
|
c.wg.Add(1)
|
|
|
|
go c.asyncHandler()
|
|
|
|
c.asyncStarted = true
|
|
|
|
}
|
|
|
|
c.asyncChan <- cmd
|
|
|
|
return
|
2014-01-22 21:10:04 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Lookup the websocket extension for the command and if it doesn't
|
|
|
|
// exist fallback to handling the command as a standard command.
|
|
|
|
wsHandler, ok := wsHandlers[cmd.Method()]
|
|
|
|
if !ok {
|
|
|
|
// No websocket-specific handler so handle like a legacy
|
|
|
|
// RPC connection.
|
2014-06-27 18:13:04 +02:00
|
|
|
response := standardCmdReply(cmd, c.server, nil)
|
2014-02-19 00:23:33 +01:00
|
|
|
reply, err := json.Marshal(response)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal reply for <%s> "+
|
|
|
|
"command: %v", cmd.Method(), err)
|
|
|
|
|
|
|
|
return
|
|
|
|
}
|
|
|
|
c.SendMessage(reply, nil)
|
|
|
|
return
|
|
|
|
}
|
2014-01-22 21:10:04 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Invoke the handler and marshal and send response.
|
|
|
|
result, jsonErr := wsHandler(c, cmd)
|
|
|
|
reply, err := createMarshalledReply(cmd.Id(), result, jsonErr)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal reply for <%s> command: %v",
|
|
|
|
cmd.Method(), err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
c.SendMessage(reply, nil)
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// inHandler handles all incoming messages for the websocket connection. It
|
|
|
|
// must be run as a goroutine.
|
|
|
|
func (c *wsClient) inHandler() {
|
|
|
|
out:
|
|
|
|
for {
|
|
|
|
// Break out of the loop once the quit channel has been closed.
|
|
|
|
// Use a non-blocking select here so we fall through otherwise.
|
|
|
|
select {
|
|
|
|
case <-c.quit:
|
|
|
|
break out
|
|
|
|
default:
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-06-07 07:35:34 +02:00
|
|
|
_, msg, err := c.conn.ReadMessage()
|
|
|
|
if err != nil {
|
2014-02-19 00:23:33 +01:00
|
|
|
// Log the error if it's not due to disconnecting.
|
|
|
|
if err != io.EOF {
|
|
|
|
rpcsLog.Errorf("Websocket receive error from "+
|
|
|
|
"%s: %v", c.addr, err)
|
|
|
|
}
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
c.handleMessage(msg)
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Ensure the connection is closed.
|
|
|
|
c.Disconnect()
|
|
|
|
c.wg.Done()
|
|
|
|
rpcsLog.Tracef("Websocket client input handler done for %s", c.addr)
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// notificationQueueHandler handles the queueing of outgoing notifications for
|
|
|
|
// the websocket client. This runs as a muxer for various sources of input to
|
|
|
|
// ensure that queueing up notifications to be sent will not block. Otherwise,
|
|
|
|
// slow clients could bog down the other systems (such as the mempool or block
|
|
|
|
// manager) which are queueing the data. The data is passed on to outHandler to
|
|
|
|
// actually be written. It must be run as a goroutine.
|
|
|
|
func (c *wsClient) notificationQueueHandler() {
|
|
|
|
ntfnSentChan := make(chan bool, 1) // nonblocking sync
|
|
|
|
|
|
|
|
// pendingNtfns is used as a queue for notifications that are ready to
|
|
|
|
// be sent once there are no outstanding notifications currently being
|
|
|
|
// sent. The waiting flag is used over simply checking for items in the
|
|
|
|
// pending list to ensure cleanup knows what has and hasn't been sent
|
|
|
|
// to the outHandler. Currently no special cleanup is needed, however
|
|
|
|
// if something like a done channel is added to notifications in the
|
|
|
|
// future, not knowing what has and hasn't been sent to the outHandler
|
|
|
|
// (and thus who should respond to the done channel) would be
|
|
|
|
// problematic without using this approach.
|
|
|
|
pendingNtfns := list.New()
|
|
|
|
waiting := false
|
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
// This channel is notified when a message is being queued to
|
|
|
|
// be sent across the network socket. It will either send the
|
|
|
|
// message immediately if a send is not already in progress, or
|
|
|
|
// queue the message to be sent once the other pending messages
|
|
|
|
// are sent.
|
|
|
|
case msg := <-c.ntfnChan:
|
|
|
|
if !waiting {
|
|
|
|
c.SendMessage(msg, ntfnSentChan)
|
|
|
|
} else {
|
|
|
|
pendingNtfns.PushBack(msg)
|
|
|
|
}
|
|
|
|
waiting = true
|
|
|
|
|
|
|
|
// This channel is notified when a notification has been sent
|
|
|
|
// across the network socket.
|
|
|
|
case <-ntfnSentChan:
|
|
|
|
// No longer waiting if there are no more messages in
|
|
|
|
// the pending messages queue.
|
|
|
|
next := pendingNtfns.Front()
|
|
|
|
if next == nil {
|
|
|
|
waiting = false
|
|
|
|
continue
|
|
|
|
}
|
2014-01-14 19:15:22 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Notify the outHandler about the next item to
|
|
|
|
// asynchronously send.
|
|
|
|
msg := pendingNtfns.Remove(next).([]byte)
|
|
|
|
c.SendMessage(msg, ntfnSentChan)
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
case <-c.quit:
|
|
|
|
break out
|
|
|
|
}
|
2014-01-14 21:59:31 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Drain any wait channels before exiting so nothing is left waiting
|
|
|
|
// around to send.
|
|
|
|
cleanup:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-c.ntfnChan:
|
|
|
|
case <-ntfnSentChan:
|
|
|
|
default:
|
|
|
|
break cleanup
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
|
|
|
c.wg.Done()
|
|
|
|
rpcsLog.Tracef("Websocket client notification queue handler done "+
|
|
|
|
"for %s", c.addr)
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// outHandler handles all outgoing messages for the websocket connection. It
|
|
|
|
// must be run as a goroutine. It uses a buffered channel to serialize output
|
|
|
|
// messages while allowing the sender to continue running asynchronously. It
|
|
|
|
// must be run as a goroutine.
|
|
|
|
func (c *wsClient) outHandler() {
|
|
|
|
out:
|
2013-12-31 20:15:44 +01:00
|
|
|
for {
|
2014-02-19 00:23:33 +01:00
|
|
|
// Send any messages ready for send until the quit channel is
|
|
|
|
// closed.
|
2013-12-31 20:15:44 +01:00
|
|
|
select {
|
2014-02-19 00:23:33 +01:00
|
|
|
case r := <-c.sendChan:
|
2014-06-07 07:35:34 +02:00
|
|
|
err := c.conn.WriteMessage(websocket.TextMessage, r.msg)
|
2014-01-14 19:15:22 +01:00
|
|
|
if err != nil {
|
2014-02-19 00:23:33 +01:00
|
|
|
c.Disconnect()
|
|
|
|
break out
|
2014-01-14 19:15:22 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
if r.doneChan != nil {
|
|
|
|
r.doneChan <- true
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
2014-01-14 19:15:22 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
case <-c.quit:
|
|
|
|
break out
|
|
|
|
}
|
|
|
|
}
|
2014-01-15 03:45:42 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Drain any wait channels before exiting so nothing is left waiting
|
|
|
|
// around to send.
|
|
|
|
cleanup:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case r := <-c.sendChan:
|
|
|
|
if r.doneChan != nil {
|
|
|
|
r.doneChan <- false
|
2014-01-14 19:15:22 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
default:
|
|
|
|
break cleanup
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
c.wg.Done()
|
|
|
|
rpcsLog.Tracef("Websocket client output handler done for %s", c.addr)
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// asyncHandler handles all long-running requests such as rescans which are
|
|
|
|
// not run directly in the inHandler routine unlike most requests. This allows
|
|
|
|
// normal quick requests to continue to be processed and responded to even while
|
|
|
|
// lengthy operations are underway. Only one long-running operation is
|
|
|
|
// permitted at a time, so multiple long-running requests are queued and
|
|
|
|
// serialized. It must be run as a goroutine. Also, this goroutine is not
|
|
|
|
// started until/if the first long-running request is made.
|
|
|
|
func (c *wsClient) asyncHandler() {
|
2014-07-02 17:31:10 +02:00
|
|
|
asyncHandlerDoneChan := make(chan struct{}, 1) // nonblocking sync
|
2014-02-19 00:23:33 +01:00
|
|
|
pendingCmds := list.New()
|
|
|
|
waiting := false
|
|
|
|
|
|
|
|
// runHandler runs the handler for the passed command and sends the
|
|
|
|
// reply.
|
|
|
|
runHandler := func(cmd btcjson.Cmd) {
|
|
|
|
wsHandler, ok := wsHandlers[cmd.Method()]
|
|
|
|
if !ok {
|
|
|
|
rpcsLog.Warnf("No handler for command <%s>",
|
|
|
|
cmd.Method())
|
|
|
|
return
|
|
|
|
}
|
2014-01-14 21:59:31 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Invoke the handler and marshal and send response.
|
|
|
|
result, jsonErr := wsHandler(c, cmd)
|
|
|
|
reply, err := createMarshalledReply(cmd.Id(), result, jsonErr)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal reply for <%s> "+
|
|
|
|
"command: %v", cmd.Method(), err)
|
|
|
|
return
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
c.SendMessage(reply, nil)
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
out:
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case cmd := <-c.asyncChan:
|
|
|
|
if !waiting {
|
|
|
|
c.wg.Add(1)
|
|
|
|
go func(cmd btcjson.Cmd) {
|
|
|
|
runHandler(cmd)
|
2014-07-02 17:31:10 +02:00
|
|
|
asyncHandlerDoneChan <- struct{}{}
|
2014-02-19 00:23:33 +01:00
|
|
|
c.wg.Done()
|
|
|
|
}(cmd)
|
|
|
|
} else {
|
|
|
|
pendingCmds.PushBack(cmd)
|
|
|
|
}
|
|
|
|
waiting = true
|
|
|
|
|
|
|
|
case <-asyncHandlerDoneChan:
|
|
|
|
// No longer waiting if there are no more messages in
|
|
|
|
// the pending messages queue.
|
|
|
|
next := pendingCmds.Front()
|
|
|
|
if next == nil {
|
|
|
|
waiting = false
|
|
|
|
continue
|
2014-01-22 21:10:04 +01:00
|
|
|
}
|
2014-01-14 21:59:31 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Notify the outHandler about the next item to
|
|
|
|
// asynchronously send.
|
|
|
|
element := pendingCmds.Remove(next)
|
|
|
|
c.wg.Add(1)
|
|
|
|
go func(cmd btcjson.Cmd) {
|
|
|
|
runHandler(cmd)
|
2014-07-02 17:31:10 +02:00
|
|
|
asyncHandlerDoneChan <- struct{}{}
|
2014-02-19 00:23:33 +01:00
|
|
|
c.wg.Done()
|
|
|
|
}(element.(btcjson.Cmd))
|
|
|
|
|
|
|
|
case <-c.quit:
|
|
|
|
break out
|
|
|
|
}
|
2014-01-14 21:59:31 +01:00
|
|
|
}
|
2014-01-22 21:10:04 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Drain any wait channels before exiting so nothing is left waiting
|
|
|
|
// around to send.
|
|
|
|
cleanup:
|
|
|
|
for {
|
2014-01-22 21:10:04 +01:00
|
|
|
select {
|
2014-02-19 00:23:33 +01:00
|
|
|
case <-c.asyncChan:
|
|
|
|
case <-asyncHandlerDoneChan:
|
2014-01-22 21:10:04 +01:00
|
|
|
default:
|
2014-02-19 00:23:33 +01:00
|
|
|
break cleanup
|
2014-01-22 21:10:04 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2014-01-22 21:10:04 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
c.wg.Done()
|
|
|
|
rpcsLog.Tracef("Websocket client async handler done for %s", c.addr)
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// SendMessage sends the passed json to the websocket client. It is backed
|
|
|
|
// by a buffered channel, so it will not block until the send channel is full.
|
|
|
|
// Note however that QueueNotification must be used for sending async
|
|
|
|
// notifications instead of the this function. This approach allows a limit to
|
|
|
|
// the number of outstanding requests a client can make without preventing or
|
|
|
|
// blocking on async notifications.
|
|
|
|
func (c *wsClient) SendMessage(marshalledJSON []byte, doneChan chan bool) {
|
2014-02-25 06:57:36 +01:00
|
|
|
// Don't send the message if disconnected.
|
|
|
|
if c.Disconnected() {
|
2014-02-19 00:23:33 +01:00
|
|
|
if doneChan != nil {
|
|
|
|
doneChan <- false
|
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
c.sendChan <- wsResponse{msg: marshalledJSON, doneChan: doneChan}
|
|
|
|
}
|
|
|
|
|
2014-02-24 15:10:59 +01:00
|
|
|
// ErrClientQuit describes the error where a client send is not processed due
|
|
|
|
// to the client having already been disconnected or dropped.
|
|
|
|
var ErrClientQuit = errors.New("client quit")
|
|
|
|
|
2014-07-09 08:37:55 +02:00
|
|
|
// QueueNotification queues the passed notification to be sent to the websocket
|
2014-02-19 00:23:33 +01:00
|
|
|
// client. This function, as the name implies, is only intended for
|
|
|
|
// notifications since it has additional logic to prevent other subsystems, such
|
|
|
|
// as the memory pool and block manager, from blocking even when the send
|
|
|
|
// channel is full.
|
2014-02-24 15:10:59 +01:00
|
|
|
//
|
|
|
|
// If the client is in the process of shutting down, this function returns
|
|
|
|
// ErrClientQuit. This is intended to be checked by long-running notification
|
|
|
|
// handlers to stop processing if there is no more work needed to be done.
|
|
|
|
func (c *wsClient) QueueNotification(marshalledJSON []byte) error {
|
2014-02-25 06:57:36 +01:00
|
|
|
// Don't queue the message if disconnected.
|
|
|
|
if c.Disconnected() {
|
2014-02-24 15:10:59 +01:00
|
|
|
return ErrClientQuit
|
2014-01-17 22:00:46 +01:00
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
c.ntfnChan <- marshalledJSON
|
2014-02-24 15:10:59 +01:00
|
|
|
return nil
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
|
|
|
|
2014-02-25 06:57:36 +01:00
|
|
|
// Disconnected returns whether or not the websocket client is disconnected.
|
|
|
|
func (c *wsClient) Disconnected() bool {
|
|
|
|
c.Lock()
|
|
|
|
defer c.Unlock()
|
|
|
|
|
|
|
|
return c.disconnected
|
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Disconnect disconnects the websocket client.
|
|
|
|
func (c *wsClient) Disconnect() {
|
2014-02-25 06:57:36 +01:00
|
|
|
c.Lock()
|
|
|
|
defer c.Unlock()
|
|
|
|
|
|
|
|
// Nothing to do if already disconnected.
|
|
|
|
if c.disconnected {
|
2014-02-19 00:23:33 +01:00
|
|
|
return
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
|
|
|
|
rpcsLog.Tracef("Disconnecting websocket client %s", c.addr)
|
|
|
|
close(c.quit)
|
|
|
|
c.conn.Close()
|
2014-02-25 06:57:36 +01:00
|
|
|
c.disconnected = true
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Start begins processing input and output messages.
|
|
|
|
func (c *wsClient) Start() {
|
|
|
|
rpcsLog.Tracef("Starting websocket client %s", c.addr)
|
2014-02-10 16:34:26 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// Start processing input and output.
|
|
|
|
c.wg.Add(3)
|
|
|
|
go c.inHandler()
|
|
|
|
go c.notificationQueueHandler()
|
|
|
|
go c.outHandler()
|
|
|
|
}
|
|
|
|
|
|
|
|
// WaitForShutdown blocks until the websocket client goroutines are stopped
|
|
|
|
// and the connection is closed.
|
|
|
|
func (c *wsClient) WaitForShutdown() {
|
|
|
|
c.wg.Wait()
|
|
|
|
}
|
|
|
|
|
|
|
|
// newWebsocketClient returns a new websocket client given the notification
|
|
|
|
// manager, websocket connection, remote address, and whether or not the client
|
|
|
|
// has already been authenticated (via HTTP Basic access authentication). The
|
|
|
|
// returned client is ready to start. Once started, the client will process
|
|
|
|
// incoming and outgoing messages in separate goroutines complete with queueing
|
|
|
|
// and asynchrous handling for long-running operations.
|
|
|
|
func newWebsocketClient(server *rpcServer, conn *websocket.Conn,
|
|
|
|
remoteAddr string, authenticated bool) *wsClient {
|
|
|
|
|
|
|
|
return &wsClient{
|
|
|
|
conn: conn,
|
|
|
|
addr: remoteAddr,
|
|
|
|
authenticated: authenticated,
|
|
|
|
server: server,
|
|
|
|
addrRequests: make(map[string]struct{}),
|
|
|
|
spentRequests: make(map[btcwire.OutPoint]struct{}),
|
|
|
|
ntfnChan: make(chan []byte, 1), // nonblocking sync
|
|
|
|
asyncChan: make(chan btcjson.Cmd, 1), // nonblocking sync
|
|
|
|
sendChan: make(chan wsResponse, websocketSendBufferSize),
|
2014-07-02 17:31:10 +02:00
|
|
|
quit: make(chan struct{}),
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// handleNotifyBlocks implements the notifyblocks command extension for
|
|
|
|
// websocket connections.
|
|
|
|
func handleNotifyBlocks(wsc *wsClient, icmd btcjson.Cmd) (interface{}, *btcjson.Error) {
|
2014-03-04 17:15:25 +01:00
|
|
|
wsc.server.ntfnMgr.RegisterBlockUpdates(wsc)
|
2014-02-19 00:23:33 +01:00
|
|
|
return nil, nil
|
|
|
|
}
|
2014-01-08 17:40:27 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// handleNotifySpent implements the notifyspent command extension for
|
|
|
|
// websocket connections.
|
|
|
|
func handleNotifySpent(wsc *wsClient, icmd btcjson.Cmd) (interface{}, *btcjson.Error) {
|
|
|
|
cmd, ok := icmd.(*btcws.NotifySpentCmd)
|
|
|
|
if !ok {
|
|
|
|
return nil, &btcjson.ErrInternal
|
|
|
|
}
|
2014-01-08 17:40:27 +01:00
|
|
|
|
2014-05-06 15:30:36 +02:00
|
|
|
outpoints := make([]*btcwire.OutPoint, 0, len(cmd.OutPoints))
|
|
|
|
for i := range cmd.OutPoints {
|
|
|
|
blockHash, err := btcwire.NewShaHashFromStr(cmd.OutPoints[i].Hash)
|
|
|
|
if err != nil {
|
|
|
|
return nil, &btcjson.Error{
|
|
|
|
Code: btcjson.ErrParse.Code,
|
|
|
|
Message: err.Error(),
|
|
|
|
}
|
2014-04-11 03:41:36 +02:00
|
|
|
}
|
2014-05-06 15:30:36 +02:00
|
|
|
index := cmd.OutPoints[i].Index
|
|
|
|
outpoints = append(outpoints, btcwire.NewOutPoint(blockHash, index))
|
|
|
|
}
|
|
|
|
for _, outpoint := range outpoints {
|
|
|
|
wsc.server.ntfnMgr.RegisterSpentRequest(wsc, outpoint)
|
2014-04-11 03:41:36 +02:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
return nil, nil
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-04-15 07:29:49 +02:00
|
|
|
// handleNotifyNewTransations implements the notifynewtransactions command
|
|
|
|
// extension for websocket connections.
|
|
|
|
func handleNotifyNewTransactions(wsc *wsClient, icmd btcjson.Cmd) (interface{}, *btcjson.Error) {
|
|
|
|
cmd, ok := icmd.(*btcws.NotifyNewTransactionsCmd)
|
2014-02-19 00:23:33 +01:00
|
|
|
if !ok {
|
|
|
|
return nil, &btcjson.ErrInternal
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
wsc.verboseTxUpdates = cmd.Verbose
|
2014-03-04 17:15:25 +01:00
|
|
|
wsc.server.ntfnMgr.RegisterNewMempoolTxsUpdates(wsc)
|
2014-02-19 00:23:33 +01:00
|
|
|
return nil, nil
|
|
|
|
}
|
2014-02-10 16:34:26 +01:00
|
|
|
|
2014-04-15 02:11:08 +02:00
|
|
|
// handleNotifyReceived implements the notifyreceived command extension for
|
2014-02-19 00:23:33 +01:00
|
|
|
// websocket connections.
|
2014-04-15 02:11:08 +02:00
|
|
|
func handleNotifyReceived(wsc *wsClient, icmd btcjson.Cmd) (interface{}, *btcjson.Error) {
|
|
|
|
cmd, ok := icmd.(*btcws.NotifyReceivedCmd)
|
2014-02-19 00:23:33 +01:00
|
|
|
if !ok {
|
|
|
|
return nil, &btcjson.ErrInternal
|
2014-01-17 20:11:49 +01:00
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
for _, addrStr := range cmd.Addresses {
|
2014-05-28 00:44:55 +02:00
|
|
|
addr, err := btcutil.DecodeAddress(addrStr, activeNetParams.Params)
|
2014-01-08 03:30:01 +01:00
|
|
|
if err != nil {
|
2014-02-19 00:23:33 +01:00
|
|
|
e := btcjson.Error{
|
|
|
|
Code: btcjson.ErrInvalidAddressOrKey.Code,
|
|
|
|
Message: fmt.Sprintf("Invalid address or key: %v", addrStr),
|
|
|
|
}
|
|
|
|
return nil, &e
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
|
2014-03-04 17:15:25 +01:00
|
|
|
wsc.server.ntfnMgr.RegisterTxOutAddressRequest(wsc, addr.EncodeAddress())
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
return nil, nil
|
|
|
|
}
|
|
|
|
|
2014-03-21 14:25:00 +01:00
|
|
|
type rescanKeys struct {
|
|
|
|
fallbacks map[string]struct{}
|
|
|
|
pubKeyHashes map[[ripemd160.Size]byte]struct{}
|
|
|
|
scriptHashes map[[ripemd160.Size]byte]struct{}
|
|
|
|
compressedPubkeys map[[33]byte]struct{}
|
|
|
|
uncompressedPubkeys map[[65]byte]struct{}
|
|
|
|
unspent map[btcwire.OutPoint]struct{}
|
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// rescanBlock rescans all transactions in a single block. This is a helper
|
|
|
|
// function for handleRescan.
|
2014-03-21 14:25:00 +01:00
|
|
|
func rescanBlock(wsc *wsClient, lookups *rescanKeys, blk *btcutil.Block) {
|
2014-02-19 00:23:33 +01:00
|
|
|
for _, tx := range blk.Transactions() {
|
2014-02-24 15:10:59 +01:00
|
|
|
// Hexadecimal representation of this tx. Only created if
|
|
|
|
// needed, and reused for later notifications if already made.
|
|
|
|
var txHex string
|
|
|
|
|
|
|
|
// All inputs and outputs must be iterated through to correctly
|
|
|
|
// modify the unspent map, however, just a single notification
|
|
|
|
// for any matching transaction inputs or outputs should be
|
|
|
|
// created and sent.
|
|
|
|
spentNotified := false
|
|
|
|
recvNotified := false
|
|
|
|
|
|
|
|
for _, txin := range tx.MsgTx().TxIn {
|
2014-03-21 14:25:00 +01:00
|
|
|
if _, ok := lookups.unspent[txin.PreviousOutpoint]; ok {
|
|
|
|
delete(lookups.unspent, txin.PreviousOutpoint)
|
2014-02-24 15:10:59 +01:00
|
|
|
|
|
|
|
if spentNotified {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
if txHex == "" {
|
|
|
|
txHex = txHexString(tx)
|
|
|
|
}
|
|
|
|
marshalledJSON, err := newRedeemingTxNotification(txHex, tx.Index(), blk)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal redeemingtx notification: %v", err)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
err = wsc.QueueNotification(marshalledJSON)
|
|
|
|
// Stop the rescan early if the websocket client
|
|
|
|
// disconnected.
|
|
|
|
if err == ErrClientQuit {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
spentNotified = true
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
for txOutIdx, txout := range tx.MsgTx().TxOut {
|
2014-02-24 15:10:59 +01:00
|
|
|
_, addrs, _, _ := btcscript.ExtractPkScriptAddrs(
|
2014-05-28 00:44:55 +02:00
|
|
|
txout.PkScript, wsc.server.server.netParams)
|
2014-02-19 00:23:33 +01:00
|
|
|
|
|
|
|
for _, addr := range addrs {
|
2014-03-21 14:25:00 +01:00
|
|
|
switch a := addr.(type) {
|
|
|
|
case *btcutil.AddressPubKeyHash:
|
2014-04-20 22:51:04 +02:00
|
|
|
if _, ok := lookups.pubKeyHashes[*a.Hash160()]; !ok {
|
2014-03-21 14:25:00 +01:00
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
case *btcutil.AddressScriptHash:
|
2014-04-20 22:51:04 +02:00
|
|
|
if _, ok := lookups.scriptHashes[*a.Hash160()]; !ok {
|
2014-03-21 14:25:00 +01:00
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
case *btcutil.AddressPubKey:
|
2014-04-25 16:02:23 +02:00
|
|
|
found := false
|
|
|
|
switch sa := a.ScriptAddress(); len(sa) {
|
2014-03-21 14:25:00 +01:00
|
|
|
case 33: // Compressed
|
2014-04-25 16:02:23 +02:00
|
|
|
var key [33]byte
|
|
|
|
copy(key[:], sa)
|
|
|
|
if _, ok := lookups.compressedPubkeys[key]; ok {
|
|
|
|
found = true
|
2014-03-21 14:25:00 +01:00
|
|
|
}
|
|
|
|
|
|
|
|
case 65: // Uncompressed
|
2014-04-25 16:02:23 +02:00
|
|
|
var key [65]byte
|
|
|
|
copy(key[:], sa)
|
|
|
|
if _, ok := lookups.uncompressedPubkeys[key]; ok {
|
|
|
|
found = true
|
2014-03-21 14:25:00 +01:00
|
|
|
}
|
|
|
|
|
2014-04-25 16:02:23 +02:00
|
|
|
default:
|
|
|
|
rpcsLog.Warnf("Skipping rescanned pubkey of unknown "+
|
|
|
|
"serialized length %d", len(sa))
|
2014-03-21 14:25:00 +01:00
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
2014-04-25 16:02:23 +02:00
|
|
|
// If the transaction output pays to the pubkey of
|
|
|
|
// a rescanned P2PKH address, include it as well.
|
|
|
|
if !found {
|
|
|
|
pkh := a.AddressPubKeyHash()
|
|
|
|
if _, ok := lookups.pubKeyHashes[*pkh.Hash160()]; !ok {
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2014-03-21 14:25:00 +01:00
|
|
|
default:
|
|
|
|
// A new address type must have been added. Encode as a
|
|
|
|
// payment address string and check the fallback map.
|
|
|
|
addrStr := addr.EncodeAddress()
|
|
|
|
_, ok := lookups.fallbacks[addrStr]
|
|
|
|
if !ok {
|
|
|
|
continue
|
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2013-12-31 20:15:44 +01:00
|
|
|
|
2014-04-25 16:02:23 +02:00
|
|
|
outpoint := btcwire.OutPoint{
|
|
|
|
Hash: *tx.Sha(),
|
|
|
|
Index: uint32(txOutIdx),
|
|
|
|
}
|
2014-03-21 14:25:00 +01:00
|
|
|
lookups.unspent[outpoint] = struct{}{}
|
2014-02-24 15:10:59 +01:00
|
|
|
|
|
|
|
if recvNotified {
|
|
|
|
continue
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
|
|
|
|
2014-02-24 15:10:59 +01:00
|
|
|
if txHex == "" {
|
|
|
|
txHex = txHexString(tx)
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2014-02-24 15:10:59 +01:00
|
|
|
ntfn := btcws.NewRecvTxNtfn(txHex, blockDetails(blk, tx.Index()))
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
marshalledJSON, err := json.Marshal(ntfn)
|
|
|
|
if err != nil {
|
2014-02-24 15:10:59 +01:00
|
|
|
rpcsLog.Errorf("Failed to marshal recvtx notification: %v", err)
|
2014-02-19 00:23:33 +01:00
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2014-02-24 15:10:59 +01:00
|
|
|
err = wsc.QueueNotification(marshalledJSON)
|
2014-02-19 00:23:33 +01:00
|
|
|
// Stop the rescan early if the websocket client
|
|
|
|
// disconnected.
|
2014-02-24 15:10:59 +01:00
|
|
|
if err == ErrClientQuit {
|
2014-02-19 00:23:33 +01:00
|
|
|
return
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
2014-02-24 15:10:59 +01:00
|
|
|
recvNotified = true
|
2013-12-31 20:15:44 +01:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2014-02-08 23:15:17 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// handleRescan implements the rescan command extension for websocket
|
|
|
|
// connections.
|
|
|
|
func handleRescan(wsc *wsClient, icmd btcjson.Cmd) (interface{}, *btcjson.Error) {
|
|
|
|
cmd, ok := icmd.(*btcws.RescanCmd)
|
|
|
|
if !ok {
|
|
|
|
return nil, &btcjson.ErrInternal
|
|
|
|
}
|
2014-02-08 23:15:17 +01:00
|
|
|
|
2014-04-11 03:41:36 +02:00
|
|
|
outpoints := make([]*btcwire.OutPoint, 0, len(cmd.OutPoints))
|
|
|
|
for i := range cmd.OutPoints {
|
|
|
|
blockHash, err := btcwire.NewShaHashFromStr(cmd.OutPoints[i].Hash)
|
|
|
|
if err != nil {
|
|
|
|
return nil, &btcjson.Error{
|
|
|
|
Code: btcjson.ErrParse.Code,
|
|
|
|
Message: err.Error(),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
index := cmd.OutPoints[i].Index
|
|
|
|
outpoints = append(outpoints, btcwire.NewOutPoint(blockHash, index))
|
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
numAddrs := len(cmd.Addresses)
|
|
|
|
if numAddrs == 1 {
|
|
|
|
rpcsLog.Info("Beginning rescan for 1 address")
|
|
|
|
} else {
|
|
|
|
rpcsLog.Infof("Beginning rescan for %d addresses", numAddrs)
|
2014-02-08 23:15:17 +01:00
|
|
|
}
|
|
|
|
|
2014-03-21 14:25:00 +01:00
|
|
|
// Build lookup maps.
|
|
|
|
lookups := rescanKeys{
|
|
|
|
fallbacks: map[string]struct{}{},
|
|
|
|
pubKeyHashes: map[[ripemd160.Size]byte]struct{}{},
|
|
|
|
scriptHashes: map[[ripemd160.Size]byte]struct{}{},
|
|
|
|
compressedPubkeys: map[[33]byte]struct{}{},
|
|
|
|
uncompressedPubkeys: map[[65]byte]struct{}{},
|
|
|
|
unspent: map[btcwire.OutPoint]struct{}{},
|
|
|
|
}
|
|
|
|
var compressedPubkey [33]byte
|
|
|
|
var uncompressedPubkey [65]byte
|
2014-03-21 21:43:31 +01:00
|
|
|
for _, addrStr := range cmd.Addresses {
|
2014-05-28 00:44:55 +02:00
|
|
|
addr, err := btcutil.DecodeAddress(addrStr, activeNetParams.Params)
|
2014-03-21 14:25:00 +01:00
|
|
|
if err != nil {
|
|
|
|
jsonErr := btcjson.Error{
|
|
|
|
Code: btcjson.ErrInvalidAddressOrKey.Code,
|
|
|
|
Message: "Rescan address " + addrStr + ": " + err.Error(),
|
|
|
|
}
|
|
|
|
return nil, &jsonErr
|
|
|
|
}
|
|
|
|
switch a := addr.(type) {
|
|
|
|
case *btcutil.AddressPubKeyHash:
|
2014-04-20 22:51:04 +02:00
|
|
|
lookups.pubKeyHashes[*a.Hash160()] = struct{}{}
|
2014-03-21 14:25:00 +01:00
|
|
|
|
|
|
|
case *btcutil.AddressScriptHash:
|
2014-04-20 22:51:04 +02:00
|
|
|
lookups.scriptHashes[*a.Hash160()] = struct{}{}
|
2014-03-21 14:25:00 +01:00
|
|
|
|
|
|
|
case *btcutil.AddressPubKey:
|
|
|
|
pubkeyBytes := a.ScriptAddress()
|
|
|
|
switch len(pubkeyBytes) {
|
|
|
|
case 33: // Compressed
|
|
|
|
copy(compressedPubkey[:], pubkeyBytes)
|
|
|
|
lookups.compressedPubkeys[compressedPubkey] = struct{}{}
|
|
|
|
|
|
|
|
case 65: // Uncompressed
|
|
|
|
copy(uncompressedPubkey[:], pubkeyBytes)
|
|
|
|
lookups.uncompressedPubkeys[uncompressedPubkey] = struct{}{}
|
|
|
|
|
|
|
|
default:
|
|
|
|
jsonErr := btcjson.Error{
|
|
|
|
Code: btcjson.ErrInvalidAddressOrKey.Code,
|
|
|
|
Message: "Pubkey " + addrStr + " is of unknown length",
|
|
|
|
}
|
|
|
|
return nil, &jsonErr
|
|
|
|
}
|
|
|
|
|
|
|
|
default:
|
|
|
|
// A new address type must have been added. Use encoded
|
|
|
|
// payment address string as a fallback until a fast path
|
|
|
|
// is added.
|
|
|
|
lookups.fallbacks[addrStr] = struct{}{}
|
|
|
|
}
|
|
|
|
}
|
2014-04-11 03:41:36 +02:00
|
|
|
for _, outpoint := range outpoints {
|
2014-03-21 21:43:31 +01:00
|
|
|
lookups.unspent[*outpoint] = struct{}{}
|
|
|
|
}
|
2014-03-21 14:25:00 +01:00
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
minBlock := int64(cmd.BeginBlock)
|
|
|
|
maxBlock := int64(cmd.EndBlock)
|
2014-07-12 16:29:43 +02:00
|
|
|
lastBlock := int64(-1) // -1 indicates no blocks scanned
|
2014-02-08 23:15:17 +01:00
|
|
|
|
2014-03-24 19:29:50 +01:00
|
|
|
// A ticker is created to wait at least 10 seconds before notifying the
|
|
|
|
// websocket client of the current progress completed by the rescan.
|
|
|
|
ticker := time.NewTicker(10 * time.Second)
|
|
|
|
defer ticker.Stop()
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
// FetchHeightRange may not return a complete list of block shas for
|
|
|
|
// the given range, so fetch range as many times as necessary.
|
|
|
|
db := wsc.server.server.db
|
2014-03-24 19:29:50 +01:00
|
|
|
for minBlock < maxBlock {
|
2014-02-19 00:23:33 +01:00
|
|
|
hashList, err := db.FetchHeightRange(minBlock, maxBlock)
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Error looking up block range: %v", err)
|
|
|
|
return nil, &btcjson.ErrDatabase
|
|
|
|
}
|
|
|
|
if len(hashList) == 0 {
|
|
|
|
break
|
|
|
|
}
|
|
|
|
|
|
|
|
for i := range hashList {
|
|
|
|
blk, err := db.FetchBlockBySha(&hashList[i])
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Error looking up block sha: %v", err)
|
|
|
|
return nil, &btcjson.ErrDatabase
|
|
|
|
}
|
|
|
|
|
|
|
|
// A select statement is used to stop rescans if the
|
|
|
|
// client requesting the rescan has disconnected.
|
|
|
|
select {
|
|
|
|
case <-wsc.quit:
|
2014-03-24 19:29:50 +01:00
|
|
|
rpcsLog.Debugf("Stopped rescan at height %v "+
|
|
|
|
"for disconnected client", blk.Height())
|
2014-02-19 00:23:33 +01:00
|
|
|
return nil, nil
|
|
|
|
default:
|
2014-03-21 14:25:00 +01:00
|
|
|
rescanBlock(wsc, &lookups, blk)
|
2014-02-08 23:15:17 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
|
2014-03-24 19:29:50 +01:00
|
|
|
// Periodically notify the client of the progress
|
|
|
|
// completed. Continue with next block if no progress
|
|
|
|
// notification is needed yet.
|
|
|
|
select {
|
|
|
|
case <-ticker.C: // fallthrough
|
|
|
|
default:
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
n := btcws.NewRescanProgressNtfn(int32(blk.Height()))
|
|
|
|
mn, err := n.MarshalJSON()
|
|
|
|
if err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal rescan "+
|
|
|
|
"progress notification: %v", err)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
|
|
|
if err = wsc.QueueNotification(mn); err == ErrClientQuit {
|
|
|
|
// Finished if the client disconnected.
|
|
|
|
rpcsLog.Debugf("Stopped rescan at height %v "+
|
|
|
|
"for disconnected client", blk.Height())
|
|
|
|
return nil, nil
|
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
}
|
2014-03-24 19:29:50 +01:00
|
|
|
|
|
|
|
minBlock += int64(len(hashList))
|
2014-07-12 16:29:43 +02:00
|
|
|
lastBlock = minBlock - 1
|
2014-02-08 23:15:17 +01:00
|
|
|
}
|
2014-02-19 00:23:33 +01:00
|
|
|
|
2014-06-16 16:57:20 +02:00
|
|
|
// Notify websocket client of the finished rescan. Due to how btcd
|
|
|
|
// asynchronously queues notifications to not block calling code,
|
|
|
|
// there is no guarantee that any of the notifications created during
|
|
|
|
// rescan (such as rescanprogress, recvtx and redeemingtx) will be
|
|
|
|
// received before the rescan RPC returns. Therefore, another method
|
|
|
|
// is needed to safely inform clients that all rescan notifiations have
|
|
|
|
// been sent.
|
2014-07-12 16:29:43 +02:00
|
|
|
n := btcws.NewRescanFinishedNtfn(int32(lastBlock))
|
2014-06-16 16:57:20 +02:00
|
|
|
if mn, err := n.MarshalJSON(); err != nil {
|
|
|
|
rpcsLog.Errorf("Failed to marshal rescan finished "+
|
|
|
|
"notification: %v", err)
|
|
|
|
} else {
|
|
|
|
// The rescan is finished, so we don't care whether the client
|
|
|
|
// has disconnected at this point, so discard error.
|
|
|
|
_ = wsc.QueueNotification(mn)
|
|
|
|
}
|
|
|
|
|
2014-02-19 00:23:33 +01:00
|
|
|
rpcsLog.Info("Finished rescan")
|
|
|
|
return nil, nil
|
2014-02-08 23:15:17 +01:00
|
|
|
}
|