Bitcoin Core  27.99.0
P2P Digital Currency
httpserver.cpp
Go to the documentation of this file.
1 // Copyright (c) 2015-2022 The Bitcoin Core developers
2 // Distributed under the MIT software license, see the accompanying
3 // file COPYING or http://www.opensource.org/licenses/mit-license.php.
4 
5 #if defined(HAVE_CONFIG_H)
7 #endif
8 
9 #include <httpserver.h>
10 
11 #include <chainparamsbase.h>
12 #include <common/args.h>
13 #include <compat/compat.h>
14 #include <logging.h>
15 #include <netbase.h>
16 #include <node/interface_ui.h>
17 #include <rpc/protocol.h> // For HTTP status codes
18 #include <sync.h>
19 #include <util/check.h>
20 #include <util/signalinterrupt.h>
21 #include <util/strencodings.h>
22 #include <util/threadnames.h>
23 #include <util/translation.h>
24 
25 #include <condition_variable>
26 #include <cstdio>
27 #include <cstdlib>
28 #include <deque>
29 #include <memory>
30 #include <optional>
31 #include <string>
32 #include <unordered_map>
33 
34 #include <sys/types.h>
35 #include <sys/stat.h>
36 
37 #include <event2/buffer.h>
38 #include <event2/bufferevent.h>
39 #include <event2/http.h>
40 #include <event2/http_struct.h>
41 #include <event2/keyvalq_struct.h>
42 #include <event2/thread.h>
43 #include <event2/util.h>
44 
45 #include <support/events.h>
46 
48 static const size_t MAX_HEADERS_SIZE = 8192;
49 
51 class HTTPWorkItem final : public HTTPClosure
52 {
53 public:
54  HTTPWorkItem(std::unique_ptr<HTTPRequest> _req, const std::string &_path, const HTTPRequestHandler& _func):
55  req(std::move(_req)), path(_path), func(_func)
56  {
57  }
58  void operator()() override
59  {
60  func(req.get(), path);
61  }
62 
63  std::unique_ptr<HTTPRequest> req;
64 
65 private:
66  std::string path;
68 };
69 
73 template <typename WorkItem>
74 class WorkQueue
75 {
76 private:
78  std::condition_variable cond GUARDED_BY(cs);
79  std::deque<std::unique_ptr<WorkItem>> queue GUARDED_BY(cs);
80  bool running GUARDED_BY(cs){true};
81  const size_t maxDepth;
82 
83 public:
84  explicit WorkQueue(size_t _maxDepth) : maxDepth(_maxDepth)
85  {
86  }
89  ~WorkQueue() = default;
91  bool Enqueue(WorkItem* item) EXCLUSIVE_LOCKS_REQUIRED(!cs)
92  {
93  LOCK(cs);
94  if (!running || queue.size() >= maxDepth) {
95  return false;
96  }
97  queue.emplace_back(std::unique_ptr<WorkItem>(item));
98  cond.notify_one();
99  return true;
100  }
103  {
104  while (true) {
105  std::unique_ptr<WorkItem> i;
106  {
107  WAIT_LOCK(cs, lock);
108  while (running && queue.empty())
109  cond.wait(lock);
110  if (!running && queue.empty())
111  break;
112  i = std::move(queue.front());
113  queue.pop_front();
114  }
115  (*i)();
116  }
117  }
120  {
121  LOCK(cs);
122  running = false;
123  cond.notify_all();
124  }
125 };
126 
128 {
129  HTTPPathHandler(std::string _prefix, bool _exactMatch, HTTPRequestHandler _handler):
130  prefix(_prefix), exactMatch(_exactMatch), handler(_handler)
131  {
132  }
133  std::string prefix;
136 };
137 
141 static struct event_base* eventBase = nullptr;
143 static struct evhttp* eventHTTP = nullptr;
145 static std::vector<CSubNet> rpc_allow_subnets;
147 static std::unique_ptr<WorkQueue<HTTPClosure>> g_work_queue{nullptr};
150 static std::vector<HTTPPathHandler> pathHandlers GUARDED_BY(g_httppathhandlers_mutex);
152 static std::vector<evhttp_bound_socket *> boundSockets;
153 
159 {
160 private:
161  mutable Mutex m_mutex;
162  mutable std::condition_variable m_cv;
164  std::unordered_map<const evhttp_connection*, size_t> m_tracker GUARDED_BY(m_mutex);
165 
166  void RemoveConnectionInternal(const decltype(m_tracker)::iterator it) EXCLUSIVE_LOCKS_REQUIRED(m_mutex)
167  {
168  m_tracker.erase(it);
169  if (m_tracker.empty()) m_cv.notify_all();
170  }
171 public:
173  void AddRequest(evhttp_request* req) EXCLUSIVE_LOCKS_REQUIRED(!m_mutex)
174  {
175  const evhttp_connection* conn{Assert(evhttp_request_get_connection(Assert(req)))};
176  WITH_LOCK(m_mutex, ++m_tracker[conn]);
177  }
179  void RemoveRequest(evhttp_request* req) EXCLUSIVE_LOCKS_REQUIRED(!m_mutex)
180  {
181  const evhttp_connection* conn{Assert(evhttp_request_get_connection(Assert(req)))};
182  LOCK(m_mutex);
183  auto it{m_tracker.find(conn)};
184  if (it != m_tracker.end() && it->second > 0) {
185  if (--(it->second) == 0) RemoveConnectionInternal(it);
186  }
187  }
189  void RemoveConnection(const evhttp_connection* conn) EXCLUSIVE_LOCKS_REQUIRED(!m_mutex)
190  {
191  LOCK(m_mutex);
192  auto it{m_tracker.find(Assert(conn))};
193  if (it != m_tracker.end()) RemoveConnectionInternal(it);
194  }
196  {
197  return WITH_LOCK(m_mutex, return m_tracker.size());
198  }
201  {
202  WAIT_LOCK(m_mutex, lock);
203  m_cv.wait(lock, [this]() EXCLUSIVE_LOCKS_REQUIRED(m_mutex) { return m_tracker.empty(); });
204  }
205 };
208 
210 static bool ClientAllowed(const CNetAddr& netaddr)
211 {
212  if (!netaddr.IsValid())
213  return false;
214  for(const CSubNet& subnet : rpc_allow_subnets)
215  if (subnet.Match(netaddr))
216  return true;
217  return false;
218 }
219 
221 static bool InitHTTPAllowList()
222 {
223  rpc_allow_subnets.clear();
224  rpc_allow_subnets.emplace_back(LookupHost("127.0.0.1", false).value(), 8); // always allow IPv4 local subnet
225  rpc_allow_subnets.emplace_back(LookupHost("::1", false).value()); // always allow IPv6 localhost
226  for (const std::string& strAllow : gArgs.GetArgs("-rpcallowip")) {
227  const CSubNet subnet{LookupSubNet(strAllow)};
228  if (!subnet.IsValid()) {
229  uiInterface.ThreadSafeMessageBox(
230  strprintf(Untranslated("Invalid -rpcallowip subnet specification: %s. Valid are a single IP (e.g. 1.2.3.4), a network/netmask (e.g. 1.2.3.4/255.255.255.0) or a network/CIDR (e.g. 1.2.3.4/24)."), strAllow),
232  return false;
233  }
234  rpc_allow_subnets.push_back(subnet);
235  }
236  std::string strAllowed;
237  for (const CSubNet& subnet : rpc_allow_subnets)
238  strAllowed += subnet.ToString() + " ";
239  LogPrint(BCLog::HTTP, "Allowing HTTP connections from: %s\n", strAllowed);
240  return true;
241 }
242 
245 {
246  switch (m) {
247  case HTTPRequest::GET:
248  return "GET";
249  case HTTPRequest::POST:
250  return "POST";
251  case HTTPRequest::HEAD:
252  return "HEAD";
253  case HTTPRequest::PUT:
254  return "PUT";
256  return "unknown";
257  } // no default case, so the compiler can warn about missing cases
258  assert(false);
259 }
260 
262 static void http_request_cb(struct evhttp_request* req, void* arg)
263 {
264  evhttp_connection* conn{evhttp_request_get_connection(req)};
265  // Track active requests
266  {
267  g_requests.AddRequest(req);
268  evhttp_request_set_on_complete_cb(req, [](struct evhttp_request* req, void*) {
270  }, nullptr);
271  evhttp_connection_set_closecb(conn, [](evhttp_connection* conn, void* arg) {
273  }, nullptr);
274  }
275 
276  // Disable reading to work around a libevent bug, fixed in 2.1.9
277  // See https://github.com/libevent/libevent/commit/5ff8eb26371c4dc56f384b2de35bea2d87814779
278  // and https://github.com/bitcoin/bitcoin/pull/11593.
279  if (event_get_version_number() >= 0x02010600 && event_get_version_number() < 0x02010900) {
280  if (conn) {
281  bufferevent* bev = evhttp_connection_get_bufferevent(conn);
282  if (bev) {
283  bufferevent_disable(bev, EV_READ);
284  }
285  }
286  }
287  auto hreq{std::make_unique<HTTPRequest>(req, *static_cast<const util::SignalInterrupt*>(arg))};
288 
289  // Early address-based allow check
290  if (!ClientAllowed(hreq->GetPeer())) {
291  LogPrint(BCLog::HTTP, "HTTP request from %s rejected: Client network is not allowed RPC access\n",
292  hreq->GetPeer().ToStringAddrPort());
293  hreq->WriteReply(HTTP_FORBIDDEN);
294  return;
295  }
296 
297  // Early reject unknown HTTP methods
298  if (hreq->GetRequestMethod() == HTTPRequest::UNKNOWN) {
299  LogPrint(BCLog::HTTP, "HTTP request from %s rejected: Unknown HTTP request method\n",
300  hreq->GetPeer().ToStringAddrPort());
301  hreq->WriteReply(HTTP_BAD_METHOD);
302  return;
303  }
304 
305  LogPrint(BCLog::HTTP, "Received a %s request for %s from %s\n",
306  RequestMethodString(hreq->GetRequestMethod()), SanitizeString(hreq->GetURI(), SAFE_CHARS_URI).substr(0, 100), hreq->GetPeer().ToStringAddrPort());
307 
308  // Find registered handler for prefix
309  std::string strURI = hreq->GetURI();
310  std::string path;
312  std::vector<HTTPPathHandler>::const_iterator i = pathHandlers.begin();
313  std::vector<HTTPPathHandler>::const_iterator iend = pathHandlers.end();
314  for (; i != iend; ++i) {
315  bool match = false;
316  if (i->exactMatch)
317  match = (strURI == i->prefix);
318  else
319  match = (strURI.substr(0, i->prefix.size()) == i->prefix);
320  if (match) {
321  path = strURI.substr(i->prefix.size());
322  break;
323  }
324  }
325 
326  // Dispatch to worker thread
327  if (i != iend) {
328  std::unique_ptr<HTTPWorkItem> item(new HTTPWorkItem(std::move(hreq), path, i->handler));
330  if (g_work_queue->Enqueue(item.get())) {
331  item.release(); /* if true, queue took ownership */
332  } else {
333  LogPrintf("WARNING: request rejected because http work queue depth exceeded, it can be increased with the -rpcworkqueue= setting\n");
334  item->req->WriteReply(HTTP_SERVICE_UNAVAILABLE, "Work queue depth exceeded");
335  }
336  } else {
337  hreq->WriteReply(HTTP_NOT_FOUND);
338  }
339 }
340 
342 static void http_reject_request_cb(struct evhttp_request* req, void*)
343 {
344  LogPrint(BCLog::HTTP, "Rejecting request while shutting down\n");
345  evhttp_send_error(req, HTTP_SERVUNAVAIL, nullptr);
346 }
347 
349 static void ThreadHTTP(struct event_base* base)
350 {
351  util::ThreadRename("http");
352  LogPrint(BCLog::HTTP, "Entering http event loop\n");
353  event_base_dispatch(base);
354  // Event loop will be interrupted by InterruptHTTPServer()
355  LogPrint(BCLog::HTTP, "Exited http event loop\n");
356 }
357 
359 static bool HTTPBindAddresses(struct evhttp* http)
360 {
361  uint16_t http_port{static_cast<uint16_t>(gArgs.GetIntArg("-rpcport", BaseParams().RPCPort()))};
362  std::vector<std::pair<std::string, uint16_t>> endpoints;
363 
364  // Determine what addresses to bind to
365  if (!(gArgs.IsArgSet("-rpcallowip") && gArgs.IsArgSet("-rpcbind"))) { // Default to loopback if not allowing external IPs
366  endpoints.emplace_back("::1", http_port);
367  endpoints.emplace_back("127.0.0.1", http_port);
368  if (gArgs.IsArgSet("-rpcallowip")) {
369  LogPrintf("WARNING: option -rpcallowip was specified without -rpcbind; this doesn't usually make sense\n");
370  }
371  if (gArgs.IsArgSet("-rpcbind")) {
372  LogPrintf("WARNING: option -rpcbind was ignored because -rpcallowip was not specified, refusing to allow everyone to connect\n");
373  }
374  } else if (gArgs.IsArgSet("-rpcbind")) { // Specific bind address
375  for (const std::string& strRPCBind : gArgs.GetArgs("-rpcbind")) {
376  uint16_t port{http_port};
377  std::string host;
378  SplitHostPort(strRPCBind, port, host);
379  endpoints.emplace_back(host, port);
380  }
381  }
382 
383  // Bind addresses
384  for (std::vector<std::pair<std::string, uint16_t> >::iterator i = endpoints.begin(); i != endpoints.end(); ++i) {
385  LogPrintf("Binding RPC on address %s port %i\n", i->first, i->second);
386  evhttp_bound_socket *bind_handle = evhttp_bind_socket_with_handle(http, i->first.empty() ? nullptr : i->first.c_str(), i->second);
387  if (bind_handle) {
388  const std::optional<CNetAddr> addr{LookupHost(i->first, false)};
389  if (i->first.empty() || (addr.has_value() && addr->IsBindAny())) {
390  LogPrintf("WARNING: the RPC server is not safe to expose to untrusted networks such as the public internet\n");
391  }
392  boundSockets.push_back(bind_handle);
393  } else {
394  LogPrintf("Binding RPC on address %s port %i failed.\n", i->first, i->second);
395  }
396  }
397  return !boundSockets.empty();
398 }
399 
401 static void HTTPWorkQueueRun(WorkQueue<HTTPClosure>* queue, int worker_num)
402 {
403  util::ThreadRename(strprintf("httpworker.%i", worker_num));
404  queue->Run();
405 }
406 
408 static void libevent_log_cb(int severity, const char *msg)
409 {
410  BCLog::Level level;
411  switch (severity) {
412  case EVENT_LOG_DEBUG:
413  level = BCLog::Level::Debug;
414  break;
415  case EVENT_LOG_MSG:
416  level = BCLog::Level::Info;
417  break;
418  case EVENT_LOG_WARN:
419  level = BCLog::Level::Warning;
420  break;
421  default: // EVENT_LOG_ERR and others are mapped to error
422  level = BCLog::Level::Error;
423  break;
424  }
425  LogPrintLevel(BCLog::LIBEVENT, level, "%s\n", msg);
426 }
427 
428 bool InitHTTPServer(const util::SignalInterrupt& interrupt)
429 {
430  if (!InitHTTPAllowList())
431  return false;
432 
433  // Redirect libevent's logging to our own log
434  event_set_log_callback(&libevent_log_cb);
435  // Update libevent's log handling.
437 
438 #ifdef WIN32
439  evthread_use_windows_threads();
440 #else
441  evthread_use_pthreads();
442 #endif
443 
444  raii_event_base base_ctr = obtain_event_base();
445 
446  /* Create a new evhttp object to handle requests. */
447  raii_evhttp http_ctr = obtain_evhttp(base_ctr.get());
448  struct evhttp* http = http_ctr.get();
449  if (!http) {
450  LogPrintf("couldn't create evhttp. Exiting.\n");
451  return false;
452  }
453 
454  evhttp_set_timeout(http, gArgs.GetIntArg("-rpcservertimeout", DEFAULT_HTTP_SERVER_TIMEOUT));
455  evhttp_set_max_headers_size(http, MAX_HEADERS_SIZE);
456  evhttp_set_max_body_size(http, MAX_SIZE);
457  evhttp_set_gencb(http, http_request_cb, (void*)&interrupt);
458 
459  if (!HTTPBindAddresses(http)) {
460  LogPrintf("Unable to bind any endpoint for RPC server\n");
461  return false;
462  }
463 
464  LogPrint(BCLog::HTTP, "Initialized HTTP server\n");
465  int workQueueDepth = std::max((long)gArgs.GetIntArg("-rpcworkqueue", DEFAULT_HTTP_WORKQUEUE), 1L);
466  LogDebug(BCLog::HTTP, "creating work queue of depth %d\n", workQueueDepth);
467 
468  g_work_queue = std::make_unique<WorkQueue<HTTPClosure>>(workQueueDepth);
469  // transfer ownership to eventBase/HTTP via .release()
470  eventBase = base_ctr.release();
471  eventHTTP = http_ctr.release();
472  return true;
473 }
474 
475 void UpdateHTTPServerLogging(bool enable) {
476  if (enable) {
477  event_enable_debug_logging(EVENT_DBG_ALL);
478  } else {
479  event_enable_debug_logging(EVENT_DBG_NONE);
480  }
481 }
482 
483 static std::thread g_thread_http;
484 static std::vector<std::thread> g_thread_http_workers;
485 
487 {
488  int rpcThreads = std::max((long)gArgs.GetIntArg("-rpcthreads", DEFAULT_HTTP_THREADS), 1L);
489  LogInfo("Starting HTTP server with %d worker threads\n", rpcThreads);
490  g_thread_http = std::thread(ThreadHTTP, eventBase);
491 
492  for (int i = 0; i < rpcThreads; i++) {
493  g_thread_http_workers.emplace_back(HTTPWorkQueueRun, g_work_queue.get(), i);
494  }
495 }
496 
498 {
499  LogPrint(BCLog::HTTP, "Interrupting HTTP server\n");
500  if (eventHTTP) {
501  // Reject requests on current connections
502  evhttp_set_gencb(eventHTTP, http_reject_request_cb, nullptr);
503  }
504  if (g_work_queue) {
505  g_work_queue->Interrupt();
506  }
507 }
508 
510 {
511  LogPrint(BCLog::HTTP, "Stopping HTTP server\n");
512  if (g_work_queue) {
513  LogPrint(BCLog::HTTP, "Waiting for HTTP worker threads to exit\n");
514  for (auto& thread : g_thread_http_workers) {
515  thread.join();
516  }
517  g_thread_http_workers.clear();
518  }
519  // Unlisten sockets, these are what make the event loop running, which means
520  // that after this and all connections are closed the event loop will quit.
521  for (evhttp_bound_socket *socket : boundSockets) {
522  evhttp_del_accept_socket(eventHTTP, socket);
523  }
524  boundSockets.clear();
525  {
526  if (const auto n_connections{g_requests.CountActiveConnections()}; n_connections != 0) {
527  LogPrint(BCLog::HTTP, "Waiting for %d connections to stop HTTP server\n", n_connections);
528  }
530  }
531  if (eventHTTP) {
532  // Schedule a callback to call evhttp_free in the event base thread, so
533  // that evhttp_free does not need to be called again after the handling
534  // of unfinished request connections that follows.
535  event_base_once(eventBase, -1, EV_TIMEOUT, [](evutil_socket_t, short, void*) {
536  evhttp_free(eventHTTP);
537  eventHTTP = nullptr;
538  }, nullptr, nullptr);
539  }
540  if (eventBase) {
541  LogPrint(BCLog::HTTP, "Waiting for HTTP event thread to exit\n");
542  if (g_thread_http.joinable()) g_thread_http.join();
543  event_base_free(eventBase);
544  eventBase = nullptr;
545  }
546  g_work_queue.reset();
547  LogPrint(BCLog::HTTP, "Stopped HTTP server\n");
548 }
549 
550 struct event_base* EventBase()
551 {
552  return eventBase;
553 }
554 
555 static void httpevent_callback_fn(evutil_socket_t, short, void* data)
556 {
557  // Static handler: simply call inner handler
558  HTTPEvent *self = static_cast<HTTPEvent*>(data);
559  self->handler();
560  if (self->deleteWhenTriggered)
561  delete self;
562 }
563 
564 HTTPEvent::HTTPEvent(struct event_base* base, bool _deleteWhenTriggered, const std::function<void()>& _handler):
565  deleteWhenTriggered(_deleteWhenTriggered), handler(_handler)
566 {
567  ev = event_new(base, -1, 0, httpevent_callback_fn, this);
568  assert(ev);
569 }
571 {
572  event_free(ev);
573 }
574 void HTTPEvent::trigger(struct timeval* tv)
575 {
576  if (tv == nullptr)
577  event_active(ev, 0, 0); // immediately trigger event in main thread
578  else
579  evtimer_add(ev, tv); // trigger after timeval passed
580 }
581 HTTPRequest::HTTPRequest(struct evhttp_request* _req, const util::SignalInterrupt& interrupt, bool _replySent)
582  : req(_req), m_interrupt(interrupt), replySent(_replySent)
583 {
584 }
585 
587 {
588  if (!replySent) {
589  // Keep track of whether reply was sent to avoid request leaks
590  LogPrintf("%s: Unhandled request\n", __func__);
591  WriteReply(HTTP_INTERNAL_SERVER_ERROR, "Unhandled request");
592  }
593  // evhttpd cleans up the request, as long as a reply was sent.
594 }
595 
596 std::pair<bool, std::string> HTTPRequest::GetHeader(const std::string& hdr) const
597 {
598  const struct evkeyvalq* headers = evhttp_request_get_input_headers(req);
599  assert(headers);
600  const char* val = evhttp_find_header(headers, hdr.c_str());
601  if (val)
602  return std::make_pair(true, val);
603  else
604  return std::make_pair(false, "");
605 }
606 
608 {
609  struct evbuffer* buf = evhttp_request_get_input_buffer(req);
610  if (!buf)
611  return "";
612  size_t size = evbuffer_get_length(buf);
619  const char* data = (const char*)evbuffer_pullup(buf, size);
620  if (!data) // returns nullptr in case of empty buffer
621  return "";
622  std::string rv(data, size);
623  evbuffer_drain(buf, size);
624  return rv;
625 }
626 
627 void HTTPRequest::WriteHeader(const std::string& hdr, const std::string& value)
628 {
629  struct evkeyvalq* headers = evhttp_request_get_output_headers(req);
630  assert(headers);
631  evhttp_add_header(headers, hdr.c_str(), value.c_str());
632 }
633 
639 void HTTPRequest::WriteReply(int nStatus, const std::string& strReply)
640 {
641  assert(!replySent && req);
642  if (m_interrupt) {
643  WriteHeader("Connection", "close");
644  }
645  // Send event to main http thread to send reply message
646  struct evbuffer* evb = evhttp_request_get_output_buffer(req);
647  assert(evb);
648  evbuffer_add(evb, strReply.data(), strReply.size());
649  auto req_copy = req;
650  HTTPEvent* ev = new HTTPEvent(eventBase, true, [req_copy, nStatus]{
651  evhttp_send_reply(req_copy, nStatus, nullptr, nullptr);
652  // Re-enable reading from the socket. This is the second part of the libevent
653  // workaround above.
654  if (event_get_version_number() >= 0x02010600 && event_get_version_number() < 0x02010900) {
655  evhttp_connection* conn = evhttp_request_get_connection(req_copy);
656  if (conn) {
657  bufferevent* bev = evhttp_connection_get_bufferevent(conn);
658  if (bev) {
659  bufferevent_enable(bev, EV_READ | EV_WRITE);
660  }
661  }
662  }
663  });
664  ev->trigger(nullptr);
665  replySent = true;
666  req = nullptr; // transferred back to main thread
667 }
668 
670 {
671  evhttp_connection* con = evhttp_request_get_connection(req);
672  CService peer;
673  if (con) {
674  // evhttp retains ownership over returned address string
675  const char* address = "";
676  uint16_t port = 0;
677 
678 #ifdef HAVE_EVHTTP_CONNECTION_GET_PEER_CONST_CHAR
679  evhttp_connection_get_peer(con, &address, &port);
680 #else
681  evhttp_connection_get_peer(con, (char**)&address, &port);
682 #endif // HAVE_EVHTTP_CONNECTION_GET_PEER_CONST_CHAR
683 
684  peer = MaybeFlipIPv6toCJDNS(LookupNumeric(address, port));
685  }
686  return peer;
687 }
688 
689 std::string HTTPRequest::GetURI() const
690 {
691  return evhttp_request_get_uri(req);
692 }
693 
695 {
696  switch (evhttp_request_get_command(req)) {
697  case EVHTTP_REQ_GET:
698  return GET;
699  case EVHTTP_REQ_POST:
700  return POST;
701  case EVHTTP_REQ_HEAD:
702  return HEAD;
703  case EVHTTP_REQ_PUT:
704  return PUT;
705  default:
706  return UNKNOWN;
707  }
708 }
709 
710 std::optional<std::string> HTTPRequest::GetQueryParameter(const std::string& key) const
711 {
712  const char* uri{evhttp_request_get_uri(req)};
713 
714  return GetQueryParameterFromUri(uri, key);
715 }
716 
717 std::optional<std::string> GetQueryParameterFromUri(const char* uri, const std::string& key)
718 {
719  evhttp_uri* uri_parsed{evhttp_uri_parse(uri)};
720  if (!uri_parsed) {
721  throw std::runtime_error("URI parsing failed, it likely contained RFC 3986 invalid characters");
722  }
723  const char* query{evhttp_uri_get_query(uri_parsed)};
724  std::optional<std::string> result;
725 
726  if (query) {
727  // Parse the query string into a key-value queue and iterate over it
728  struct evkeyvalq params_q;
729  evhttp_parse_query_str(query, &params_q);
730 
731  for (struct evkeyval* param{params_q.tqh_first}; param != nullptr; param = param->next.tqe_next) {
732  if (param->key == key) {
733  result = param->value;
734  break;
735  }
736  }
737  evhttp_clear_headers(&params_q);
738  }
739  evhttp_uri_free(uri_parsed);
740 
741  return result;
742 }
743 
744 void RegisterHTTPHandler(const std::string &prefix, bool exactMatch, const HTTPRequestHandler &handler)
745 {
746  LogPrint(BCLog::HTTP, "Registering HTTP handler for %s (exactmatch %d)\n", prefix, exactMatch);
748  pathHandlers.emplace_back(prefix, exactMatch, handler);
749 }
750 
751 void UnregisterHTTPHandler(const std::string &prefix, bool exactMatch)
752 {
754  std::vector<HTTPPathHandler>::iterator i = pathHandlers.begin();
755  std::vector<HTTPPathHandler>::iterator iend = pathHandlers.end();
756  for (; i != iend; ++i)
757  if (i->prefix == prefix && i->exactMatch == exactMatch)
758  break;
759  if (i != iend)
760  {
761  LogPrint(BCLog::HTTP, "Unregistering HTTP handler for %s (exactmatch %d)\n", prefix, exactMatch);
762  pathHandlers.erase(i);
763  }
764 }
ArgsManager gArgs
Definition: args.cpp:41
const CBaseChainParams & BaseParams()
Return the currently selected parameters.
#define Assert(val)
Identity function.
Definition: check.h:77
std::vector< std::string > GetArgs(const std::string &strArg) const
Return a vector of strings of the given argument.
Definition: args.cpp:360
bool IsArgSet(const std::string &strArg) const
Return true if the given argument has been manually set.
Definition: args.cpp:369
int64_t GetIntArg(const std::string &strArg, int64_t nDefault) const
Return integer argument or default value.
Definition: args.cpp:480
Network address.
Definition: netaddress.h:112
bool IsValid() const
Definition: netaddress.cpp:425
A combination of a network address (CNetAddr) and a (TCP) port.
Definition: netaddress.h:531
Different type to mark Mutex at global scope.
Definition: sync.h:140
Event handler closure.
Definition: httpserver.h:151
Event class.
Definition: httpserver.h:160
struct event * ev
Definition: httpserver.h:177
std::function< void()> handler
Definition: httpserver.h:175
HTTPEvent(struct event_base *base, bool deleteWhenTriggered, const std::function< void()> &handler)
Create a new event.
Definition: httpserver.cpp:564
void trigger(struct timeval *tv)
Trigger the event.
Definition: httpserver.cpp:574
std::optional< std::string > GetQueryParameter(const std::string &key) const
Get the query parameter value from request uri for a specified key, or std::nullopt if the key is not...
Definition: httpserver.cpp:710
bool replySent
Definition: httpserver.h:65
std::pair< bool, std::string > GetHeader(const std::string &hdr) const
Get the request header specified by hdr, or an empty string.
Definition: httpserver.cpp:596
std::string GetURI() const
Get requested URI.
Definition: httpserver.cpp:689
void WriteReply(int nStatus, const std::string &strReply="")
Write HTTP reply.
Definition: httpserver.cpp:639
void WriteHeader(const std::string &hdr, const std::string &value)
Write output header.
Definition: httpserver.cpp:627
HTTPRequest(struct evhttp_request *req, const util::SignalInterrupt &interrupt, bool replySent=false)
Definition: httpserver.cpp:581
struct evhttp_request * req
Definition: httpserver.h:63
RequestMethod GetRequestMethod() const
Get request method.
Definition: httpserver.cpp:694
const util::SignalInterrupt & m_interrupt
Definition: httpserver.h:64
std::string ReadBody()
Read request body.
Definition: httpserver.cpp:607
CService GetPeer() const
Get CService (address:ip) for the origin of the http request.
Definition: httpserver.cpp:669
Helps keep track of open evhttp_connections with active evhttp_requests
Definition: httpserver.cpp:159
void WaitUntilEmpty() const EXCLUSIVE_LOCKS_REQUIRED(!m_mutex)
Wait until there are no more connections with active requests in the tracker.
Definition: httpserver.cpp:200
std::unordered_map< const evhttp_connection *, size_t > m_tracker GUARDED_BY(m_mutex)
For each connection, keep a counter of how many requests are open.
size_t CountActiveConnections() const EXCLUSIVE_LOCKS_REQUIRED(!m_mutex)
Definition: httpserver.cpp:195
void AddRequest(evhttp_request *req) EXCLUSIVE_LOCKS_REQUIRED(!m_mutex)
Increase request counter for the associated connection by 1.
Definition: httpserver.cpp:173
void RemoveConnection(const evhttp_connection *conn) EXCLUSIVE_LOCKS_REQUIRED(!m_mutex)
Remove a connection entirely.
Definition: httpserver.cpp:189
void RemoveRequest(evhttp_request *req) EXCLUSIVE_LOCKS_REQUIRED(!m_mutex)
Decrease request counter for the associated connection by 1, remove connection if counter is 0.
Definition: httpserver.cpp:179
std::condition_variable m_cv
Definition: httpserver.cpp:162
void RemoveConnectionInternal(const decltype(m_tracker)::iterator it) EXCLUSIVE_LOCKS_REQUIRED(m_mutex)
Definition: httpserver.cpp:166
HTTP request work item.
Definition: httpserver.cpp:52
void operator()() override
Definition: httpserver.cpp:58
std::unique_ptr< HTTPRequest > req
Definition: httpserver.cpp:63
HTTPWorkItem(std::unique_ptr< HTTPRequest > _req, const std::string &_path, const HTTPRequestHandler &_func)
Definition: httpserver.cpp:54
std::string path
Definition: httpserver.cpp:66
HTTPRequestHandler func
Definition: httpserver.cpp:67
Simple work queue for distributing work over multiple threads.
Definition: httpserver.cpp:75
const size_t maxDepth
Definition: httpserver.cpp:80
bool Enqueue(WorkItem *item) EXCLUSIVE_LOCKS_REQUIRED(!cs)
Enqueue a work item.
Definition: httpserver.cpp:91
~WorkQueue()=default
Precondition: worker threads have all stopped (they have been joined).
std::condition_variable cond GUARDED_BY(cs)
void Interrupt() EXCLUSIVE_LOCKS_REQUIRED(!cs)
Interrupt and exit loops.
Definition: httpserver.cpp:119
Mutex cs
Definition: httpserver.cpp:77
bool running GUARDED_BY(cs)
Definition: httpserver.cpp:80
WorkQueue(size_t _maxDepth)
Definition: httpserver.cpp:84
void Run() EXCLUSIVE_LOCKS_REQUIRED(!cs)
Thread function.
Definition: httpserver.cpp:102
std::deque< std::unique_ptr< WorkItem > > queue GUARDED_BY(cs)
Helper class that manages an interrupt flag, and allows a thread or signal to interrupt another threa...
raii_evhttp obtain_evhttp(struct event_base *base)
Definition: events.h:41
raii_event_base obtain_event_base()
Definition: events.h:30
static struct evhttp * eventHTTP
HTTP server.
Definition: httpserver.cpp:143
void InterruptHTTPServer()
Interrupt HTTP server threads.
Definition: httpserver.cpp:497
static void http_request_cb(struct evhttp_request *req, void *arg)
HTTP request callback.
Definition: httpserver.cpp:262
std::optional< std::string > GetQueryParameterFromUri(const char *uri, const std::string &key)
Get the query parameter value from request uri for a specified key, or std::nullopt if the key is not...
Definition: httpserver.cpp:717
static bool HTTPBindAddresses(struct evhttp *http)
Bind HTTP server to specified addresses.
Definition: httpserver.cpp:359
static std::vector< evhttp_bound_socket * > boundSockets
Bound listening sockets.
Definition: httpserver.cpp:152
void UnregisterHTTPHandler(const std::string &prefix, bool exactMatch)
Unregister handler for prefix.
Definition: httpserver.cpp:751
void RegisterHTTPHandler(const std::string &prefix, bool exactMatch, const HTTPRequestHandler &handler)
Register handler for prefix.
Definition: httpserver.cpp:744
struct event_base * EventBase()
Return evhttp event base.
Definition: httpserver.cpp:550
void StartHTTPServer()
Start HTTP server.
Definition: httpserver.cpp:486
static struct event_base * eventBase
HTTP module state.
Definition: httpserver.cpp:141
void UpdateHTTPServerLogging(bool enable)
Change logging level for libevent.
Definition: httpserver.cpp:475
static std::thread g_thread_http
Definition: httpserver.cpp:483
static std::unique_ptr< WorkQueue< HTTPClosure > > g_work_queue
Work queue for handling longer requests off the event loop thread.
Definition: httpserver.cpp:147
static void httpevent_callback_fn(evutil_socket_t, short, void *data)
Definition: httpserver.cpp:555
std::string RequestMethodString(HTTPRequest::RequestMethod m)
HTTP request method as string - use for logging only.
Definition: httpserver.cpp:244
static HTTPRequestTracker g_requests
Track active requests.
Definition: httpserver.cpp:207
bool InitHTTPServer(const util::SignalInterrupt &interrupt)
Initialize HTTP server.
Definition: httpserver.cpp:428
static void HTTPWorkQueueRun(WorkQueue< HTTPClosure > *queue, int worker_num)
Simple wrapper to set thread name and run work queue.
Definition: httpserver.cpp:401
static bool InitHTTPAllowList()
Initialize ACL list for HTTP server.
Definition: httpserver.cpp:221
static void libevent_log_cb(int severity, const char *msg)
libevent event log callback
Definition: httpserver.cpp:408
static std::vector< CSubNet > rpc_allow_subnets
List of subnets to allow RPC connections from.
Definition: httpserver.cpp:145
static bool ClientAllowed(const CNetAddr &netaddr)
Check if a network address is allowed to access the HTTP server.
Definition: httpserver.cpp:210
static void http_reject_request_cb(struct evhttp_request *req, void *)
Callback to reject HTTP requests after shutdown.
Definition: httpserver.cpp:342
static std::vector< HTTPPathHandler > pathHandlers GUARDED_BY(g_httppathhandlers_mutex)
static const size_t MAX_HEADERS_SIZE
Maximum size of http request (request line + headers)
Definition: httpserver.cpp:48
void StopHTTPServer()
Stop HTTP server.
Definition: httpserver.cpp:509
static void ThreadHTTP(struct event_base *base)
Event dispatcher thread.
Definition: httpserver.cpp:349
static std::vector< std::thread > g_thread_http_workers
Definition: httpserver.cpp:484
static GlobalMutex g_httppathhandlers_mutex
Handlers for (sub)paths.
Definition: httpserver.cpp:149
static const int DEFAULT_HTTP_SERVER_TIMEOUT
Definition: httpserver.h:18
static const int DEFAULT_HTTP_WORKQUEUE
Definition: httpserver.h:17
static const int DEFAULT_HTTP_THREADS
Definition: httpserver.h:16
std::function< bool(HTTPRequest *req, const std::string &)> HTTPRequestHandler
Handler for requests to a certain HTTP path.
Definition: httpserver.h:43
CClientUIInterface uiInterface
BCLog::Logger & LogInstance()
Definition: logging.cpp:19
#define LogPrintLevel(category, level,...)
Definition: logging.h:251
#define LogPrint(category,...)
Definition: logging.h:263
#define LogInfo(...)
Definition: logging.h:239
#define LogDebug(category,...)
Definition: logging.h:259
#define LogPrintf(...)
Definition: logging.h:244
Level
Definition: logging.h:74
@ HTTP
Definition: logging.h:44
@ LIBEVENT
Definition: logging.h:58
void ThreadRename(std::string &&)
Rename a thread both in terms of an internal (in-memory) name as well as its system thread name.
Definition: threadnames.cpp:59
CSubNet LookupSubNet(const std::string &subnet_str)
Parse and resolve a specified subnet string into the appropriate internal representation.
Definition: netbase.cpp:745
CService MaybeFlipIPv6toCJDNS(const CService &service)
If an IPv6 address belongs to the address range used by the CJDNS network and the CJDNS network is re...
Definition: netbase.cpp:871
std::vector< CNetAddr > LookupHost(const std::string &name, unsigned int nMaxSolutions, bool fAllowLookup, DNSLookupFn dns_lookup_function)
Resolve a host string to its corresponding network addresses.
Definition: netbase.cpp:166
CService LookupNumeric(const std::string &name, uint16_t portDefault, DNSLookupFn dns_lookup_function)
Resolve a service string with a numeric IP to its first corresponding service.
Definition: netbase.cpp:209
const char * prefix
Definition: rest.cpp:1007
bool(* handler)(const std::any &context, HTTPRequest *req, const std::string &strReq)
Definition: rest.cpp:1008
@ HTTP_BAD_METHOD
Definition: protocol.h:17
@ HTTP_SERVICE_UNAVAILABLE
Definition: protocol.h:19
@ HTTP_NOT_FOUND
Definition: protocol.h:16
@ HTTP_FORBIDDEN
Definition: protocol.h:15
@ HTTP_INTERNAL_SERVER_ERROR
Definition: protocol.h:18
static constexpr uint64_t MAX_SIZE
The maximum size of a serialized object in bytes or number of elements (for eg vectors) when the size...
Definition: serialize.h:32
@ SAFE_CHARS_URI
Chars allowed in URIs (RFC 3986)
Definition: strencodings.h:32
std::string prefix
Definition: httpserver.cpp:133
HTTPPathHandler(std::string _prefix, bool _exactMatch, HTTPRequestHandler _handler)
Definition: httpserver.cpp:129
HTTPRequestHandler handler
Definition: httpserver.cpp:135
#define WAIT_LOCK(cs, name)
Definition: sync.h:262
#define LOCK(cs)
Definition: sync.h:257
#define WITH_LOCK(cs, code)
Run code while locking a mutex.
Definition: sync.h:301
#define EXCLUSIVE_LOCKS_REQUIRED(...)
Definition: threadsafety.h:49
#define strprintf
Format arguments and return the string or write to given std::ostream (see tinyformat::format doc for...
Definition: tinyformat.h:1162
bilingual_str Untranslated(std::string original)
Mark a bilingual_str as untranslated.
Definition: translation.h:48
bool SplitHostPort(std::string_view in, uint16_t &portOut, std::string &hostOut)
Splits socket address string into host string and port value.
std::string SanitizeString(std::string_view str, int rule)
Remove unsafe chars.
assert(!tx.IsCoinBase())