123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508250925102511251225132514251525162517251825192520252125222523252425252526252725282529253025312532253325342535253625372538253925402541254225432544254525462547254825492550255125522553255425552556255725582559256025612562256325642565256625672568256925702571257225732574257525762577257825792580258125822583258425852586258725882589259025912592259325942595259625972598259926002601260226032604260526062607260826092610261126122613261426152616 |
- // Copyright (c) 2009-2010 Satoshi Nakamoto
- // Copyright (c) 2009-2015 The Bitcoin Core developers
- // Distributed under the MIT software license, see the accompanying
- // file COPYING or http://www.opensource.org/licenses/mit-license.php.
-
- #if defined(HAVE_CONFIG_H)
- #include "config/bitcoin-config.h"
- #endif
-
- #include "net.h"
-
- #include "addrman.h"
- #include "chainparams.h"
- #include "clientversion.h"
- #include "consensus/consensus.h"
- #include "crypto/common.h"
- #include "hash.h"
- #include "primitives/transaction.h"
- #include "scheduler.h"
- #include "ui_interface.h"
- #include "utilstrencodings.h"
-
- #ifdef WIN32
- #include <string.h>
- #else
- #include <fcntl.h>
- #endif
-
- #ifdef USE_UPNP
- #include <miniupnpc/miniupnpc.h>
- #include <miniupnpc/miniwget.h>
- #include <miniupnpc/upnpcommands.h>
- #include <miniupnpc/upnperrors.h>
- #endif
-
- #include <boost/filesystem.hpp>
- #include <boost/thread.hpp>
-
- // Dump addresses to peers.dat every 15 minutes (900s)
- #define DUMP_ADDRESSES_INTERVAL 900
-
- #if !defined(HAVE_MSG_NOSIGNAL) && !defined(MSG_NOSIGNAL)
- #define MSG_NOSIGNAL 0
- #endif
-
- // Fix for ancient MinGW versions, that don't have defined these in ws2tcpip.h.
- // Todo: Can be removed when our pull-tester is upgraded to a modern MinGW version.
- #ifdef WIN32
- #ifndef PROTECTION_LEVEL_UNRESTRICTED
- #define PROTECTION_LEVEL_UNRESTRICTED 10
- #endif
- #ifndef IPV6_PROTECTION_LEVEL
- #define IPV6_PROTECTION_LEVEL 23
- #endif
- #endif
-
- using namespace std;
-
- namespace {
- const int MAX_OUTBOUND_CONNECTIONS = 8;
-
- struct ListenSocket {
- SOCKET socket;
- bool whitelisted;
-
- ListenSocket(SOCKET socket, bool whitelisted) : socket(socket), whitelisted(whitelisted) {}
- };
- }
-
- //
- // Global state variables
- //
- bool fDiscover = true;
- bool fListen = true;
- uint64_t nLocalServices = NODE_NETWORK;
- CCriticalSection cs_mapLocalHost;
- map<CNetAddr, LocalServiceInfo> mapLocalHost;
- static bool vfReachable[NET_MAX] = {};
- static bool vfLimited[NET_MAX] = {};
- static CNode* pnodeLocalHost = NULL;
- uint64_t nLocalHostNonce = 0;
- static std::vector<ListenSocket> vhListenSocket;
- CAddrMan addrman;
- int nMaxConnections = DEFAULT_MAX_PEER_CONNECTIONS;
- bool fAddressesInitialized = false;
- std::string strSubVersion;
-
- vector<CNode*> vNodes;
- CCriticalSection cs_vNodes;
- map<CInv, CDataStream> mapRelay;
- deque<pair<int64_t, CInv> > vRelayExpiration;
- CCriticalSection cs_mapRelay;
- limitedmap<CInv, int64_t> mapAlreadyAskedFor(MAX_INV_SZ);
-
- static deque<string> vOneShots;
- CCriticalSection cs_vOneShots;
-
- set<CNetAddr> setservAddNodeAddresses;
- CCriticalSection cs_setservAddNodeAddresses;
-
- vector<std::string> vAddedNodes;
- CCriticalSection cs_vAddedNodes;
-
- NodeId nLastNodeId = 0;
- CCriticalSection cs_nLastNodeId;
-
- static CSemaphore *semOutbound = NULL;
- boost::condition_variable messageHandlerCondition;
-
- // Signals for message handling
- static CNodeSignals g_signals;
- CNodeSignals& GetNodeSignals() { return g_signals; }
-
- void AddOneShot(const std::string& strDest)
- {
- LOCK(cs_vOneShots);
- vOneShots.push_back(strDest);
- }
-
- unsigned short GetListenPort()
- {
- return (unsigned short)(GetArg("-port", Params().GetDefaultPort()));
- }
-
- // find 'best' local address for a particular peer
- bool GetLocal(CService& addr, const CNetAddr *paddrPeer)
- {
- if (!fListen)
- return false;
-
- int nBestScore = -1;
- int nBestReachability = -1;
- {
- LOCK(cs_mapLocalHost);
- for (map<CNetAddr, LocalServiceInfo>::iterator it = mapLocalHost.begin(); it != mapLocalHost.end(); it++)
- {
- int nScore = (*it).second.nScore;
- int nReachability = (*it).first.GetReachabilityFrom(paddrPeer);
- if (nReachability > nBestReachability || (nReachability == nBestReachability && nScore > nBestScore))
- {
- addr = CService((*it).first, (*it).second.nPort);
- nBestReachability = nReachability;
- nBestScore = nScore;
- }
- }
- }
- return nBestScore >= 0;
- }
-
- //! Convert the pnSeeds6 array into usable address objects.
- static std::vector<CAddress> convertSeed6(const std::vector<SeedSpec6> &vSeedsIn)
- {
- // It'll only connect to one or two seed nodes because once it connects,
- // it'll get a pile of addresses with newer timestamps.
- // Seed nodes are given a random 'last seen time' of between one and two
- // weeks ago.
- const int64_t nOneWeek = 7*24*60*60;
- std::vector<CAddress> vSeedsOut;
- vSeedsOut.reserve(vSeedsIn.size());
- for (std::vector<SeedSpec6>::const_iterator i(vSeedsIn.begin()); i != vSeedsIn.end(); ++i)
- {
- struct in6_addr ip;
- memcpy(&ip, i->addr, sizeof(ip));
- CAddress addr(CService(ip, i->port));
- addr.nTime = GetTime() - GetRand(nOneWeek) - nOneWeek;
- vSeedsOut.push_back(addr);
- }
- return vSeedsOut;
- }
-
- // get best local address for a particular peer as a CAddress
- // Otherwise, return the unroutable 0.0.0.0 but filled in with
- // the normal parameters, since the IP may be changed to a useful
- // one by discovery.
- CAddress GetLocalAddress(const CNetAddr *paddrPeer)
- {
- CAddress ret(CService("0.0.0.0",GetListenPort()),0);
- CService addr;
- if (GetLocal(addr, paddrPeer))
- {
- ret = CAddress(addr);
- }
- ret.nServices = nLocalServices;
- ret.nTime = GetAdjustedTime();
- return ret;
- }
-
- int GetnScore(const CService& addr)
- {
- LOCK(cs_mapLocalHost);
- if (mapLocalHost.count(addr) == LOCAL_NONE)
- return 0;
- return mapLocalHost[addr].nScore;
- }
-
- // Is our peer's addrLocal potentially useful as an external IP source?
- bool IsPeerAddrLocalGood(CNode *pnode)
- {
- return fDiscover && pnode->addr.IsRoutable() && pnode->addrLocal.IsRoutable() &&
- !IsLimited(pnode->addrLocal.GetNetwork());
- }
-
- // pushes our own address to a peer
- void AdvertizeLocal(CNode *pnode)
- {
- if (fListen && pnode->fSuccessfullyConnected)
- {
- CAddress addrLocal = GetLocalAddress(&pnode->addr);
- // If discovery is enabled, sometimes give our peer the address it
- // tells us that it sees us as in case it has a better idea of our
- // address than we do.
- if (IsPeerAddrLocalGood(pnode) && (!addrLocal.IsRoutable() ||
- GetRand((GetnScore(addrLocal) > LOCAL_MANUAL) ? 8:2) == 0))
- {
- addrLocal.SetIP(pnode->addrLocal);
- }
- if (addrLocal.IsRoutable())
- {
- LogPrintf("AdvertizeLocal: advertizing address %s\n", addrLocal.ToString());
- pnode->PushAddress(addrLocal);
- }
- }
- }
-
- void SetReachable(enum Network net, bool fFlag)
- {
- LOCK(cs_mapLocalHost);
- vfReachable[net] = fFlag;
- if (net == NET_IPV6 && fFlag)
- vfReachable[NET_IPV4] = true;
- }
-
- // learn a new local address
- bool AddLocal(const CService& addr, int nScore)
- {
- if (!addr.IsRoutable())
- return false;
-
- if (!fDiscover && nScore < LOCAL_MANUAL)
- return false;
-
- if (IsLimited(addr))
- return false;
-
- LogPrintf("AddLocal(%s,%i)\n", addr.ToString(), nScore);
-
- {
- LOCK(cs_mapLocalHost);
- bool fAlready = mapLocalHost.count(addr) > 0;
- LocalServiceInfo &info = mapLocalHost[addr];
- if (!fAlready || nScore >= info.nScore) {
- info.nScore = nScore + (fAlready ? 1 : 0);
- info.nPort = addr.GetPort();
- }
- SetReachable(addr.GetNetwork());
- }
-
- return true;
- }
-
- bool AddLocal(const CNetAddr &addr, int nScore)
- {
- return AddLocal(CService(addr, GetListenPort()), nScore);
- }
-
- bool RemoveLocal(const CService& addr)
- {
- LOCK(cs_mapLocalHost);
- LogPrintf("RemoveLocal(%s)\n", addr.ToString());
- mapLocalHost.erase(addr);
- return true;
- }
-
- /** Make a particular network entirely off-limits (no automatic connects to it) */
- void SetLimited(enum Network net, bool fLimited)
- {
- if (net == NET_UNROUTABLE)
- return;
- LOCK(cs_mapLocalHost);
- vfLimited[net] = fLimited;
- }
-
- bool IsLimited(enum Network net)
- {
- LOCK(cs_mapLocalHost);
- return vfLimited[net];
- }
-
- bool IsLimited(const CNetAddr &addr)
- {
- return IsLimited(addr.GetNetwork());
- }
-
- /** vote for a local address */
- bool SeenLocal(const CService& addr)
- {
- {
- LOCK(cs_mapLocalHost);
- if (mapLocalHost.count(addr) == 0)
- return false;
- mapLocalHost[addr].nScore++;
- }
- return true;
- }
-
-
- /** check whether a given address is potentially local */
- bool IsLocal(const CService& addr)
- {
- LOCK(cs_mapLocalHost);
- return mapLocalHost.count(addr) > 0;
- }
-
- /** check whether a given network is one we can probably connect to */
- bool IsReachable(enum Network net)
- {
- LOCK(cs_mapLocalHost);
- return vfReachable[net] && !vfLimited[net];
- }
-
- /** check whether a given address is in a network we can probably connect to */
- bool IsReachable(const CNetAddr& addr)
- {
- enum Network net = addr.GetNetwork();
- return IsReachable(net);
- }
-
- void AddressCurrentlyConnected(const CService& addr)
- {
- addrman.Connected(addr);
- }
-
-
- uint64_t CNode::nTotalBytesRecv = 0;
- uint64_t CNode::nTotalBytesSent = 0;
- CCriticalSection CNode::cs_totalBytesRecv;
- CCriticalSection CNode::cs_totalBytesSent;
-
- uint64_t CNode::nMaxOutboundLimit = 0;
- uint64_t CNode::nMaxOutboundTotalBytesSentInCycle = 0;
- uint64_t CNode::nMaxOutboundTimeframe = 60*60*24; //1 day
- uint64_t CNode::nMaxOutboundCycleStartTime = 0;
-
- CNode* FindNode(const CNetAddr& ip)
- {
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodes)
- if ((CNetAddr)pnode->addr == ip)
- return (pnode);
- return NULL;
- }
-
- CNode* FindNode(const CSubNet& subNet)
- {
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodes)
- if (subNet.Match((CNetAddr)pnode->addr))
- return (pnode);
- return NULL;
- }
-
- CNode* FindNode(const std::string& addrName)
- {
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodes)
- if (pnode->addrName == addrName)
- return (pnode);
- return NULL;
- }
-
- CNode* FindNode(const CService& addr)
- {
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodes)
- if ((CService)pnode->addr == addr)
- return (pnode);
- return NULL;
- }
-
- CNode* ConnectNode(CAddress addrConnect, const char *pszDest)
- {
- if (pszDest == NULL) {
- if (IsLocal(addrConnect))
- return NULL;
-
- // Look for an existing connection
- CNode* pnode = FindNode((CService)addrConnect);
- if (pnode)
- {
- pnode->AddRef();
- return pnode;
- }
- }
-
- /// debug print
- LogPrint("net", "trying connection %s lastseen=%.1fhrs\n",
- pszDest ? pszDest : addrConnect.ToString(),
- pszDest ? 0.0 : (double)(GetAdjustedTime() - addrConnect.nTime)/3600.0);
-
- // Connect
- SOCKET hSocket;
- bool proxyConnectionFailed = false;
- if (pszDest ? ConnectSocketByName(addrConnect, hSocket, pszDest, Params().GetDefaultPort(), nConnectTimeout, &proxyConnectionFailed) :
- ConnectSocket(addrConnect, hSocket, nConnectTimeout, &proxyConnectionFailed))
- {
- if (!IsSelectableSocket(hSocket)) {
- LogPrintf("Cannot create connection: non-selectable socket created (fd >= FD_SETSIZE ?)\n");
- CloseSocket(hSocket);
- return NULL;
- }
-
- addrman.Attempt(addrConnect);
-
- // Add node
- CNode* pnode = new CNode(hSocket, addrConnect, pszDest ? pszDest : "", false);
- pnode->AddRef();
-
- {
- LOCK(cs_vNodes);
- vNodes.push_back(pnode);
- }
-
- pnode->nTimeConnected = GetTime();
-
- return pnode;
- } else if (!proxyConnectionFailed) {
- // If connecting to the node failed, and failure is not caused by a problem connecting to
- // the proxy, mark this as an attempt.
- addrman.Attempt(addrConnect);
- }
-
- return NULL;
- }
-
- void CNode::CloseSocketDisconnect()
- {
- fDisconnect = true;
- if (hSocket != INVALID_SOCKET)
- {
- LogPrint("net", "disconnecting peer=%d\n", id);
- CloseSocket(hSocket);
- }
-
- // in case this fails, we'll empty the recv buffer when the CNode is deleted
- TRY_LOCK(cs_vRecvMsg, lockRecv);
- if (lockRecv)
- vRecvMsg.clear();
- }
-
- void CNode::PushVersion()
- {
- int nBestHeight = g_signals.GetHeight().get_value_or(0);
-
- int64_t nTime = (fInbound ? GetAdjustedTime() : GetTime());
- CAddress addrYou = (addr.IsRoutable() && !IsProxy(addr) ? addr : CAddress(CService("0.0.0.0",0)));
- CAddress addrMe = GetLocalAddress(&addr);
- GetRandBytes((unsigned char*)&nLocalHostNonce, sizeof(nLocalHostNonce));
- if (fLogIPs)
- LogPrint("net", "send version message: version %d, blocks=%d, us=%s, them=%s, peer=%d\n", PROTOCOL_VERSION, nBestHeight, addrMe.ToString(), addrYou.ToString(), id);
- else
- LogPrint("net", "send version message: version %d, blocks=%d, us=%s, peer=%d\n", PROTOCOL_VERSION, nBestHeight, addrMe.ToString(), id);
- PushMessage("version", PROTOCOL_VERSION, nLocalServices, nTime, addrYou, addrMe,
- nLocalHostNonce, strSubVersion, nBestHeight, !GetBoolArg("-blocksonly", DEFAULT_BLOCKSONLY));
- }
-
-
-
-
-
- banmap_t CNode::setBanned;
- CCriticalSection CNode::cs_setBanned;
- bool CNode::setBannedIsDirty;
-
- void CNode::ClearBanned()
- {
- LOCK(cs_setBanned);
- setBanned.clear();
- setBannedIsDirty = true;
- }
-
- bool CNode::IsBanned(CNetAddr ip)
- {
- bool fResult = false;
- {
- LOCK(cs_setBanned);
- for (banmap_t::iterator it = setBanned.begin(); it != setBanned.end(); it++)
- {
- CSubNet subNet = (*it).first;
- CBanEntry banEntry = (*it).second;
-
- if(subNet.Match(ip) && GetTime() < banEntry.nBanUntil)
- fResult = true;
- }
- }
- return fResult;
- }
-
- bool CNode::IsBanned(CSubNet subnet)
- {
- bool fResult = false;
- {
- LOCK(cs_setBanned);
- banmap_t::iterator i = setBanned.find(subnet);
- if (i != setBanned.end())
- {
- CBanEntry banEntry = (*i).second;
- if (GetTime() < banEntry.nBanUntil)
- fResult = true;
- }
- }
- return fResult;
- }
-
- void CNode::Ban(const CNetAddr& addr, const BanReason &banReason, int64_t bantimeoffset, bool sinceUnixEpoch) {
- CSubNet subNet(addr);
- Ban(subNet, banReason, bantimeoffset, sinceUnixEpoch);
- }
-
- void CNode::Ban(const CSubNet& subNet, const BanReason &banReason, int64_t bantimeoffset, bool sinceUnixEpoch) {
- CBanEntry banEntry(GetTime());
- banEntry.banReason = banReason;
- if (bantimeoffset <= 0)
- {
- bantimeoffset = GetArg("-bantime", DEFAULT_MISBEHAVING_BANTIME);
- sinceUnixEpoch = false;
- }
- banEntry.nBanUntil = (sinceUnixEpoch ? 0 : GetTime() )+bantimeoffset;
-
- LOCK(cs_setBanned);
- if (setBanned[subNet].nBanUntil < banEntry.nBanUntil)
- setBanned[subNet] = banEntry;
-
- setBannedIsDirty = true;
- }
-
- bool CNode::Unban(const CNetAddr &addr) {
- CSubNet subNet(addr);
- return Unban(subNet);
- }
-
- bool CNode::Unban(const CSubNet &subNet) {
- LOCK(cs_setBanned);
- if (setBanned.erase(subNet))
- {
- setBannedIsDirty = true;
- return true;
- }
- return false;
- }
-
- void CNode::GetBanned(banmap_t &banMap)
- {
- LOCK(cs_setBanned);
- banMap = setBanned; //create a thread safe copy
- }
-
- void CNode::SetBanned(const banmap_t &banMap)
- {
- LOCK(cs_setBanned);
- setBanned = banMap;
- setBannedIsDirty = true;
- }
-
- void CNode::SweepBanned()
- {
- int64_t now = GetTime();
-
- LOCK(cs_setBanned);
- banmap_t::iterator it = setBanned.begin();
- while(it != setBanned.end())
- {
- CBanEntry banEntry = (*it).second;
- if(now > banEntry.nBanUntil)
- {
- setBanned.erase(it++);
- setBannedIsDirty = true;
- }
- else
- ++it;
- }
- }
-
- bool CNode::BannedSetIsDirty()
- {
- LOCK(cs_setBanned);
- return setBannedIsDirty;
- }
-
- void CNode::SetBannedSetDirty(bool dirty)
- {
- LOCK(cs_setBanned); //reuse setBanned lock for the isDirty flag
- setBannedIsDirty = dirty;
- }
-
-
- std::vector<CSubNet> CNode::vWhitelistedRange;
- CCriticalSection CNode::cs_vWhitelistedRange;
-
- bool CNode::IsWhitelistedRange(const CNetAddr &addr) {
- LOCK(cs_vWhitelistedRange);
- BOOST_FOREACH(const CSubNet& subnet, vWhitelistedRange) {
- if (subnet.Match(addr))
- return true;
- }
- return false;
- }
-
- void CNode::AddWhitelistedRange(const CSubNet &subnet) {
- LOCK(cs_vWhitelistedRange);
- vWhitelistedRange.push_back(subnet);
- }
-
- #undef X
- #define X(name) stats.name = name
- void CNode::copyStats(CNodeStats &stats)
- {
- stats.nodeid = this->GetId();
- X(nServices);
- X(fRelayTxes);
- X(nLastSend);
- X(nLastRecv);
- X(nTimeConnected);
- X(nTimeOffset);
- X(addrName);
- X(nVersion);
- X(cleanSubVer);
- X(fInbound);
- X(nStartingHeight);
- X(nSendBytes);
- X(nRecvBytes);
- X(fWhitelisted);
-
- // It is common for nodes with good ping times to suddenly become lagged,
- // due to a new block arriving or other large transfer.
- // Merely reporting pingtime might fool the caller into thinking the node was still responsive,
- // since pingtime does not update until the ping is complete, which might take a while.
- // So, if a ping is taking an unusually long time in flight,
- // the caller can immediately detect that this is happening.
- int64_t nPingUsecWait = 0;
- if ((0 != nPingNonceSent) && (0 != nPingUsecStart)) {
- nPingUsecWait = GetTimeMicros() - nPingUsecStart;
- }
-
- // Raw ping time is in microseconds, but show it to user as whole seconds (Bitcoin users should be well used to small numbers with many decimal places by now :)
- stats.dPingTime = (((double)nPingUsecTime) / 1e6);
- stats.dPingMin = (((double)nMinPingUsecTime) / 1e6);
- stats.dPingWait = (((double)nPingUsecWait) / 1e6);
-
- // Leave string empty if addrLocal invalid (not filled in yet)
- stats.addrLocal = addrLocal.IsValid() ? addrLocal.ToString() : "";
- }
- #undef X
-
- // requires LOCK(cs_vRecvMsg)
- bool CNode::ReceiveMsgBytes(const char *pch, unsigned int nBytes)
- {
- while (nBytes > 0) {
-
- // get current incomplete message, or create a new one
- if (vRecvMsg.empty() ||
- vRecvMsg.back().complete())
- vRecvMsg.push_back(CNetMessage(Params().MessageStart(), SER_NETWORK, nRecvVersion));
-
- CNetMessage& msg = vRecvMsg.back();
-
- // absorb network data
- int handled;
- if (!msg.in_data)
- handled = msg.readHeader(pch, nBytes);
- else
- handled = msg.readData(pch, nBytes);
-
- if (handled < 0)
- return false;
-
- if (msg.in_data && msg.hdr.nMessageSize > MAX_PROTOCOL_MESSAGE_LENGTH) {
- LogPrint("net", "Oversized message from peer=%i, disconnecting\n", GetId());
- return false;
- }
-
- pch += handled;
- nBytes -= handled;
-
- if (msg.complete()) {
- msg.nTime = GetTimeMicros();
- messageHandlerCondition.notify_one();
- }
- }
-
- return true;
- }
-
- int CNetMessage::readHeader(const char *pch, unsigned int nBytes)
- {
- // copy data to temporary parsing buffer
- unsigned int nRemaining = 24 - nHdrPos;
- unsigned int nCopy = std::min(nRemaining, nBytes);
-
- memcpy(&hdrbuf[nHdrPos], pch, nCopy);
- nHdrPos += nCopy;
-
- // if header incomplete, exit
- if (nHdrPos < 24)
- return nCopy;
-
- // deserialize to CMessageHeader
- try {
- hdrbuf >> hdr;
- }
- catch (const std::exception&) {
- return -1;
- }
-
- // reject messages larger than MAX_SIZE
- if (hdr.nMessageSize > MAX_SIZE)
- return -1;
-
- // switch state to reading message data
- in_data = true;
-
- return nCopy;
- }
-
- int CNetMessage::readData(const char *pch, unsigned int nBytes)
- {
- unsigned int nRemaining = hdr.nMessageSize - nDataPos;
- unsigned int nCopy = std::min(nRemaining, nBytes);
-
- if (vRecv.size() < nDataPos + nCopy) {
- // Allocate up to 256 KiB ahead, but never more than the total message size.
- vRecv.resize(std::min(hdr.nMessageSize, nDataPos + nCopy + 256 * 1024));
- }
-
- memcpy(&vRecv[nDataPos], pch, nCopy);
- nDataPos += nCopy;
-
- return nCopy;
- }
-
-
-
-
-
-
-
-
-
- // requires LOCK(cs_vSend)
- void SocketSendData(CNode *pnode)
- {
- std::deque<CSerializeData>::iterator it = pnode->vSendMsg.begin();
-
- while (it != pnode->vSendMsg.end()) {
- const CSerializeData &data = *it;
- assert(data.size() > pnode->nSendOffset);
- int nBytes = send(pnode->hSocket, &data[pnode->nSendOffset], data.size() - pnode->nSendOffset, MSG_NOSIGNAL | MSG_DONTWAIT);
- if (nBytes > 0) {
- pnode->nLastSend = GetTime();
- pnode->nSendBytes += nBytes;
- pnode->nSendOffset += nBytes;
- pnode->RecordBytesSent(nBytes);
- if (pnode->nSendOffset == data.size()) {
- pnode->nSendOffset = 0;
- pnode->nSendSize -= data.size();
- it++;
- } else {
- // could not send full message; stop sending more
- break;
- }
- } else {
- if (nBytes < 0) {
- // error
- int nErr = WSAGetLastError();
- if (nErr != WSAEWOULDBLOCK && nErr != WSAEMSGSIZE && nErr != WSAEINTR && nErr != WSAEINPROGRESS)
- {
- LogPrintf("socket send error %s\n", NetworkErrorString(nErr));
- pnode->CloseSocketDisconnect();
- }
- }
- // couldn't send anything at all
- break;
- }
- }
-
- if (it == pnode->vSendMsg.end()) {
- assert(pnode->nSendOffset == 0);
- assert(pnode->nSendSize == 0);
- }
- pnode->vSendMsg.erase(pnode->vSendMsg.begin(), it);
- }
-
- static list<CNode*> vNodesDisconnected;
-
- class CNodeRef {
- public:
- CNodeRef(CNode *pnode) : _pnode(pnode) {
- LOCK(cs_vNodes);
- _pnode->AddRef();
- }
-
- ~CNodeRef() {
- LOCK(cs_vNodes);
- _pnode->Release();
- }
-
- CNode& operator *() const {return *_pnode;};
- CNode* operator ->() const {return _pnode;};
-
- CNodeRef& operator =(const CNodeRef& other)
- {
- if (this != &other) {
- LOCK(cs_vNodes);
-
- _pnode->Release();
- _pnode = other._pnode;
- _pnode->AddRef();
- }
- return *this;
- }
-
- CNodeRef(const CNodeRef& other):
- _pnode(other._pnode)
- {
- LOCK(cs_vNodes);
- _pnode->AddRef();
- }
- private:
- CNode *_pnode;
- };
-
- static bool ReverseCompareNodeMinPingTime(const CNodeRef &a, const CNodeRef &b)
- {
- return a->nMinPingUsecTime > b->nMinPingUsecTime;
- }
-
- static bool ReverseCompareNodeTimeConnected(const CNodeRef &a, const CNodeRef &b)
- {
- return a->nTimeConnected > b->nTimeConnected;
- }
-
- class CompareNetGroupKeyed
- {
- std::vector<unsigned char> vchSecretKey;
- public:
- CompareNetGroupKeyed()
- {
- vchSecretKey.resize(32, 0);
- GetRandBytes(vchSecretKey.data(), vchSecretKey.size());
- }
-
- bool operator()(const CNodeRef &a, const CNodeRef &b)
- {
- std::vector<unsigned char> vchGroupA, vchGroupB;
- CSHA256 hashA, hashB;
- std::vector<unsigned char> vchA(32), vchB(32);
-
- vchGroupA = a->addr.GetGroup();
- vchGroupB = b->addr.GetGroup();
-
- hashA.Write(begin_ptr(vchGroupA), vchGroupA.size());
- hashB.Write(begin_ptr(vchGroupB), vchGroupB.size());
-
- hashA.Write(begin_ptr(vchSecretKey), vchSecretKey.size());
- hashB.Write(begin_ptr(vchSecretKey), vchSecretKey.size());
-
- hashA.Finalize(begin_ptr(vchA));
- hashB.Finalize(begin_ptr(vchB));
-
- return vchA < vchB;
- }
- };
-
- static bool AttemptToEvictConnection(bool fPreferNewConnection) {
- std::vector<CNodeRef> vEvictionCandidates;
- {
- LOCK(cs_vNodes);
-
- BOOST_FOREACH(CNode *node, vNodes) {
- if (node->fWhitelisted)
- continue;
- if (!node->fInbound)
- continue;
- if (node->fDisconnect)
- continue;
- if (node->addr.IsLocal())
- continue;
- vEvictionCandidates.push_back(CNodeRef(node));
- }
- }
-
- if (vEvictionCandidates.empty()) return false;
-
- // Protect connections with certain characteristics
-
- // Deterministically select 4 peers to protect by netgroup.
- // An attacker cannot predict which netgroups will be protected.
- static CompareNetGroupKeyed comparerNetGroupKeyed;
- std::sort(vEvictionCandidates.begin(), vEvictionCandidates.end(), comparerNetGroupKeyed);
- vEvictionCandidates.erase(vEvictionCandidates.end() - std::min(4, static_cast<int>(vEvictionCandidates.size())), vEvictionCandidates.end());
-
- if (vEvictionCandidates.empty()) return false;
-
- // Protect the 8 nodes with the best ping times.
- // An attacker cannot manipulate this metric without physically moving nodes closer to the target.
- std::sort(vEvictionCandidates.begin(), vEvictionCandidates.end(), ReverseCompareNodeMinPingTime);
- vEvictionCandidates.erase(vEvictionCandidates.end() - std::min(8, static_cast<int>(vEvictionCandidates.size())), vEvictionCandidates.end());
-
- if (vEvictionCandidates.empty()) return false;
-
- // Protect the half of the remaining nodes which have been connected the longest.
- // This replicates the existing implicit behavior.
- std::sort(vEvictionCandidates.begin(), vEvictionCandidates.end(), ReverseCompareNodeTimeConnected);
- vEvictionCandidates.erase(vEvictionCandidates.end() - static_cast<int>(vEvictionCandidates.size() / 2), vEvictionCandidates.end());
-
- if (vEvictionCandidates.empty()) return false;
-
- // Identify the network group with the most connections
- std::vector<unsigned char> naMostConnections;
- unsigned int nMostConnections = 0;
- std::map<std::vector<unsigned char>, std::vector<CNodeRef> > mapAddrCounts;
- BOOST_FOREACH(const CNodeRef &node, vEvictionCandidates) {
- mapAddrCounts[node->addr.GetGroup()].push_back(node);
-
- if (mapAddrCounts[node->addr.GetGroup()].size() > nMostConnections) {
- nMostConnections = mapAddrCounts[node->addr.GetGroup()].size();
- naMostConnections = node->addr.GetGroup();
- }
- }
-
- // Reduce to the network group with the most connections
- vEvictionCandidates = mapAddrCounts[naMostConnections];
-
- // Do not disconnect peers if there is only 1 connection from their network group
- if (vEvictionCandidates.size() <= 1)
- // unless we prefer the new connection (for whitelisted peers)
- if (!fPreferNewConnection)
- return false;
-
- // Disconnect the most recent connection from the network group with the most connections
- std::sort(vEvictionCandidates.begin(), vEvictionCandidates.end(), ReverseCompareNodeTimeConnected);
- vEvictionCandidates[0]->fDisconnect = true;
-
- return true;
- }
-
- static void AcceptConnection(const ListenSocket& hListenSocket) {
- struct sockaddr_storage sockaddr;
- socklen_t len = sizeof(sockaddr);
- SOCKET hSocket = accept(hListenSocket.socket, (struct sockaddr*)&sockaddr, &len);
- CAddress addr;
- int nInbound = 0;
- int nMaxInbound = nMaxConnections - MAX_OUTBOUND_CONNECTIONS;
-
- if (hSocket != INVALID_SOCKET)
- if (!addr.SetSockAddr((const struct sockaddr*)&sockaddr))
- LogPrintf("Warning: Unknown socket family\n");
-
- bool whitelisted = hListenSocket.whitelisted || CNode::IsWhitelistedRange(addr);
- {
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodes)
- if (pnode->fInbound)
- nInbound++;
- }
-
- if (hSocket == INVALID_SOCKET)
- {
- int nErr = WSAGetLastError();
- if (nErr != WSAEWOULDBLOCK)
- LogPrintf("socket error accept failed: %s\n", NetworkErrorString(nErr));
- return;
- }
-
- if (!IsSelectableSocket(hSocket))
- {
- LogPrintf("connection from %s dropped: non-selectable socket\n", addr.ToString());
- CloseSocket(hSocket);
- return;
- }
-
- // According to the internet TCP_NODELAY is not carried into accepted sockets
- // on all platforms. Set it again here just to be sure.
- int set = 1;
- #ifdef WIN32
- setsockopt(hSocket, IPPROTO_TCP, TCP_NODELAY, (const char*)&set, sizeof(int));
- #else
- setsockopt(hSocket, IPPROTO_TCP, TCP_NODELAY, (void*)&set, sizeof(int));
- #endif
-
- if (CNode::IsBanned(addr) && !whitelisted)
- {
- LogPrintf("connection from %s dropped (banned)\n", addr.ToString());
- CloseSocket(hSocket);
- return;
- }
-
- if (nInbound >= nMaxInbound)
- {
- if (!AttemptToEvictConnection(whitelisted)) {
- // No connection to evict, disconnect the new connection
- LogPrint("net", "failed to find an eviction candidate - connection dropped (full)\n");
- CloseSocket(hSocket);
- return;
- }
- }
-
- CNode* pnode = new CNode(hSocket, addr, "", true);
- pnode->AddRef();
- pnode->fWhitelisted = whitelisted;
-
- LogPrint("net", "connection from %s accepted\n", addr.ToString());
-
- {
- LOCK(cs_vNodes);
- vNodes.push_back(pnode);
- }
- }
-
- void ThreadSocketHandler()
- {
- unsigned int nPrevNodeCount = 0;
- while (true)
- {
- //
- // Disconnect nodes
- //
- {
- LOCK(cs_vNodes);
- // Disconnect unused nodes
- vector<CNode*> vNodesCopy = vNodes;
- BOOST_FOREACH(CNode* pnode, vNodesCopy)
- {
- if (pnode->fDisconnect ||
- (pnode->GetRefCount() <= 0 && pnode->vRecvMsg.empty() && pnode->nSendSize == 0 && pnode->ssSend.empty()))
- {
- // remove from vNodes
- vNodes.erase(remove(vNodes.begin(), vNodes.end(), pnode), vNodes.end());
-
- // release outbound grant (if any)
- pnode->grantOutbound.Release();
-
- // close socket and cleanup
- pnode->CloseSocketDisconnect();
-
- // hold in disconnected pool until all refs are released
- if (pnode->fNetworkNode || pnode->fInbound)
- pnode->Release();
- vNodesDisconnected.push_back(pnode);
- }
- }
- }
- {
- // Delete disconnected nodes
- list<CNode*> vNodesDisconnectedCopy = vNodesDisconnected;
- BOOST_FOREACH(CNode* pnode, vNodesDisconnectedCopy)
- {
- // wait until threads are done using it
- if (pnode->GetRefCount() <= 0)
- {
- bool fDelete = false;
- {
- TRY_LOCK(pnode->cs_vSend, lockSend);
- if (lockSend)
- {
- TRY_LOCK(pnode->cs_vRecvMsg, lockRecv);
- if (lockRecv)
- {
- TRY_LOCK(pnode->cs_inventory, lockInv);
- if (lockInv)
- fDelete = true;
- }
- }
- }
- if (fDelete)
- {
- vNodesDisconnected.remove(pnode);
- delete pnode;
- }
- }
- }
- }
- if(vNodes.size() != nPrevNodeCount) {
- nPrevNodeCount = vNodes.size();
- uiInterface.NotifyNumConnectionsChanged(nPrevNodeCount);
- }
-
- //
- // Find which sockets have data to receive
- //
- struct timeval timeout;
- timeout.tv_sec = 0;
- timeout.tv_usec = 50000; // frequency to poll pnode->vSend
-
- fd_set fdsetRecv;
- fd_set fdsetSend;
- fd_set fdsetError;
- FD_ZERO(&fdsetRecv);
- FD_ZERO(&fdsetSend);
- FD_ZERO(&fdsetError);
- SOCKET hSocketMax = 0;
- bool have_fds = false;
-
- BOOST_FOREACH(const ListenSocket& hListenSocket, vhListenSocket) {
- FD_SET(hListenSocket.socket, &fdsetRecv);
- hSocketMax = max(hSocketMax, hListenSocket.socket);
- have_fds = true;
- }
-
- {
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodes)
- {
- if (pnode->hSocket == INVALID_SOCKET)
- continue;
- FD_SET(pnode->hSocket, &fdsetError);
- hSocketMax = max(hSocketMax, pnode->hSocket);
- have_fds = true;
-
- // Implement the following logic:
- // * If there is data to send, select() for sending data. As this only
- // happens when optimistic write failed, we choose to first drain the
- // write buffer in this case before receiving more. This avoids
- // needlessly queueing received data, if the remote peer is not themselves
- // receiving data. This means properly utilizing TCP flow control signalling.
- // * Otherwise, if there is no (complete) message in the receive buffer,
- // or there is space left in the buffer, select() for receiving data.
- // * (if neither of the above applies, there is certainly one message
- // in the receiver buffer ready to be processed).
- // Together, that means that at least one of the following is always possible,
- // so we don't deadlock:
- // * We send some data.
- // * We wait for data to be received (and disconnect after timeout).
- // * We process a message in the buffer (message handler thread).
- {
- TRY_LOCK(pnode->cs_vSend, lockSend);
- if (lockSend && !pnode->vSendMsg.empty()) {
- FD_SET(pnode->hSocket, &fdsetSend);
- continue;
- }
- }
- {
- TRY_LOCK(pnode->cs_vRecvMsg, lockRecv);
- if (lockRecv && (
- pnode->vRecvMsg.empty() || !pnode->vRecvMsg.front().complete() ||
- pnode->GetTotalRecvSize() <= ReceiveFloodSize()))
- FD_SET(pnode->hSocket, &fdsetRecv);
- }
- }
- }
-
- int nSelect = select(have_fds ? hSocketMax + 1 : 0,
- &fdsetRecv, &fdsetSend, &fdsetError, &timeout);
- boost::this_thread::interruption_point();
-
- if (nSelect == SOCKET_ERROR)
- {
- if (have_fds)
- {
- int nErr = WSAGetLastError();
- LogPrintf("socket select error %s\n", NetworkErrorString(nErr));
- for (unsigned int i = 0; i <= hSocketMax; i++)
- FD_SET(i, &fdsetRecv);
- }
- FD_ZERO(&fdsetSend);
- FD_ZERO(&fdsetError);
- MilliSleep(timeout.tv_usec/1000);
- }
-
- //
- // Accept new connections
- //
- BOOST_FOREACH(const ListenSocket& hListenSocket, vhListenSocket)
- {
- if (hListenSocket.socket != INVALID_SOCKET && FD_ISSET(hListenSocket.socket, &fdsetRecv))
- {
- AcceptConnection(hListenSocket);
- }
- }
-
- //
- // Service each socket
- //
- vector<CNode*> vNodesCopy;
- {
- LOCK(cs_vNodes);
- vNodesCopy = vNodes;
- BOOST_FOREACH(CNode* pnode, vNodesCopy)
- pnode->AddRef();
- }
- BOOST_FOREACH(CNode* pnode, vNodesCopy)
- {
- boost::this_thread::interruption_point();
-
- //
- // Receive
- //
- if (pnode->hSocket == INVALID_SOCKET)
- continue;
- if (FD_ISSET(pnode->hSocket, &fdsetRecv) || FD_ISSET(pnode->hSocket, &fdsetError))
- {
- TRY_LOCK(pnode->cs_vRecvMsg, lockRecv);
- if (lockRecv)
- {
- {
- // typical socket buffer is 8K-64K
- char pchBuf[0x10000];
- int nBytes = recv(pnode->hSocket, pchBuf, sizeof(pchBuf), MSG_DONTWAIT);
- if (nBytes > 0)
- {
- if (!pnode->ReceiveMsgBytes(pchBuf, nBytes))
- pnode->CloseSocketDisconnect();
- pnode->nLastRecv = GetTime();
- pnode->nRecvBytes += nBytes;
- pnode->RecordBytesRecv(nBytes);
- }
- else if (nBytes == 0)
- {
- // socket closed gracefully
- if (!pnode->fDisconnect)
- LogPrint("net", "socket closed\n");
- pnode->CloseSocketDisconnect();
- }
- else if (nBytes < 0)
- {
- // error
- int nErr = WSAGetLastError();
- if (nErr != WSAEWOULDBLOCK && nErr != WSAEMSGSIZE && nErr != WSAEINTR && nErr != WSAEINPROGRESS)
- {
- if (!pnode->fDisconnect)
- LogPrintf("socket recv error %s\n", NetworkErrorString(nErr));
- pnode->CloseSocketDisconnect();
- }
- }
- }
- }
- }
-
- //
- // Send
- //
- if (pnode->hSocket == INVALID_SOCKET)
- continue;
- if (FD_ISSET(pnode->hSocket, &fdsetSend))
- {
- TRY_LOCK(pnode->cs_vSend, lockSend);
- if (lockSend)
- SocketSendData(pnode);
- }
-
- //
- // Inactivity checking
- //
- int64_t nTime = GetTime();
- if (nTime - pnode->nTimeConnected > 60)
- {
- if (pnode->nLastRecv == 0 || pnode->nLastSend == 0)
- {
- LogPrint("net", "socket no message in first 60 seconds, %d %d from %d\n", pnode->nLastRecv != 0, pnode->nLastSend != 0, pnode->id);
- pnode->fDisconnect = true;
- }
- else if (nTime - pnode->nLastSend > TIMEOUT_INTERVAL)
- {
- LogPrintf("socket sending timeout: %is\n", nTime - pnode->nLastSend);
- pnode->fDisconnect = true;
- }
- else if (nTime - pnode->nLastRecv > (pnode->nVersion > BIP0031_VERSION ? TIMEOUT_INTERVAL : 90*60))
- {
- LogPrintf("socket receive timeout: %is\n", nTime - pnode->nLastRecv);
- pnode->fDisconnect = true;
- }
- else if (pnode->nPingNonceSent && pnode->nPingUsecStart + TIMEOUT_INTERVAL * 1000000 < GetTimeMicros())
- {
- LogPrintf("ping timeout: %fs\n", 0.000001 * (GetTimeMicros() - pnode->nPingUsecStart));
- pnode->fDisconnect = true;
- }
- }
- }
- {
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodesCopy)
- pnode->Release();
- }
- }
- }
-
-
-
-
-
-
-
-
-
- #ifdef USE_UPNP
- void ThreadMapPort()
- {
- std::string port = strprintf("%u", GetListenPort());
- const char * multicastif = 0;
- const char * minissdpdpath = 0;
- struct UPNPDev * devlist = 0;
- char lanaddr[64];
-
- #ifndef UPNPDISCOVER_SUCCESS
- /* miniupnpc 1.5 */
- devlist = upnpDiscover(2000, multicastif, minissdpdpath, 0);
- #elif MINIUPNPC_API_VERSION < 14
- /* miniupnpc 1.6 */
- int error = 0;
- devlist = upnpDiscover(2000, multicastif, minissdpdpath, 0, 0, &error);
- #else
- /* miniupnpc 1.9.20150730 */
- int error = 0;
- devlist = upnpDiscover(2000, multicastif, minissdpdpath, 0, 0, 2, &error);
- #endif
-
- struct UPNPUrls urls;
- struct IGDdatas data;
- int r;
-
- r = UPNP_GetValidIGD(devlist, &urls, &data, lanaddr, sizeof(lanaddr));
- if (r == 1)
- {
- if (fDiscover) {
- char externalIPAddress[40];
- r = UPNP_GetExternalIPAddress(urls.controlURL, data.first.servicetype, externalIPAddress);
- if(r != UPNPCOMMAND_SUCCESS)
- LogPrintf("UPnP: GetExternalIPAddress() returned %d\n", r);
- else
- {
- if(externalIPAddress[0])
- {
- LogPrintf("UPnP: ExternalIPAddress = %s\n", externalIPAddress);
- AddLocal(CNetAddr(externalIPAddress), LOCAL_UPNP);
- }
- else
- LogPrintf("UPnP: GetExternalIPAddress failed.\n");
- }
- }
-
- string strDesc = "Bitcoin " + FormatFullVersion();
-
- try {
- while (true) {
- #ifndef UPNPDISCOVER_SUCCESS
- /* miniupnpc 1.5 */
- r = UPNP_AddPortMapping(urls.controlURL, data.first.servicetype,
- port.c_str(), port.c_str(), lanaddr, strDesc.c_str(), "TCP", 0);
- #else
- /* miniupnpc 1.6 */
- r = UPNP_AddPortMapping(urls.controlURL, data.first.servicetype,
- port.c_str(), port.c_str(), lanaddr, strDesc.c_str(), "TCP", 0, "0");
- #endif
-
- if(r!=UPNPCOMMAND_SUCCESS)
- LogPrintf("AddPortMapping(%s, %s, %s) failed with code %d (%s)\n",
- port, port, lanaddr, r, strupnperror(r));
- else
- LogPrintf("UPnP Port Mapping successful.\n");;
-
- MilliSleep(20*60*1000); // Refresh every 20 minutes
- }
- }
- catch (const boost::thread_interrupted&)
- {
- r = UPNP_DeletePortMapping(urls.controlURL, data.first.servicetype, port.c_str(), "TCP", 0);
- LogPrintf("UPNP_DeletePortMapping() returned: %d\n", r);
- freeUPNPDevlist(devlist); devlist = 0;
- FreeUPNPUrls(&urls);
- throw;
- }
- } else {
- LogPrintf("No valid UPnP IGDs found\n");
- freeUPNPDevlist(devlist); devlist = 0;
- if (r != 0)
- FreeUPNPUrls(&urls);
- }
- }
-
- void MapPort(bool fUseUPnP)
- {
- static boost::thread* upnp_thread = NULL;
-
- if (fUseUPnP)
- {
- if (upnp_thread) {
- upnp_thread->interrupt();
- upnp_thread->join();
- delete upnp_thread;
- }
- upnp_thread = new boost::thread(boost::bind(&TraceThread<void (*)()>, "upnp", &ThreadMapPort));
- }
- else if (upnp_thread) {
- upnp_thread->interrupt();
- upnp_thread->join();
- delete upnp_thread;
- upnp_thread = NULL;
- }
- }
-
- #else
- void MapPort(bool)
- {
- // Intentionally left blank.
- }
- #endif
-
-
-
-
-
-
- void ThreadDNSAddressSeed()
- {
- // goal: only query DNS seeds if address need is acute
- if ((addrman.size() > 0) &&
- (!GetBoolArg("-forcednsseed", DEFAULT_FORCEDNSSEED))) {
- MilliSleep(11 * 1000);
-
- LOCK(cs_vNodes);
- if (vNodes.size() >= 2) {
- LogPrintf("P2P peers available. Skipped DNS seeding.\n");
- return;
- }
- }
-
- const vector<CDNSSeedData> &vSeeds = Params().DNSSeeds();
- int found = 0;
-
- LogPrintf("Loading addresses from DNS seeds (could take a while)\n");
-
- BOOST_FOREACH(const CDNSSeedData &seed, vSeeds) {
- if (HaveNameProxy()) {
- AddOneShot(seed.host);
- } else {
- vector<CNetAddr> vIPs;
- vector<CAddress> vAdd;
- if (LookupHost(seed.host.c_str(), vIPs))
- {
- BOOST_FOREACH(const CNetAddr& ip, vIPs)
- {
- int nOneDay = 24*3600;
- CAddress addr = CAddress(CService(ip, Params().GetDefaultPort()));
- addr.nTime = GetTime() - 3*nOneDay - GetRand(4*nOneDay); // use a random age between 3 and 7 days old
- vAdd.push_back(addr);
- found++;
- }
- }
- addrman.Add(vAdd, CNetAddr(seed.name, true));
- }
- }
-
- LogPrintf("%d addresses found from DNS seeds\n", found);
- }
-
-
-
-
-
-
-
-
-
-
-
-
- void DumpAddresses()
- {
- int64_t nStart = GetTimeMillis();
-
- CAddrDB adb;
- adb.Write(addrman);
-
- LogPrint("net", "Flushed %d addresses to peers.dat %dms\n",
- addrman.size(), GetTimeMillis() - nStart);
- }
-
- void DumpData()
- {
- DumpAddresses();
-
- if (CNode::BannedSetIsDirty())
- {
- DumpBanlist();
- CNode::SetBannedSetDirty(false);
- }
- }
-
- void static ProcessOneShot()
- {
- string strDest;
- {
- LOCK(cs_vOneShots);
- if (vOneShots.empty())
- return;
- strDest = vOneShots.front();
- vOneShots.pop_front();
- }
- CAddress addr;
- CSemaphoreGrant grant(*semOutbound, true);
- if (grant) {
- if (!OpenNetworkConnection(addr, &grant, strDest.c_str(), true))
- AddOneShot(strDest);
- }
- }
-
- void ThreadOpenConnections()
- {
- // Connect to specific addresses
- if (mapArgs.count("-connect") && mapMultiArgs["-connect"].size() > 0)
- {
- for (int64_t nLoop = 0;; nLoop++)
- {
- ProcessOneShot();
- BOOST_FOREACH(const std::string& strAddr, mapMultiArgs["-connect"])
- {
- CAddress addr;
- OpenNetworkConnection(addr, NULL, strAddr.c_str());
- for (int i = 0; i < 10 && i < nLoop; i++)
- {
- MilliSleep(500);
- }
- }
- MilliSleep(500);
- }
- }
-
- // Initiate network connections
- int64_t nStart = GetTime();
- while (true)
- {
- ProcessOneShot();
-
- MilliSleep(500);
-
- CSemaphoreGrant grant(*semOutbound);
- boost::this_thread::interruption_point();
-
- // Add seed nodes if DNS seeds are all down (an infrastructure attack?).
- if (addrman.size() == 0 && (GetTime() - nStart > 60)) {
- static bool done = false;
- if (!done) {
- LogPrintf("Adding fixed seed nodes as DNS doesn't seem to be available.\n");
- addrman.Add(convertSeed6(Params().FixedSeeds()), CNetAddr("127.0.0.1"));
- done = true;
- }
- }
-
- //
- // Choose an address to connect to based on most recently seen
- //
- CAddress addrConnect;
-
- // Only connect out to one peer per network group (/16 for IPv4).
- // Do this here so we don't have to critsect vNodes inside mapAddresses critsect.
- int nOutbound = 0;
- set<vector<unsigned char> > setConnected;
- {
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodes) {
- if (!pnode->fInbound) {
- setConnected.insert(pnode->addr.GetGroup());
- nOutbound++;
- }
- }
- }
-
- int64_t nANow = GetAdjustedTime();
-
- int nTries = 0;
- while (true)
- {
- CAddrInfo addr = addrman.Select();
-
- // if we selected an invalid address, restart
- if (!addr.IsValid() || setConnected.count(addr.GetGroup()) || IsLocal(addr))
- break;
-
- // If we didn't find an appropriate destination after trying 100 addresses fetched from addrman,
- // stop this loop, and let the outer loop run again (which sleeps, adds seed nodes, recalculates
- // already-connected network ranges, ...) before trying new addrman addresses.
- nTries++;
- if (nTries > 100)
- break;
-
- if (IsLimited(addr))
- continue;
-
- // only consider very recently tried nodes after 30 failed attempts
- if (nANow - addr.nLastTry < 600 && nTries < 30)
- continue;
-
- // do not allow non-default ports, unless after 50 invalid addresses selected already
- if (addr.GetPort() != Params().GetDefaultPort() && nTries < 50)
- continue;
-
- addrConnect = addr;
- break;
- }
-
- if (addrConnect.IsValid())
- OpenNetworkConnection(addrConnect, &grant);
- }
- }
-
- void ThreadOpenAddedConnections()
- {
- {
- LOCK(cs_vAddedNodes);
- vAddedNodes = mapMultiArgs["-addnode"];
- }
-
- if (HaveNameProxy()) {
- while(true) {
- list<string> lAddresses(0);
- {
- LOCK(cs_vAddedNodes);
- BOOST_FOREACH(const std::string& strAddNode, vAddedNodes)
- lAddresses.push_back(strAddNode);
- }
- BOOST_FOREACH(const std::string& strAddNode, lAddresses) {
- CAddress addr;
- CSemaphoreGrant grant(*semOutbound);
- OpenNetworkConnection(addr, &grant, strAddNode.c_str());
- MilliSleep(500);
- }
- MilliSleep(120000); // Retry every 2 minutes
- }
- }
-
- for (unsigned int i = 0; true; i++)
- {
- list<string> lAddresses(0);
- {
- LOCK(cs_vAddedNodes);
- BOOST_FOREACH(const std::string& strAddNode, vAddedNodes)
- lAddresses.push_back(strAddNode);
- }
-
- list<vector<CService> > lservAddressesToAdd(0);
- BOOST_FOREACH(const std::string& strAddNode, lAddresses) {
- vector<CService> vservNode(0);
- if(Lookup(strAddNode.c_str(), vservNode, Params().GetDefaultPort(), fNameLookup, 0))
- {
- lservAddressesToAdd.push_back(vservNode);
- {
- LOCK(cs_setservAddNodeAddresses);
- BOOST_FOREACH(const CService& serv, vservNode)
- setservAddNodeAddresses.insert(serv);
- }
- }
- }
- // Attempt to connect to each IP for each addnode entry until at least one is successful per addnode entry
- // (keeping in mind that addnode entries can have many IPs if fNameLookup)
- {
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodes)
- for (list<vector<CService> >::iterator it = lservAddressesToAdd.begin(); it != lservAddressesToAdd.end(); it++)
- BOOST_FOREACH(const CService& addrNode, *(it))
- if (pnode->addr == addrNode)
- {
- it = lservAddressesToAdd.erase(it);
- it--;
- break;
- }
- }
- BOOST_FOREACH(vector<CService>& vserv, lservAddressesToAdd)
- {
- CSemaphoreGrant grant(*semOutbound);
- OpenNetworkConnection(CAddress(vserv[i % vserv.size()]), &grant);
- MilliSleep(500);
- }
- MilliSleep(120000); // Retry every 2 minutes
- }
- }
-
- // if successful, this moves the passed grant to the constructed node
- bool OpenNetworkConnection(const CAddress& addrConnect, CSemaphoreGrant *grantOutbound, const char *pszDest, bool fOneShot)
- {
- //
- // Initiate outbound network connection
- //
- boost::this_thread::interruption_point();
- if (!pszDest) {
- if (IsLocal(addrConnect) ||
- FindNode((CNetAddr)addrConnect) || CNode::IsBanned(addrConnect) ||
- FindNode(addrConnect.ToStringIPPort()))
- return false;
- } else if (FindNode(std::string(pszDest)))
- return false;
-
- CNode* pnode = ConnectNode(addrConnect, pszDest);
- boost::this_thread::interruption_point();
-
- if (!pnode)
- return false;
- if (grantOutbound)
- grantOutbound->MoveTo(pnode->grantOutbound);
- pnode->fNetworkNode = true;
- if (fOneShot)
- pnode->fOneShot = true;
-
- return true;
- }
-
-
- void ThreadMessageHandler()
- {
- boost::mutex condition_mutex;
- boost::unique_lock<boost::mutex> lock(condition_mutex);
-
- SetThreadPriority(THREAD_PRIORITY_BELOW_NORMAL);
- while (true)
- {
- vector<CNode*> vNodesCopy;
- {
- LOCK(cs_vNodes);
- vNodesCopy = vNodes;
- BOOST_FOREACH(CNode* pnode, vNodesCopy) {
- pnode->AddRef();
- }
- }
-
- // Poll the connected nodes for messages
- CNode* pnodeTrickle = NULL;
- if (!vNodesCopy.empty())
- pnodeTrickle = vNodesCopy[GetRand(vNodesCopy.size())];
-
- bool fSleep = true;
-
- BOOST_FOREACH(CNode* pnode, vNodesCopy)
- {
- if (pnode->fDisconnect)
- continue;
-
- // Receive messages
- {
- TRY_LOCK(pnode->cs_vRecvMsg, lockRecv);
- if (lockRecv)
- {
- if (!g_signals.ProcessMessages(pnode))
- pnode->CloseSocketDisconnect();
-
- if (pnode->nSendSize < SendBufferSize())
- {
- if (!pnode->vRecvGetData.empty() || (!pnode->vRecvMsg.empty() && pnode->vRecvMsg[0].complete()))
- {
- fSleep = false;
- }
- }
- }
- }
- boost::this_thread::interruption_point();
-
- // Send messages
- {
- TRY_LOCK(pnode->cs_vSend, lockSend);
- if (lockSend)
- g_signals.SendMessages(pnode, pnode == pnodeTrickle || pnode->fWhitelisted);
- }
- boost::this_thread::interruption_point();
- }
-
- {
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodesCopy)
- pnode->Release();
- }
-
- if (fSleep)
- messageHandlerCondition.timed_wait(lock, boost::posix_time::microsec_clock::universal_time() + boost::posix_time::milliseconds(100));
- }
- }
-
-
-
-
-
-
- bool BindListenPort(const CService &addrBind, string& strError, bool fWhitelisted)
- {
- strError = "";
- int nOne = 1;
-
- // Create socket for listening for incoming connections
- struct sockaddr_storage sockaddr;
- socklen_t len = sizeof(sockaddr);
- if (!addrBind.GetSockAddr((struct sockaddr*)&sockaddr, &len))
- {
- strError = strprintf("Error: Bind address family for %s not supported", addrBind.ToString());
- LogPrintf("%s\n", strError);
- return false;
- }
-
- SOCKET hListenSocket = socket(((struct sockaddr*)&sockaddr)->sa_family, SOCK_STREAM, IPPROTO_TCP);
- if (hListenSocket == INVALID_SOCKET)
- {
- strError = strprintf("Error: Couldn't open socket for incoming connections (socket returned error %s)", NetworkErrorString(WSAGetLastError()));
- LogPrintf("%s\n", strError);
- return false;
- }
- if (!IsSelectableSocket(hListenSocket))
- {
- strError = "Error: Couldn't create a listenable socket for incoming connections";
- LogPrintf("%s\n", strError);
- return false;
- }
-
-
- #ifndef WIN32
- #ifdef SO_NOSIGPIPE
- // Different way of disabling SIGPIPE on BSD
- setsockopt(hListenSocket, SOL_SOCKET, SO_NOSIGPIPE, (void*)&nOne, sizeof(int));
- #endif
- // Allow binding if the port is still in TIME_WAIT state after
- // the program was closed and restarted.
- setsockopt(hListenSocket, SOL_SOCKET, SO_REUSEADDR, (void*)&nOne, sizeof(int));
- // Disable Nagle's algorithm
- setsockopt(hListenSocket, IPPROTO_TCP, TCP_NODELAY, (void*)&nOne, sizeof(int));
- #else
- setsockopt(hListenSocket, SOL_SOCKET, SO_REUSEADDR, (const char*)&nOne, sizeof(int));
- setsockopt(hListenSocket, IPPROTO_TCP, TCP_NODELAY, (const char*)&nOne, sizeof(int));
- #endif
-
- // Set to non-blocking, incoming connections will also inherit this
- if (!SetSocketNonBlocking(hListenSocket, true)) {
- strError = strprintf("BindListenPort: Setting listening socket to non-blocking failed, error %s\n", NetworkErrorString(WSAGetLastError()));
- LogPrintf("%s\n", strError);
- return false;
- }
-
- // some systems don't have IPV6_V6ONLY but are always v6only; others do have the option
- // and enable it by default or not. Try to enable it, if possible.
- if (addrBind.IsIPv6()) {
- #ifdef IPV6_V6ONLY
- #ifdef WIN32
- setsockopt(hListenSocket, IPPROTO_IPV6, IPV6_V6ONLY, (const char*)&nOne, sizeof(int));
- #else
- setsockopt(hListenSocket, IPPROTO_IPV6, IPV6_V6ONLY, (void*)&nOne, sizeof(int));
- #endif
- #endif
- #ifdef WIN32
- int nProtLevel = PROTECTION_LEVEL_UNRESTRICTED;
- setsockopt(hListenSocket, IPPROTO_IPV6, IPV6_PROTECTION_LEVEL, (const char*)&nProtLevel, sizeof(int));
- #endif
- }
-
- if (::bind(hListenSocket, (struct sockaddr*)&sockaddr, len) == SOCKET_ERROR)
- {
- int nErr = WSAGetLastError();
- if (nErr == WSAEADDRINUSE)
- strError = strprintf(_("Unable to bind to %s on this computer. Bitcoin Core is probably already running."), addrBind.ToString());
- else
- strError = strprintf(_("Unable to bind to %s on this computer (bind returned error %s)"), addrBind.ToString(), NetworkErrorString(nErr));
- LogPrintf("%s\n", strError);
- CloseSocket(hListenSocket);
- return false;
- }
- LogPrintf("Bound to %s\n", addrBind.ToString());
-
- // Listen for incoming connections
- if (listen(hListenSocket, SOMAXCONN) == SOCKET_ERROR)
- {
- strError = strprintf(_("Error: Listening for incoming connections failed (listen returned error %s)"), NetworkErrorString(WSAGetLastError()));
- LogPrintf("%s\n", strError);
- CloseSocket(hListenSocket);
- return false;
- }
-
- vhListenSocket.push_back(ListenSocket(hListenSocket, fWhitelisted));
-
- if (addrBind.IsRoutable() && fDiscover && !fWhitelisted)
- AddLocal(addrBind, LOCAL_BIND);
-
- return true;
- }
-
- void static Discover(boost::thread_group& threadGroup)
- {
- if (!fDiscover)
- return;
-
- #ifdef WIN32
- // Get local host IP
- char pszHostName[256] = "";
- if (gethostname(pszHostName, sizeof(pszHostName)) != SOCKET_ERROR)
- {
- vector<CNetAddr> vaddr;
- if (LookupHost(pszHostName, vaddr))
- {
- BOOST_FOREACH (const CNetAddr &addr, vaddr)
- {
- if (AddLocal(addr, LOCAL_IF))
- LogPrintf("%s: %s - %s\n", __func__, pszHostName, addr.ToString());
- }
- }
- }
- #else
- // Get local host ip
- struct ifaddrs* myaddrs;
- if (getifaddrs(&myaddrs) == 0)
- {
- for (struct ifaddrs* ifa = myaddrs; ifa != NULL; ifa = ifa->ifa_next)
- {
- if (ifa->ifa_addr == NULL) continue;
- if ((ifa->ifa_flags & IFF_UP) == 0) continue;
- if (strcmp(ifa->ifa_name, "lo") == 0) continue;
- if (strcmp(ifa->ifa_name, "lo0") == 0) continue;
- if (ifa->ifa_addr->sa_family == AF_INET)
- {
- struct sockaddr_in* s4 = (struct sockaddr_in*)(ifa->ifa_addr);
- CNetAddr addr(s4->sin_addr);
- if (AddLocal(addr, LOCAL_IF))
- LogPrintf("%s: IPv4 %s: %s\n", __func__, ifa->ifa_name, addr.ToString());
- }
- else if (ifa->ifa_addr->sa_family == AF_INET6)
- {
- struct sockaddr_in6* s6 = (struct sockaddr_in6*)(ifa->ifa_addr);
- CNetAddr addr(s6->sin6_addr);
- if (AddLocal(addr, LOCAL_IF))
- LogPrintf("%s: IPv6 %s: %s\n", __func__, ifa->ifa_name, addr.ToString());
- }
- }
- freeifaddrs(myaddrs);
- }
- #endif
- }
-
- void StartNode(boost::thread_group& threadGroup, CScheduler& scheduler)
- {
- uiInterface.InitMessage(_("Loading addresses..."));
- // Load addresses for peers.dat
- int64_t nStart = GetTimeMillis();
- {
- CAddrDB adb;
- if (!adb.Read(addrman))
- LogPrintf("Invalid or missing peers.dat; recreating\n");
- }
-
- //try to read stored banlist
- CBanDB bandb;
- banmap_t banmap;
- if (!bandb.Read(banmap))
- LogPrintf("Invalid or missing banlist.dat; recreating\n");
-
- CNode::SetBanned(banmap); //thread save setter
- CNode::SetBannedSetDirty(false); //no need to write down just read or nonexistent data
- CNode::SweepBanned(); //sweap out unused entries
-
- LogPrintf("Loaded %i addresses from peers.dat %dms\n",
- addrman.size(), GetTimeMillis() - nStart);
- fAddressesInitialized = true;
-
- if (semOutbound == NULL) {
- // initialize semaphore
- int nMaxOutbound = min(MAX_OUTBOUND_CONNECTIONS, nMaxConnections);
- semOutbound = new CSemaphore(nMaxOutbound);
- }
-
- if (pnodeLocalHost == NULL)
- pnodeLocalHost = new CNode(INVALID_SOCKET, CAddress(CService("127.0.0.1", 0), nLocalServices));
-
- Discover(threadGroup);
-
- //
- // Start threads
- //
-
- if (!GetBoolArg("-dnsseed", true))
- LogPrintf("DNS seeding disabled\n");
- else
- threadGroup.create_thread(boost::bind(&TraceThread<void (*)()>, "dnsseed", &ThreadDNSAddressSeed));
-
- // Map ports with UPnP
- MapPort(GetBoolArg("-upnp", DEFAULT_UPNP));
-
- // Send and receive from sockets, accept connections
- threadGroup.create_thread(boost::bind(&TraceThread<void (*)()>, "net", &ThreadSocketHandler));
-
- // Initiate outbound connections from -addnode
- threadGroup.create_thread(boost::bind(&TraceThread<void (*)()>, "addcon", &ThreadOpenAddedConnections));
-
- // Initiate outbound connections
- threadGroup.create_thread(boost::bind(&TraceThread<void (*)()>, "opencon", &ThreadOpenConnections));
-
- // Process messages
- threadGroup.create_thread(boost::bind(&TraceThread<void (*)()>, "msghand", &ThreadMessageHandler));
-
- // Dump network addresses
- scheduler.scheduleEvery(&DumpData, DUMP_ADDRESSES_INTERVAL);
- }
-
- bool StopNode()
- {
- LogPrintf("StopNode()\n");
- MapPort(false);
- if (semOutbound)
- for (int i=0; i<MAX_OUTBOUND_CONNECTIONS; i++)
- semOutbound->post();
-
- if (fAddressesInitialized)
- {
- DumpData();
- fAddressesInitialized = false;
- }
-
- return true;
- }
-
- class CNetCleanup
- {
- public:
- CNetCleanup() {}
-
- ~CNetCleanup()
- {
- // Close sockets
- BOOST_FOREACH(CNode* pnode, vNodes)
- if (pnode->hSocket != INVALID_SOCKET)
- CloseSocket(pnode->hSocket);
- BOOST_FOREACH(ListenSocket& hListenSocket, vhListenSocket)
- if (hListenSocket.socket != INVALID_SOCKET)
- if (!CloseSocket(hListenSocket.socket))
- LogPrintf("CloseSocket(hListenSocket) failed with error %s\n", NetworkErrorString(WSAGetLastError()));
-
- // clean up some globals (to help leak detection)
- BOOST_FOREACH(CNode *pnode, vNodes)
- delete pnode;
- BOOST_FOREACH(CNode *pnode, vNodesDisconnected)
- delete pnode;
- vNodes.clear();
- vNodesDisconnected.clear();
- vhListenSocket.clear();
- delete semOutbound;
- semOutbound = NULL;
- delete pnodeLocalHost;
- pnodeLocalHost = NULL;
-
- #ifdef WIN32
- // Shutdown Windows Sockets
- WSACleanup();
- #endif
- }
- }
- instance_of_cnetcleanup;
-
-
-
-
-
-
-
- void RelayTransaction(const CTransaction& tx)
- {
- CDataStream ss(SER_NETWORK, PROTOCOL_VERSION);
- ss.reserve(10000);
- ss << tx;
- RelayTransaction(tx, ss);
- }
-
- void RelayTransaction(const CTransaction& tx, const CDataStream& ss)
- {
- CInv inv(MSG_TX, tx.GetHash());
- {
- LOCK(cs_mapRelay);
- // Expire old relay messages
- while (!vRelayExpiration.empty() && vRelayExpiration.front().first < GetTime())
- {
- mapRelay.erase(vRelayExpiration.front().second);
- vRelayExpiration.pop_front();
- }
-
- // Save original serialized message so newer versions are preserved
- mapRelay.insert(std::make_pair(inv, ss));
- vRelayExpiration.push_back(std::make_pair(GetTime() + 15 * 60, inv));
- }
- LOCK(cs_vNodes);
- BOOST_FOREACH(CNode* pnode, vNodes)
- {
- if(!pnode->fRelayTxes)
- continue;
- LOCK(pnode->cs_filter);
- if (pnode->pfilter)
- {
- if (pnode->pfilter->IsRelevantAndUpdate(tx))
- pnode->PushInventory(inv);
- } else
- pnode->PushInventory(inv);
- }
- }
-
- void CNode::RecordBytesRecv(uint64_t bytes)
- {
- LOCK(cs_totalBytesRecv);
- nTotalBytesRecv += bytes;
- }
-
- void CNode::RecordBytesSent(uint64_t bytes)
- {
- LOCK(cs_totalBytesSent);
- nTotalBytesSent += bytes;
-
- uint64_t now = GetTime();
- if (nMaxOutboundCycleStartTime + nMaxOutboundTimeframe < now)
- {
- // timeframe expired, reset cycle
- nMaxOutboundCycleStartTime = now;
- nMaxOutboundTotalBytesSentInCycle = 0;
- }
-
- // TODO, exclude whitebind peers
- nMaxOutboundTotalBytesSentInCycle += bytes;
- }
-
- void CNode::SetMaxOutboundTarget(uint64_t limit)
- {
- LOCK(cs_totalBytesSent);
- uint64_t recommendedMinimum = (nMaxOutboundTimeframe / 600) * MAX_BLOCK_SIZE;
- nMaxOutboundLimit = limit;
-
- if (limit > 0 && limit < recommendedMinimum)
- LogPrintf("Max outbound target is very small (%s bytes) and will be overshot. Recommended minimum is %s bytes.\n", nMaxOutboundLimit, recommendedMinimum);
- }
-
- uint64_t CNode::GetMaxOutboundTarget()
- {
- LOCK(cs_totalBytesSent);
- return nMaxOutboundLimit;
- }
-
- uint64_t CNode::GetMaxOutboundTimeframe()
- {
- LOCK(cs_totalBytesSent);
- return nMaxOutboundTimeframe;
- }
-
- uint64_t CNode::GetMaxOutboundTimeLeftInCycle()
- {
- LOCK(cs_totalBytesSent);
- if (nMaxOutboundLimit == 0)
- return 0;
-
- if (nMaxOutboundCycleStartTime == 0)
- return nMaxOutboundTimeframe;
-
- uint64_t cycleEndTime = nMaxOutboundCycleStartTime + nMaxOutboundTimeframe;
- uint64_t now = GetTime();
- return (cycleEndTime < now) ? 0 : cycleEndTime - GetTime();
- }
-
- void CNode::SetMaxOutboundTimeframe(uint64_t timeframe)
- {
- LOCK(cs_totalBytesSent);
- if (nMaxOutboundTimeframe != timeframe)
- {
- // reset measure-cycle in case of changing
- // the timeframe
- nMaxOutboundCycleStartTime = GetTime();
- }
- nMaxOutboundTimeframe = timeframe;
- }
-
- bool CNode::OutboundTargetReached(bool historicalBlockServingLimit)
- {
- LOCK(cs_totalBytesSent);
- if (nMaxOutboundLimit == 0)
- return false;
-
- if (historicalBlockServingLimit)
- {
- // keep a large enought buffer to at least relay each block once
- uint64_t timeLeftInCycle = GetMaxOutboundTimeLeftInCycle();
- uint64_t buffer = timeLeftInCycle / 600 * MAX_BLOCK_SIZE;
- if (buffer >= nMaxOutboundLimit || nMaxOutboundTotalBytesSentInCycle >= nMaxOutboundLimit - buffer)
- return true;
- }
- else if (nMaxOutboundTotalBytesSentInCycle >= nMaxOutboundLimit)
- return true;
-
- return false;
- }
-
- uint64_t CNode::GetOutboundTargetBytesLeft()
- {
- LOCK(cs_totalBytesSent);
- if (nMaxOutboundLimit == 0)
- return 0;
-
- return (nMaxOutboundTotalBytesSentInCycle >= nMaxOutboundLimit) ? 0 : nMaxOutboundLimit - nMaxOutboundTotalBytesSentInCycle;
- }
-
- uint64_t CNode::GetTotalBytesRecv()
- {
- LOCK(cs_totalBytesRecv);
- return nTotalBytesRecv;
- }
-
- uint64_t CNode::GetTotalBytesSent()
- {
- LOCK(cs_totalBytesSent);
- return nTotalBytesSent;
- }
-
- void CNode::Fuzz(int nChance)
- {
- if (!fSuccessfullyConnected) return; // Don't fuzz initial handshake
- if (GetRand(nChance) != 0) return; // Fuzz 1 of every nChance messages
-
- switch (GetRand(3))
- {
- case 0:
- // xor a random byte with a random value:
- if (!ssSend.empty()) {
- CDataStream::size_type pos = GetRand(ssSend.size());
- ssSend[pos] ^= (unsigned char)(GetRand(256));
- }
- break;
- case 1:
- // delete a random byte:
- if (!ssSend.empty()) {
- CDataStream::size_type pos = GetRand(ssSend.size());
- ssSend.erase(ssSend.begin()+pos);
- }
- break;
- case 2:
- // insert a random byte at a random position
- {
- CDataStream::size_type pos = GetRand(ssSend.size());
- char ch = (char)GetRand(256);
- ssSend.insert(ssSend.begin()+pos, ch);
- }
- break;
- }
- // Chance of more than one change half the time:
- // (more changes exponentially less likely):
- Fuzz(2);
- }
-
- //
- // CAddrDB
- //
-
- CAddrDB::CAddrDB()
- {
- pathAddr = GetDataDir() / "peers.dat";
- }
-
- bool CAddrDB::Write(const CAddrMan& addr)
- {
- // Generate random temporary filename
- unsigned short randv = 0;
- GetRandBytes((unsigned char*)&randv, sizeof(randv));
- std::string tmpfn = strprintf("peers.dat.%04x", randv);
-
- // serialize addresses, checksum data up to that point, then append csum
- CDataStream ssPeers(SER_DISK, CLIENT_VERSION);
- ssPeers << FLATDATA(Params().MessageStart());
- ssPeers << addr;
- uint256 hash = Hash(ssPeers.begin(), ssPeers.end());
- ssPeers << hash;
-
- // open temp output file, and associate with CAutoFile
- boost::filesystem::path pathTmp = GetDataDir() / tmpfn;
- FILE *file = fopen(pathTmp.string().c_str(), "wb");
- CAutoFile fileout(file, SER_DISK, CLIENT_VERSION);
- if (fileout.IsNull())
- return error("%s: Failed to open file %s", __func__, pathTmp.string());
-
- // Write and commit header, data
- try {
- fileout << ssPeers;
- }
- catch (const std::exception& e) {
- return error("%s: Serialize or I/O error - %s", __func__, e.what());
- }
- FileCommit(fileout.Get());
- fileout.fclose();
-
- // replace existing peers.dat, if any, with new peers.dat.XXXX
- if (!RenameOver(pathTmp, pathAddr))
- return error("%s: Rename-into-place failed", __func__);
-
- return true;
- }
-
- bool CAddrDB::Read(CAddrMan& addr)
- {
- // open input file, and associate with CAutoFile
- FILE *file = fopen(pathAddr.string().c_str(), "rb");
- CAutoFile filein(file, SER_DISK, CLIENT_VERSION);
- if (filein.IsNull())
- return error("%s: Failed to open file %s", __func__, pathAddr.string());
-
- // use file size to size memory buffer
- uint64_t fileSize = boost::filesystem::file_size(pathAddr);
- uint64_t dataSize = 0;
- // Don't try to resize to a negative number if file is small
- if (fileSize >= sizeof(uint256))
- dataSize = fileSize - sizeof(uint256);
- vector<unsigned char> vchData;
- vchData.resize(dataSize);
- uint256 hashIn;
-
- // read data and checksum from file
- try {
- filein.read((char *)&vchData[0], dataSize);
- filein >> hashIn;
- }
- catch (const std::exception& e) {
- return error("%s: Deserialize or I/O error - %s", __func__, e.what());
- }
- filein.fclose();
-
- CDataStream ssPeers(vchData, SER_DISK, CLIENT_VERSION);
-
- // verify stored checksum matches input data
- uint256 hashTmp = Hash(ssPeers.begin(), ssPeers.end());
- if (hashIn != hashTmp)
- return error("%s: Checksum mismatch, data corrupted", __func__);
-
- unsigned char pchMsgTmp[4];
- try {
- // de-serialize file header (network specific magic number) and ..
- ssPeers >> FLATDATA(pchMsgTmp);
-
- // ... verify the network matches ours
- if (memcmp(pchMsgTmp, Params().MessageStart(), sizeof(pchMsgTmp)))
- return error("%s: Invalid network magic number", __func__);
-
- // de-serialize address data into one CAddrMan object
- ssPeers >> addr;
- }
- catch (const std::exception& e) {
- return error("%s: Deserialize or I/O error - %s", __func__, e.what());
- }
-
- return true;
- }
-
- unsigned int ReceiveFloodSize() { return 1000*GetArg("-maxreceivebuffer", DEFAULT_MAXRECEIVEBUFFER); }
- unsigned int SendBufferSize() { return 1000*GetArg("-maxsendbuffer", DEFAULT_MAXSENDBUFFER); }
-
- CNode::CNode(SOCKET hSocketIn, const CAddress& addrIn, const std::string& addrNameIn, bool fInboundIn) :
- ssSend(SER_NETWORK, INIT_PROTO_VERSION),
- addrKnown(5000, 0.001),
- setInventoryKnown(SendBufferSize() / 1000)
- {
- nServices = 0;
- hSocket = hSocketIn;
- nRecvVersion = INIT_PROTO_VERSION;
- nLastSend = 0;
- nLastRecv = 0;
- nSendBytes = 0;
- nRecvBytes = 0;
- nTimeConnected = GetTime();
- nTimeOffset = 0;
- addr = addrIn;
- addrName = addrNameIn == "" ? addr.ToStringIPPort() : addrNameIn;
- nVersion = 0;
- strSubVer = "";
- fWhitelisted = false;
- fOneShot = false;
- fClient = false; // set by version message
- fInbound = fInboundIn;
- fNetworkNode = false;
- fSuccessfullyConnected = false;
- fDisconnect = false;
- nRefCount = 0;
- nSendSize = 0;
- nSendOffset = 0;
- hashContinue = uint256();
- nStartingHeight = -1;
- fGetAddr = false;
- fRelayTxes = false;
- pfilter = new CBloomFilter();
- nPingNonceSent = 0;
- nPingUsecStart = 0;
- nPingUsecTime = 0;
- fPingQueued = false;
- nMinPingUsecTime = std::numeric_limits<int64_t>::max();
-
- {
- LOCK(cs_nLastNodeId);
- id = nLastNodeId++;
- }
-
- if (fLogIPs)
- LogPrint("net", "Added connection to %s peer=%d\n", addrName, id);
- else
- LogPrint("net", "Added connection peer=%d\n", id);
-
- // Be shy and don't send version until we hear
- if (hSocket != INVALID_SOCKET && !fInbound)
- PushVersion();
-
- GetNodeSignals().InitializeNode(GetId(), this);
- }
-
- CNode::~CNode()
- {
- CloseSocket(hSocket);
-
- if (pfilter)
- delete pfilter;
-
- GetNodeSignals().FinalizeNode(GetId());
- }
-
- void CNode::AskFor(const CInv& inv)
- {
- if (mapAskFor.size() > MAPASKFOR_MAX_SZ || setAskFor.size() > SETASKFOR_MAX_SZ)
- return;
- // a peer may not have multiple non-responded queue positions for a single inv item
- if (!setAskFor.insert(inv.hash).second)
- return;
-
- // We're using mapAskFor as a priority queue,
- // the key is the earliest time the request can be sent
- int64_t nRequestTime;
- limitedmap<CInv, int64_t>::const_iterator it = mapAlreadyAskedFor.find(inv);
- if (it != mapAlreadyAskedFor.end())
- nRequestTime = it->second;
- else
- nRequestTime = 0;
- LogPrint("net", "askfor %s %d (%s) peer=%d\n", inv.ToString(), nRequestTime, DateTimeStrFormat("%H:%M:%S", nRequestTime/1000000), id);
-
- // Make sure not to reuse time indexes to keep things in the same order
- int64_t nNow = GetTimeMicros() - 1000000;
- static int64_t nLastTime;
- ++nLastTime;
- nNow = std::max(nNow, nLastTime);
- nLastTime = nNow;
-
- // Each retry is 2 minutes after the last
- nRequestTime = std::max(nRequestTime + 2 * 60 * 1000000, nNow);
- if (it != mapAlreadyAskedFor.end())
- mapAlreadyAskedFor.update(it, nRequestTime);
- else
- mapAlreadyAskedFor.insert(std::make_pair(inv, nRequestTime));
- mapAskFor.insert(std::make_pair(nRequestTime, inv));
- }
-
- void CNode::BeginMessage(const char* pszCommand) EXCLUSIVE_LOCK_FUNCTION(cs_vSend)
- {
- ENTER_CRITICAL_SECTION(cs_vSend);
- assert(ssSend.size() == 0);
- ssSend << CMessageHeader(Params().MessageStart(), pszCommand, 0);
- LogPrint("net", "sending: %s ", SanitizeString(pszCommand));
- }
-
- void CNode::AbortMessage() UNLOCK_FUNCTION(cs_vSend)
- {
- ssSend.clear();
-
- LEAVE_CRITICAL_SECTION(cs_vSend);
-
- LogPrint("net", "(aborted)\n");
- }
-
- void CNode::EndMessage() UNLOCK_FUNCTION(cs_vSend)
- {
- // The -*messagestest options are intentionally not documented in the help message,
- // since they are only used during development to debug the networking code and are
- // not intended for end-users.
- if (mapArgs.count("-dropmessagestest") && GetRand(GetArg("-dropmessagestest", 2)) == 0)
- {
- LogPrint("net", "dropmessages DROPPING SEND MESSAGE\n");
- AbortMessage();
- return;
- }
- if (mapArgs.count("-fuzzmessagestest"))
- Fuzz(GetArg("-fuzzmessagestest", 10));
-
- if (ssSend.size() == 0)
- {
- LEAVE_CRITICAL_SECTION(cs_vSend);
- return;
- }
- // Set the size
- unsigned int nSize = ssSend.size() - CMessageHeader::HEADER_SIZE;
- WriteLE32((uint8_t*)&ssSend[CMessageHeader::MESSAGE_SIZE_OFFSET], nSize);
-
- // Set the checksum
- uint256 hash = Hash(ssSend.begin() + CMessageHeader::HEADER_SIZE, ssSend.end());
- unsigned int nChecksum = 0;
- memcpy(&nChecksum, &hash, sizeof(nChecksum));
- assert(ssSend.size () >= CMessageHeader::CHECKSUM_OFFSET + sizeof(nChecksum));
- memcpy((char*)&ssSend[CMessageHeader::CHECKSUM_OFFSET], &nChecksum, sizeof(nChecksum));
-
- LogPrint("net", "(%d bytes) peer=%d\n", nSize, id);
-
- std::deque<CSerializeData>::iterator it = vSendMsg.insert(vSendMsg.end(), CSerializeData());
- ssSend.GetAndClear(*it);
- nSendSize += (*it).size();
-
- // If write queue empty, attempt "optimistic write"
- if (it == vSendMsg.begin())
- SocketSendData(this);
-
- LEAVE_CRITICAL_SECTION(cs_vSend);
- }
-
- //
- // CBanDB
- //
-
- CBanDB::CBanDB()
- {
- pathBanlist = GetDataDir() / "banlist.dat";
- }
-
- bool CBanDB::Write(const banmap_t& banSet)
- {
- // Generate random temporary filename
- unsigned short randv = 0;
- GetRandBytes((unsigned char*)&randv, sizeof(randv));
- std::string tmpfn = strprintf("banlist.dat.%04x", randv);
-
- // serialize banlist, checksum data up to that point, then append csum
- CDataStream ssBanlist(SER_DISK, CLIENT_VERSION);
- ssBanlist << FLATDATA(Params().MessageStart());
- ssBanlist << banSet;
- uint256 hash = Hash(ssBanlist.begin(), ssBanlist.end());
- ssBanlist << hash;
-
- // open temp output file, and associate with CAutoFile
- boost::filesystem::path pathTmp = GetDataDir() / tmpfn;
- FILE *file = fopen(pathTmp.string().c_str(), "wb");
- CAutoFile fileout(file, SER_DISK, CLIENT_VERSION);
- if (fileout.IsNull())
- return error("%s: Failed to open file %s", __func__, pathTmp.string());
-
- // Write and commit header, data
- try {
- fileout << ssBanlist;
- }
- catch (const std::exception& e) {
- return error("%s: Serialize or I/O error - %s", __func__, e.what());
- }
- FileCommit(fileout.Get());
- fileout.fclose();
-
- // replace existing banlist.dat, if any, with new banlist.dat.XXXX
- if (!RenameOver(pathTmp, pathBanlist))
- return error("%s: Rename-into-place failed", __func__);
-
- return true;
- }
-
- bool CBanDB::Read(banmap_t& banSet)
- {
- // open input file, and associate with CAutoFile
- FILE *file = fopen(pathBanlist.string().c_str(), "rb");
- CAutoFile filein(file, SER_DISK, CLIENT_VERSION);
- if (filein.IsNull())
- return error("%s: Failed to open file %s", __func__, pathBanlist.string());
-
- // use file size to size memory buffer
- uint64_t fileSize = boost::filesystem::file_size(pathBanlist);
- uint64_t dataSize = 0;
- // Don't try to resize to a negative number if file is small
- if (fileSize >= sizeof(uint256))
- dataSize = fileSize - sizeof(uint256);
- vector<unsigned char> vchData;
- vchData.resize(dataSize);
- uint256 hashIn;
-
- // read data and checksum from file
- try {
- filein.read((char *)&vchData[0], dataSize);
- filein >> hashIn;
- }
- catch (const std::exception& e) {
- return error("%s: Deserialize or I/O error - %s", __func__, e.what());
- }
- filein.fclose();
-
- CDataStream ssBanlist(vchData, SER_DISK, CLIENT_VERSION);
-
- // verify stored checksum matches input data
- uint256 hashTmp = Hash(ssBanlist.begin(), ssBanlist.end());
- if (hashIn != hashTmp)
- return error("%s: Checksum mismatch, data corrupted", __func__);
-
- unsigned char pchMsgTmp[4];
- try {
- // de-serialize file header (network specific magic number) and ..
- ssBanlist >> FLATDATA(pchMsgTmp);
-
- // ... verify the network matches ours
- if (memcmp(pchMsgTmp, Params().MessageStart(), sizeof(pchMsgTmp)))
- return error("%s: Invalid network magic number", __func__);
-
- // de-serialize address data into one CAddrMan object
- ssBanlist >> banSet;
- }
- catch (const std::exception& e) {
- return error("%s: Deserialize or I/O error - %s", __func__, e.what());
- }
-
- return true;
- }
-
- void DumpBanlist()
- {
- int64_t nStart = GetTimeMillis();
-
- CNode::SweepBanned(); //clean unused entries (if bantime has expired)
-
- CBanDB bandb;
- banmap_t banmap;
- CNode::GetBanned(banmap);
- bandb.Write(banmap);
-
- LogPrint("net", "Flushed %d banned node ips/subnets to banlist.dat %dms\n",
- banmap.size(), GetTimeMillis() - nStart);
- }
|