httplib.h 62 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751752753754755756757758759760761762763764765766767768769770771772773774775776777778779780781782783784785786787788789790791792793794795796797798799800801802803804805806807808809810811812813814815816817818819820821822823824825826827828829830831832833834835836837838839840841842843844845846847848849850851852853854855856857858859860861862863864865866867868869870871872873874875876877878879880881882883884885886887888889890891892893894895896897898899900901902903904905906907908909910911912913914915916917918919920921922923924925926927928929930931932933934935936937938939940941942943944945946947948949950951952953954955956957958959960961962963964965966967968969970971972973974975976977978979980981982983984985986987988989990991992993994995996997998999100010011002100310041005100610071008100910101011101210131014101510161017101810191020102110221023102410251026102710281029103010311032103310341035103610371038103910401041104210431044104510461047104810491050105110521053105410551056105710581059106010611062106310641065106610671068106910701071107210731074107510761077107810791080108110821083108410851086108710881089109010911092109310941095109610971098109911001101110211031104110511061107110811091110111111121113111411151116111711181119112011211122112311241125112611271128112911301131113211331134113511361137113811391140114111421143114411451146114711481149115011511152115311541155115611571158115911601161116211631164116511661167116811691170117111721173117411751176117711781179118011811182118311841185118611871188118911901191119211931194119511961197119811991200120112021203120412051206120712081209121012111212121312141215121612171218121912201221122212231224122512261227122812291230123112321233123412351236123712381239124012411242124312441245124612471248124912501251125212531254125512561257125812591260126112621263126412651266126712681269127012711272127312741275127612771278127912801281128212831284128512861287128812891290129112921293129412951296129712981299130013011302130313041305130613071308130913101311131213131314131513161317131813191320132113221323132413251326132713281329133013311332133313341335133613371338133913401341134213431344134513461347134813491350135113521353135413551356135713581359136013611362136313641365136613671368136913701371137213731374137513761377137813791380138113821383138413851386138713881389139013911392139313941395139613971398139914001401140214031404140514061407140814091410141114121413141414151416141714181419142014211422142314241425142614271428142914301431143214331434143514361437143814391440144114421443144414451446144714481449145014511452145314541455145614571458145914601461146214631464146514661467146814691470147114721473147414751476147714781479148014811482148314841485148614871488148914901491149214931494149514961497149814991500150115021503150415051506150715081509151015111512151315141515151615171518151915201521152215231524152515261527152815291530153115321533153415351536153715381539154015411542154315441545154615471548154915501551155215531554155515561557155815591560156115621563156415651566156715681569157015711572157315741575157615771578157915801581158215831584158515861587158815891590159115921593159415951596159715981599160016011602160316041605160616071608160916101611161216131614161516161617161816191620162116221623162416251626162716281629163016311632163316341635163616371638163916401641164216431644164516461647164816491650165116521653165416551656165716581659166016611662166316641665166616671668166916701671167216731674167516761677167816791680168116821683168416851686168716881689169016911692169316941695169616971698169917001701170217031704170517061707170817091710171117121713171417151716171717181719172017211722172317241725172617271728172917301731173217331734173517361737173817391740174117421743174417451746174717481749175017511752175317541755175617571758175917601761176217631764176517661767176817691770177117721773177417751776177717781779178017811782178317841785178617871788178917901791179217931794179517961797179817991800180118021803180418051806180718081809181018111812181318141815181618171818181918201821182218231824182518261827182818291830183118321833183418351836183718381839184018411842184318441845184618471848184918501851185218531854185518561857185818591860186118621863186418651866186718681869187018711872187318741875187618771878187918801881188218831884188518861887188818891890189118921893189418951896189718981899190019011902190319041905190619071908190919101911191219131914191519161917191819191920192119221923192419251926192719281929193019311932193319341935193619371938193919401941194219431944194519461947194819491950195119521953195419551956195719581959196019611962196319641965196619671968196919701971197219731974197519761977197819791980198119821983198419851986198719881989199019911992199319941995199619971998199920002001200220032004200520062007200820092010201120122013201420152016201720182019202020212022202320242025202620272028202920302031203220332034203520362037203820392040204120422043204420452046204720482049205020512052205320542055205620572058205920602061206220632064206520662067206820692070207120722073207420752076207720782079208020812082208320842085208620872088208920902091209220932094209520962097209820992100210121022103210421052106210721082109211021112112211321142115211621172118211921202121212221232124212521262127212821292130213121322133213421352136213721382139214021412142214321442145214621472148214921502151215221532154215521562157215821592160216121622163216421652166216721682169217021712172217321742175217621772178217921802181218221832184218521862187218821892190219121922193219421952196219721982199220022012202220322042205220622072208220922102211221222132214221522162217221822192220222122222223222422252226222722282229223022312232223322342235223622372238223922402241224222432244224522462247224822492250225122522253225422552256225722582259226022612262226322642265226622672268226922702271227222732274227522762277227822792280228122822283228422852286228722882289229022912292229322942295229622972298229923002301230223032304230523062307230823092310231123122313231423152316231723182319232023212322232323242325232623272328232923302331233223332334233523362337233823392340234123422343234423452346234723482349235023512352235323542355235623572358235923602361236223632364236523662367236823692370237123722373237423752376237723782379238023812382238323842385238623872388238923902391239223932394239523962397239823992400240124022403240424052406240724082409241024112412241324142415241624172418241924202421242224232424242524262427242824292430243124322433243424352436243724382439244024412442244324442445244624472448244924502451245224532454245524562457245824592460246124622463246424652466246724682469247024712472247324742475247624772478247924802481248224832484248524862487248824892490249124922493249424952496249724982499250025012502250325042505250625072508
  1. //
  2. // httplib.h
  3. //
  4. // Copyright (c) 2017 Yuji Hirose. All rights reserved.
  5. // MIT License
  6. //
  7. #ifndef CPPHTTPLIB_HTTPLIB_H
  8. #define CPPHTTPLIB_HTTPLIB_H
  9. #ifdef _WIN32
  10. #ifndef _CRT_SECURE_NO_WARNINGS
  11. #define _CRT_SECURE_NO_WARNINGS
  12. #endif //_CRT_SECURE_NO_WARNINGS
  13. #ifndef _CRT_NONSTDC_NO_DEPRECATE
  14. #define _CRT_NONSTDC_NO_DEPRECATE
  15. #endif //_CRT_NONSTDC_NO_DEPRECATE
  16. #if defined(_MSC_VER) && _MSC_VER < 1900
  17. #define snprintf _snprintf_s
  18. #endif // _MSC_VER
  19. #ifndef S_ISREG
  20. #define S_ISREG(m) (((m)&S_IFREG)==S_IFREG)
  21. #endif //S_ISREG
  22. #ifndef S_ISDIR
  23. #define S_ISDIR(m) (((m)&S_IFDIR)==S_IFDIR)
  24. #endif //S_ISDIR
  25. #ifndef NOMINMAX
  26. #define NOMINMAX
  27. #endif //NOMINMAX
  28. #include <io.h>
  29. #include <winsock2.h>
  30. #include <ws2tcpip.h>
  31. #ifndef strcasecmp
  32. #define strcasecmp _stricmp
  33. #endif //strcasecmp
  34. typedef SOCKET socket_t;
  35. #else
  36. #include <pthread.h>
  37. #include <unistd.h>
  38. #include <netdb.h>
  39. #include <cstring>
  40. #include <netinet/in.h>
  41. #include <arpa/inet.h>
  42. #include <signal.h>
  43. #include <sys/socket.h>
  44. #include <sys/select.h>
  45. typedef int socket_t;
  46. #define INVALID_SOCKET (-1)
  47. #endif //_WIN32
  48. #include <fstream>
  49. #include <functional>
  50. #include <map>
  51. #include <memory>
  52. #include <mutex>
  53. #include <regex>
  54. #include <string>
  55. #include <thread>
  56. #include <sys/stat.h>
  57. #include <fcntl.h>
  58. #include <assert.h>
  59. #ifdef CPPHTTPLIB_OPENSSL_SUPPORT
  60. #include <openssl/ssl.h>
  61. #include <openssl/err.h>
  62. #endif
  63. #ifdef CPPHTTPLIB_ZLIB_SUPPORT
  64. #include <zlib.h>
  65. #endif
  66. /*
  67. * Configuration
  68. */
  69. #define CPPHTTPLIB_KEEPALIVE_TIMEOUT_SECOND 5
  70. #define CPPHTTPLIB_KEEPALIVE_TIMEOUT_USECOND 0
  71. namespace httplib
  72. {
  73. namespace detail {
  74. struct ci {
  75. bool operator() (const std::string & s1, const std::string & s2) const {
  76. return std::lexicographical_compare(
  77. s1.begin(), s1.end(),
  78. s2.begin(), s2.end(),
  79. [](char c1, char c2) {
  80. return ::tolower(c1) < ::tolower(c2);
  81. });
  82. }
  83. };
  84. } // namespace detail
  85. enum class HttpVersion { v1_0 = 0, v1_1 };
  86. typedef std::multimap<std::string, std::string, detail::ci> Headers;
  87. template<typename uint64_t, typename... Args>
  88. std::pair<std::string, std::string> make_range_header(uint64_t value, Args... args);
  89. typedef std::multimap<std::string, std::string> Params;
  90. typedef std::smatch Match;
  91. typedef std::function<bool (uint64_t current, uint64_t total)> Progress;
  92. struct MultipartFile {
  93. std::string filename;
  94. std::string content_type;
  95. size_t offset = 0;
  96. size_t length = 0;
  97. };
  98. typedef std::multimap<std::string, MultipartFile> MultipartFiles;
  99. struct Request {
  100. std::string version;
  101. std::string method;
  102. std::string target;
  103. std::string path;
  104. Headers headers;
  105. std::string body;
  106. Params params;
  107. MultipartFiles files;
  108. Match matches;
  109. Progress progress;
  110. bool has_header(const char* key) const;
  111. std::string get_header_value(const char* key, size_t id = 0) const;
  112. size_t get_header_value_count(const char* key) const;
  113. void set_header(const char* key, const char* val);
  114. bool has_param(const char* key) const;
  115. std::string get_param_value(const char* key, size_t id = 0) const;
  116. size_t get_param_value_count(const char* key) const;
  117. bool has_file(const char* key) const;
  118. MultipartFile get_file_value(const char* key) const;
  119. };
  120. struct Response {
  121. std::string version;
  122. int status;
  123. Headers headers;
  124. std::string body;
  125. std::function<std::string (uint64_t offset)> streamcb;
  126. bool has_header(const char* key) const;
  127. std::string get_header_value(const char* key, size_t id = 0) const;
  128. size_t get_header_value_count(const char* key) const;
  129. void set_header(const char* key, const char* val);
  130. void set_redirect(const char* uri);
  131. void set_content(const char* s, size_t n, const char* content_type);
  132. void set_content(const std::string& s, const char* content_type);
  133. Response() : status(-1) {}
  134. };
  135. class Stream {
  136. public:
  137. virtual ~Stream() {}
  138. virtual int read(char* ptr, size_t size) = 0;
  139. virtual int write(const char* ptr, size_t size1) = 0;
  140. virtual int write(const char* ptr) = 0;
  141. virtual std::string get_remote_addr() const = 0;
  142. template <typename ...Args>
  143. void write_format(const char* fmt, const Args& ...args);
  144. };
  145. class SocketStream : public Stream {
  146. public:
  147. SocketStream(socket_t sock);
  148. virtual ~SocketStream();
  149. virtual int read(char* ptr, size_t size);
  150. virtual int write(const char* ptr, size_t size);
  151. virtual int write(const char* ptr);
  152. virtual std::string get_remote_addr() const;
  153. private:
  154. socket_t sock_;
  155. };
  156. class BufferStream : public Stream {
  157. public:
  158. BufferStream() {}
  159. virtual ~BufferStream() {}
  160. virtual int read(char* ptr, size_t size);
  161. virtual int write(const char* ptr, size_t size);
  162. virtual int write(const char* ptr);
  163. virtual std::string get_remote_addr() const;
  164. const std::string& get_buffer() const;
  165. private:
  166. std::string buffer;
  167. };
  168. class Server {
  169. public:
  170. typedef std::function<void (const Request&, Response&)> Handler;
  171. typedef std::function<void (const Request&, const Response&)> Logger;
  172. Server();
  173. virtual ~Server();
  174. virtual bool is_valid() const;
  175. Server& Get(const char* pattern, Handler handler);
  176. Server& Post(const char* pattern, Handler handler);
  177. Server& Put(const char* pattern, Handler handler);
  178. Server& Delete(const char* pattern, Handler handler);
  179. Server& Options(const char* pattern, Handler handler);
  180. bool set_base_dir(const char* path);
  181. void set_error_handler(Handler handler);
  182. void set_logger(Logger logger);
  183. void set_keep_alive_max_count(size_t count);
  184. int bind_to_any_port(const char* host, int socket_flags = 0);
  185. bool listen_after_bind();
  186. bool listen(const char* host, int port, int socket_flags = 0);
  187. bool is_running() const;
  188. void stop();
  189. protected:
  190. bool process_request(Stream& strm, bool last_connection, bool& connection_close);
  191. size_t keep_alive_max_count_;
  192. private:
  193. typedef std::vector<std::pair<std::regex, Handler>> Handlers;
  194. socket_t create_server_socket(const char* host, int port, int socket_flags) const;
  195. int bind_internal(const char* host, int port, int socket_flags);
  196. bool listen_internal();
  197. bool routing(Request& req, Response& res);
  198. bool handle_file_request(Request& req, Response& res);
  199. bool dispatch_request(Request& req, Response& res, Handlers& handlers);
  200. bool parse_request_line(const char* s, Request& req);
  201. void write_response(Stream& strm, bool last_connection, const Request& req, Response& res);
  202. virtual bool read_and_close_socket(socket_t sock);
  203. bool is_running_;
  204. socket_t svr_sock_;
  205. std::string base_dir_;
  206. Handlers get_handlers_;
  207. Handlers post_handlers_;
  208. Handlers put_handlers_;
  209. Handlers delete_handlers_;
  210. Handlers options_handlers_;
  211. Handler error_handler_;
  212. Logger logger_;
  213. // TODO: Use thread pool...
  214. std::mutex running_threads_mutex_;
  215. int running_threads_;
  216. };
  217. class Client {
  218. public:
  219. Client(
  220. const char* host,
  221. int port = 80,
  222. time_t timeout_sec = 300);
  223. virtual ~Client();
  224. virtual bool is_valid() const;
  225. std::shared_ptr<Response> Get(const char* path, Progress progress = nullptr);
  226. std::shared_ptr<Response> Get(const char* path, const Headers& headers, Progress progress = nullptr);
  227. std::shared_ptr<Response> Head(const char* path);
  228. std::shared_ptr<Response> Head(const char* path, const Headers& headers);
  229. std::shared_ptr<Response> Post(const char* path, const std::string& body, const char* content_type);
  230. std::shared_ptr<Response> Post(const char* path, const Headers& headers, const std::string& body, const char* content_type);
  231. std::shared_ptr<Response> Post(const char* path, const Params& params);
  232. std::shared_ptr<Response> Post(const char* path, const Headers& headers, const Params& params);
  233. std::shared_ptr<Response> Put(const char* path, const std::string& body, const char* content_type);
  234. std::shared_ptr<Response> Put(const char* path, const Headers& headers, const std::string& body, const char* content_type);
  235. std::shared_ptr<Response> Delete(const char* path);
  236. std::shared_ptr<Response> Delete(const char* path, const Headers& headers);
  237. std::shared_ptr<Response> Options(const char* path);
  238. std::shared_ptr<Response> Options(const char* path, const Headers& headers);
  239. bool send(Request& req, Response& res);
  240. protected:
  241. bool process_request(Stream& strm, Request& req, Response& res, bool& connection_close);
  242. const std::string host_;
  243. const int port_;
  244. time_t timeout_sec_;
  245. const std::string host_and_port_;
  246. private:
  247. socket_t create_client_socket() const;
  248. bool read_response_line(Stream& strm, Response& res);
  249. void write_request(Stream& strm, Request& req);
  250. virtual bool read_and_close_socket(socket_t sock, Request& req, Response& res);
  251. virtual bool is_ssl() const;
  252. };
  253. #ifdef CPPHTTPLIB_OPENSSL_SUPPORT
  254. class SSLSocketStream : public Stream {
  255. public:
  256. SSLSocketStream(socket_t sock, SSL* ssl);
  257. virtual ~SSLSocketStream();
  258. virtual int read(char* ptr, size_t size);
  259. virtual int write(const char* ptr, size_t size);
  260. virtual int write(const char* ptr);
  261. virtual std::string get_remote_addr() const;
  262. private:
  263. socket_t sock_;
  264. SSL* ssl_;
  265. };
  266. class SSLServer : public Server {
  267. public:
  268. SSLServer(
  269. const char* cert_path, const char* private_key_path);
  270. virtual ~SSLServer();
  271. virtual bool is_valid() const;
  272. private:
  273. virtual bool read_and_close_socket(socket_t sock);
  274. SSL_CTX* ctx_;
  275. std::mutex ctx_mutex_;
  276. };
  277. class SSLClient : public Client {
  278. public:
  279. SSLClient(
  280. const char* host,
  281. int port = 443,
  282. time_t timeout_sec = 300);
  283. virtual ~SSLClient();
  284. virtual bool is_valid() const;
  285. private:
  286. virtual bool read_and_close_socket(socket_t sock, Request& req, Response& res);
  287. virtual bool is_ssl() const;
  288. SSL_CTX* ctx_;
  289. std::mutex ctx_mutex_;
  290. };
  291. #endif
  292. /*
  293. * Implementation
  294. */
  295. namespace detail {
  296. template <class Fn>
  297. void split(const char* b, const char* e, char d, Fn fn)
  298. {
  299. int i = 0;
  300. int beg = 0;
  301. while (e ? (b + i != e) : (b[i] != '\0')) {
  302. if (b[i] == d) {
  303. fn(&b[beg], &b[i]);
  304. beg = i + 1;
  305. }
  306. i++;
  307. }
  308. if (i) {
  309. fn(&b[beg], &b[i]);
  310. }
  311. }
  312. // NOTE: until the read size reaches `fixed_buffer_size`, use `fixed_buffer`
  313. // to store data. The call can set memory on stack for performance.
  314. class stream_line_reader {
  315. public:
  316. stream_line_reader(Stream& strm, char* fixed_buffer, size_t fixed_buffer_size)
  317. : strm_(strm)
  318. , fixed_buffer_(fixed_buffer)
  319. , fixed_buffer_size_(fixed_buffer_size) {
  320. }
  321. const char* ptr() const {
  322. if (glowable_buffer_.empty()) {
  323. return fixed_buffer_;
  324. } else {
  325. return glowable_buffer_.data();
  326. }
  327. }
  328. bool getline() {
  329. fixed_buffer_used_size_ = 0;
  330. glowable_buffer_.clear();
  331. for (size_t i = 0; ; i++) {
  332. char byte;
  333. auto n = strm_.read(&byte, 1);
  334. if (n < 0) {
  335. return false;
  336. } else if (n == 0) {
  337. if (i == 0) {
  338. return false;
  339. } else {
  340. break;
  341. }
  342. }
  343. append(byte);
  344. if (byte == '\n') {
  345. break;
  346. }
  347. }
  348. return true;
  349. }
  350. private:
  351. void append(char c) {
  352. if (fixed_buffer_used_size_ < fixed_buffer_size_ - 1) {
  353. fixed_buffer_[fixed_buffer_used_size_++] = c;
  354. fixed_buffer_[fixed_buffer_used_size_] = '\0';
  355. } else {
  356. if (glowable_buffer_.empty()) {
  357. assert(fixed_buffer_[fixed_buffer_used_size_] == '\0');
  358. glowable_buffer_.assign(fixed_buffer_, fixed_buffer_used_size_);
  359. }
  360. glowable_buffer_ += c;
  361. }
  362. }
  363. Stream& strm_;
  364. char* fixed_buffer_;
  365. const size_t fixed_buffer_size_;
  366. size_t fixed_buffer_used_size_;
  367. std::string glowable_buffer_;
  368. };
  369. inline int close_socket(socket_t sock)
  370. {
  371. #ifdef _WIN32
  372. return closesocket(sock);
  373. #else
  374. return close(sock);
  375. #endif
  376. }
  377. inline int select_read(socket_t sock, time_t sec, time_t usec)
  378. {
  379. fd_set fds;
  380. FD_ZERO(&fds);
  381. FD_SET(sock, &fds);
  382. timeval tv;
  383. tv.tv_sec = static_cast<long>(sec);
  384. tv.tv_usec = static_cast<long>(usec);
  385. return select(static_cast<int>(sock + 1), &fds, NULL, NULL, &tv);
  386. }
  387. inline bool wait_until_socket_is_ready(socket_t sock, time_t sec, time_t usec)
  388. {
  389. fd_set fdsr;
  390. FD_ZERO(&fdsr);
  391. FD_SET(sock, &fdsr);
  392. auto fdsw = fdsr;
  393. auto fdse = fdsr;
  394. timeval tv;
  395. tv.tv_sec = static_cast<long>(sec);
  396. tv.tv_usec = static_cast<long>(usec);
  397. if (select(static_cast<int>(sock + 1), &fdsr, &fdsw, &fdse, &tv) < 0) {
  398. return false;
  399. } else if (FD_ISSET(sock, &fdsr) || FD_ISSET(sock, &fdsw)) {
  400. int error = 0;
  401. socklen_t len = sizeof(error);
  402. if (getsockopt(sock, SOL_SOCKET, SO_ERROR, (char*)&error, &len) < 0 || error) {
  403. return false;
  404. }
  405. } else {
  406. return false;
  407. }
  408. return true;
  409. }
  410. template <typename T>
  411. inline bool read_and_close_socket(socket_t sock, size_t keep_alive_max_count, T callback)
  412. {
  413. bool ret = false;
  414. if (keep_alive_max_count > 0) {
  415. auto count = keep_alive_max_count;
  416. while (count > 0 &&
  417. detail::select_read(sock,
  418. CPPHTTPLIB_KEEPALIVE_TIMEOUT_SECOND,
  419. CPPHTTPLIB_KEEPALIVE_TIMEOUT_USECOND) > 0) {
  420. SocketStream strm(sock);
  421. auto last_connection = count == 1;
  422. auto connection_close = false;
  423. ret = callback(strm, last_connection, connection_close);
  424. if (!ret || connection_close) {
  425. break;
  426. }
  427. count--;
  428. }
  429. } else {
  430. SocketStream strm(sock);
  431. auto dummy_connection_close = false;
  432. ret = callback(strm, true, dummy_connection_close);
  433. }
  434. close_socket(sock);
  435. return ret;
  436. }
  437. inline int shutdown_socket(socket_t sock)
  438. {
  439. #ifdef _WIN32
  440. return shutdown(sock, SD_BOTH);
  441. #else
  442. return shutdown(sock, SHUT_RDWR);
  443. #endif
  444. }
  445. template <typename Fn>
  446. socket_t create_socket(const char* host, int port, Fn fn, int socket_flags = 0)
  447. {
  448. #ifdef _WIN32
  449. #define SO_SYNCHRONOUS_NONALERT 0x20
  450. #define SO_OPENTYPE 0x7008
  451. int opt = SO_SYNCHRONOUS_NONALERT;
  452. setsockopt(INVALID_SOCKET, SOL_SOCKET, SO_OPENTYPE, (char*)&opt, sizeof(opt));
  453. #endif
  454. // Get address info
  455. struct addrinfo hints;
  456. struct addrinfo *result;
  457. memset(&hints, 0, sizeof(struct addrinfo));
  458. hints.ai_family = AF_UNSPEC;
  459. hints.ai_socktype = SOCK_STREAM;
  460. hints.ai_flags = socket_flags;
  461. hints.ai_protocol = 0;
  462. auto service = std::to_string(port);
  463. if (getaddrinfo(host, service.c_str(), &hints, &result)) {
  464. return INVALID_SOCKET;
  465. }
  466. for (auto rp = result; rp; rp = rp->ai_next) {
  467. // Create a socket
  468. auto sock = socket(rp->ai_family, rp->ai_socktype, rp->ai_protocol);
  469. if (sock == INVALID_SOCKET) {
  470. continue;
  471. }
  472. // Make 'reuse address' option available
  473. int yes = 1;
  474. setsockopt(sock, SOL_SOCKET, SO_REUSEADDR, (char*)&yes, sizeof(yes));
  475. // bind or connect
  476. if (fn(sock, *rp)) {
  477. freeaddrinfo(result);
  478. return sock;
  479. }
  480. close_socket(sock);
  481. }
  482. freeaddrinfo(result);
  483. return INVALID_SOCKET;
  484. }
  485. inline void set_nonblocking(socket_t sock, bool nonblocking)
  486. {
  487. #ifdef _WIN32
  488. auto flags = nonblocking ? 1UL : 0UL;
  489. ioctlsocket(sock, FIONBIO, &flags);
  490. #else
  491. auto flags = fcntl(sock, F_GETFL, 0);
  492. fcntl(sock, F_SETFL, nonblocking ? (flags | O_NONBLOCK) : (flags & (~O_NONBLOCK)));
  493. #endif
  494. }
  495. inline bool is_connection_error()
  496. {
  497. #ifdef _WIN32
  498. return WSAGetLastError() != WSAEWOULDBLOCK;
  499. #else
  500. return errno != EINPROGRESS;
  501. #endif
  502. }
  503. inline std::string get_remote_addr(socket_t sock) {
  504. struct sockaddr_storage addr;
  505. socklen_t len = sizeof(addr);
  506. if (!getpeername(sock, (struct sockaddr*)&addr, &len)) {
  507. char ipstr[NI_MAXHOST];
  508. if (!getnameinfo((struct sockaddr*)&addr, len,
  509. ipstr, sizeof(ipstr), nullptr, 0, NI_NUMERICHOST)) {
  510. return ipstr;
  511. }
  512. }
  513. return std::string();
  514. }
  515. inline bool is_file(const std::string& path)
  516. {
  517. struct stat st;
  518. return stat(path.c_str(), &st) >= 0 && S_ISREG(st.st_mode);
  519. }
  520. inline bool is_dir(const std::string& path)
  521. {
  522. struct stat st;
  523. return stat(path.c_str(), &st) >= 0 && S_ISDIR(st.st_mode);
  524. }
  525. inline bool is_valid_path(const std::string& path) {
  526. size_t level = 0;
  527. size_t i = 0;
  528. // Skip slash
  529. while (i < path.size() && path[i] == '/') {
  530. i++;
  531. }
  532. while (i < path.size()) {
  533. // Read component
  534. auto beg = i;
  535. while (i < path.size() && path[i] != '/') {
  536. i++;
  537. }
  538. auto len = i - beg;
  539. assert(len > 0);
  540. if (!path.compare(beg, len, ".")) {
  541. ;
  542. } else if (!path.compare(beg, len, "..")) {
  543. if (level == 0) {
  544. return false;
  545. }
  546. level--;
  547. } else {
  548. level++;
  549. }
  550. // Skip slash
  551. while (i < path.size() && path[i] == '/') {
  552. i++;
  553. }
  554. }
  555. return true;
  556. }
  557. inline void read_file(const std::string& path, std::string& out)
  558. {
  559. std::ifstream fs(path, std::ios_base::binary);
  560. fs.seekg(0, std::ios_base::end);
  561. auto size = fs.tellg();
  562. fs.seekg(0);
  563. out.resize(static_cast<size_t>(size));
  564. fs.read(&out[0], size);
  565. }
  566. inline std::string file_extension(const std::string& path)
  567. {
  568. std::smatch m;
  569. auto pat = std::regex("\\.([a-zA-Z0-9]+)$");
  570. if (std::regex_search(path, m, pat)) {
  571. return m[1].str();
  572. }
  573. return std::string();
  574. }
  575. inline const char* find_content_type(const std::string& path)
  576. {
  577. auto ext = file_extension(path);
  578. if (ext == "txt") {
  579. return "text/plain";
  580. } else if (ext == "html") {
  581. return "text/html";
  582. } else if (ext == "css") {
  583. return "text/css";
  584. } else if (ext == "jpeg" || ext == "jpg") {
  585. return "image/jpg";
  586. } else if (ext == "png") {
  587. return "image/png";
  588. } else if (ext == "gif") {
  589. return "image/gif";
  590. } else if (ext == "svg") {
  591. return "image/svg+xml";
  592. } else if (ext == "ico") {
  593. return "image/x-icon";
  594. } else if (ext == "json") {
  595. return "application/json";
  596. } else if (ext == "pdf") {
  597. return "application/pdf";
  598. } else if (ext == "js") {
  599. return "application/javascript";
  600. } else if (ext == "xml") {
  601. return "application/xml";
  602. } else if (ext == "xhtml") {
  603. return "application/xhtml+xml";
  604. }
  605. return nullptr;
  606. }
  607. inline const char* status_message(int status)
  608. {
  609. switch (status) {
  610. case 200: return "OK";
  611. case 301: return "Moved Permanently";
  612. case 302: return "Found";
  613. case 303: return "See Other";
  614. case 304: return "Not Modified";
  615. case 400: return "Bad Request";
  616. case 403: return "Forbidden";
  617. case 404: return "Not Found";
  618. case 415: return "Unsupported Media Type";
  619. default:
  620. case 500: return "Internal Server Error";
  621. }
  622. }
  623. inline bool has_header(const Headers& headers, const char* key)
  624. {
  625. return headers.find(key) != headers.end();
  626. }
  627. inline const char* get_header_value(
  628. const Headers& headers, const char* key, size_t id = 0, const char* def = nullptr)
  629. {
  630. auto it = headers.find(key);
  631. std::advance(it, id);
  632. if (it != headers.end()) {
  633. return it->second.c_str();
  634. }
  635. return def;
  636. }
  637. inline int get_header_value_int(const Headers& headers, const char* key, int def = 0)
  638. {
  639. auto it = headers.find(key);
  640. if (it != headers.end()) {
  641. return std::stoi(it->second);
  642. }
  643. return def;
  644. }
  645. inline bool read_headers(Stream& strm, Headers& headers)
  646. {
  647. static std::regex re(R"((.+?):\s*(.+?)\s*\r\n)");
  648. const auto bufsiz = 2048;
  649. char buf[bufsiz];
  650. stream_line_reader reader(strm, buf, bufsiz);
  651. for (;;) {
  652. if (!reader.getline()) {
  653. return false;
  654. }
  655. if (!strcmp(reader.ptr(), "\r\n")) {
  656. break;
  657. }
  658. std::cmatch m;
  659. if (std::regex_match(reader.ptr(), m, re)) {
  660. auto key = std::string(m[1]);
  661. auto val = std::string(m[2]);
  662. headers.emplace(key, val);
  663. }
  664. }
  665. return true;
  666. }
  667. inline bool read_content_with_length(Stream& strm, std::string& out, size_t len, Progress progress)
  668. {
  669. out.assign(len, 0);
  670. size_t r = 0;
  671. while (r < len){
  672. auto n = strm.read(&out[r], len - r);
  673. if (n <= 0) {
  674. return false;
  675. }
  676. r += n;
  677. if (progress) {
  678. if (!progress(r, len)) {
  679. return false;
  680. }
  681. }
  682. }
  683. return true;
  684. }
  685. inline bool read_content_without_length(Stream& strm, std::string& out)
  686. {
  687. for (;;) {
  688. char byte;
  689. auto n = strm.read(&byte, 1);
  690. if (n < 0) {
  691. return false;
  692. } else if (n == 0) {
  693. return true;
  694. }
  695. out += byte;
  696. }
  697. return true;
  698. }
  699. inline bool read_content_chunked(Stream& strm, std::string& out)
  700. {
  701. const auto bufsiz = 16;
  702. char buf[bufsiz];
  703. stream_line_reader reader(strm, buf, bufsiz);
  704. if (!reader.getline()) {
  705. return false;
  706. }
  707. auto chunk_len = std::stoi(reader.ptr(), 0, 16);
  708. while (chunk_len > 0){
  709. std::string chunk;
  710. if (!read_content_with_length(strm, chunk, chunk_len, nullptr)) {
  711. return false;
  712. }
  713. if (!reader.getline()) {
  714. return false;
  715. }
  716. if (strcmp(reader.ptr(), "\r\n")) {
  717. break;
  718. }
  719. out += chunk;
  720. if (!reader.getline()) {
  721. return false;
  722. }
  723. chunk_len = std::stoi(reader.ptr(), 0, 16);
  724. }
  725. if (chunk_len == 0) {
  726. // Reader terminator after chunks
  727. if (!reader.getline() || strcmp(reader.ptr(), "\r\n"))
  728. return false;
  729. }
  730. return true;
  731. }
  732. template <typename T>
  733. bool read_content(Stream& strm, T& x, Progress progress = Progress())
  734. {
  735. if (has_header(x.headers, "Content-Length")) {
  736. auto len = get_header_value_int(x.headers, "Content-Length", 0);
  737. if (len == 0) {
  738. const auto& encoding = get_header_value(x.headers, "Transfer-Encoding", 0, "");
  739. if (!strcasecmp(encoding, "chunked")) {
  740. return read_content_chunked(strm, x.body);
  741. }
  742. }
  743. return read_content_with_length(strm, x.body, len, progress);
  744. } else {
  745. const auto& encoding = get_header_value(x.headers, "Transfer-Encoding", 0, "");
  746. if (!strcasecmp(encoding, "chunked")) {
  747. return read_content_chunked(strm, x.body);
  748. }
  749. return read_content_without_length(strm, x.body);
  750. }
  751. return true;
  752. }
  753. template <typename T>
  754. inline void write_headers(Stream& strm, const T& info)
  755. {
  756. for (const auto& x: info.headers) {
  757. strm.write_format("%s: %s\r\n", x.first.c_str(), x.second.c_str());
  758. }
  759. strm.write("\r\n");
  760. }
  761. inline std::string encode_url(const std::string& s)
  762. {
  763. std::string result;
  764. for (auto i = 0; s[i]; i++) {
  765. switch (s[i]) {
  766. case ' ': result += "%20"; break;
  767. case '+': result += "%2B"; break;
  768. case '\r': result += "%0D"; break;
  769. case '\n': result += "%0A"; break;
  770. case '\'': result += "%27"; break;
  771. case ',': result += "%2C"; break;
  772. case ':': result += "%3A"; break;
  773. case ';': result += "%3B"; break;
  774. default:
  775. auto c = static_cast<uint8_t>(s[i]);
  776. if (c >= 0x80) {
  777. result += '%';
  778. char hex[4];
  779. size_t len = snprintf(hex, sizeof(hex) - 1, "%02X", c);
  780. assert(len == 2);
  781. result.append(hex, len);
  782. } else {
  783. result += s[i];
  784. }
  785. break;
  786. }
  787. }
  788. return result;
  789. }
  790. inline bool is_hex(char c, int& v)
  791. {
  792. if (0x20 <= c && isdigit(c)) {
  793. v = c - '0';
  794. return true;
  795. } else if ('A' <= c && c <= 'F') {
  796. v = c - 'A' + 10;
  797. return true;
  798. } else if ('a' <= c && c <= 'f') {
  799. v = c - 'a' + 10;
  800. return true;
  801. }
  802. return false;
  803. }
  804. inline bool from_hex_to_i(const std::string& s, size_t i, size_t cnt, int& val)
  805. {
  806. if (i >= s.size()) {
  807. return false;
  808. }
  809. val = 0;
  810. for (; cnt; i++, cnt--) {
  811. if (!s[i]) {
  812. return false;
  813. }
  814. int v = 0;
  815. if (is_hex(s[i], v)) {
  816. val = val * 16 + v;
  817. } else {
  818. return false;
  819. }
  820. }
  821. return true;
  822. }
  823. inline std::string from_i_to_hex(uint64_t n)
  824. {
  825. const char *charset = "0123456789abcdef";
  826. std::string ret;
  827. do {
  828. ret = charset[n & 15] + ret;
  829. n >>= 4;
  830. } while (n > 0);
  831. return ret;
  832. }
  833. inline size_t to_utf8(int code, char* buff)
  834. {
  835. if (code < 0x0080) {
  836. buff[0] = (code & 0x7F);
  837. return 1;
  838. } else if (code < 0x0800) {
  839. buff[0] = (0xC0 | ((code >> 6) & 0x1F));
  840. buff[1] = (0x80 | (code & 0x3F));
  841. return 2;
  842. } else if (code < 0xD800) {
  843. buff[0] = (0xE0 | ((code >> 12) & 0xF));
  844. buff[1] = (0x80 | ((code >> 6) & 0x3F));
  845. buff[2] = (0x80 | (code & 0x3F));
  846. return 3;
  847. } else if (code < 0xE000) { // D800 - DFFF is invalid...
  848. return 0;
  849. } else if (code < 0x10000) {
  850. buff[0] = (0xE0 | ((code >> 12) & 0xF));
  851. buff[1] = (0x80 | ((code >> 6) & 0x3F));
  852. buff[2] = (0x80 | (code & 0x3F));
  853. return 3;
  854. } else if (code < 0x110000) {
  855. buff[0] = (0xF0 | ((code >> 18) & 0x7));
  856. buff[1] = (0x80 | ((code >> 12) & 0x3F));
  857. buff[2] = (0x80 | ((code >> 6) & 0x3F));
  858. buff[3] = (0x80 | (code & 0x3F));
  859. return 4;
  860. }
  861. // NOTREACHED
  862. return 0;
  863. }
  864. inline std::string decode_url(const std::string& s)
  865. {
  866. std::string result;
  867. for (size_t i = 0; i < s.size(); i++) {
  868. if (s[i] == '%' && i + 1 < s.size()) {
  869. if (s[i + 1] == 'u') {
  870. int val = 0;
  871. if (from_hex_to_i(s, i + 2, 4, val)) {
  872. // 4 digits Unicode codes
  873. char buff[4];
  874. size_t len = to_utf8(val, buff);
  875. if (len > 0) {
  876. result.append(buff, len);
  877. }
  878. i += 5; // 'u0000'
  879. } else {
  880. result += s[i];
  881. }
  882. } else {
  883. int val = 0;
  884. if (from_hex_to_i(s, i + 1, 2, val)) {
  885. // 2 digits hex codes
  886. result += val;
  887. i += 2; // '00'
  888. } else {
  889. result += s[i];
  890. }
  891. }
  892. } else if (s[i] == '+') {
  893. result += ' ';
  894. } else {
  895. result += s[i];
  896. }
  897. }
  898. return result;
  899. }
  900. inline void parse_query_text(const std::string& s, Params& params)
  901. {
  902. split(&s[0], &s[s.size()], '&', [&](const char* b, const char* e) {
  903. std::string key;
  904. std::string val;
  905. split(b, e, '=', [&](const char* b, const char* e) {
  906. if (key.empty()) {
  907. key.assign(b, e);
  908. } else {
  909. val.assign(b, e);
  910. }
  911. });
  912. params.emplace(key, decode_url(val));
  913. });
  914. }
  915. inline bool parse_multipart_boundary(const std::string& content_type, std::string& boundary)
  916. {
  917. auto pos = content_type.find("boundary=");
  918. if (pos == std::string::npos) {
  919. return false;
  920. }
  921. boundary = content_type.substr(pos + 9);
  922. return true;
  923. }
  924. inline bool parse_multipart_formdata(
  925. const std::string& boundary, const std::string& body, MultipartFiles& files)
  926. {
  927. static std::string dash = "--";
  928. static std::string crlf = "\r\n";
  929. static std::regex re_content_type(
  930. "Content-Type: (.*?)", std::regex_constants::icase);
  931. static std::regex re_content_disposition(
  932. "Content-Disposition: form-data; name=\"(.*?)\"(?:; filename=\"(.*?)\")?",
  933. std::regex_constants::icase);
  934. auto dash_boundary = dash + boundary;
  935. auto pos = body.find(dash_boundary);
  936. if (pos != 0) {
  937. return false;
  938. }
  939. pos += dash_boundary.size();
  940. auto next_pos = body.find(crlf, pos);
  941. if (next_pos == std::string::npos) {
  942. return false;
  943. }
  944. pos = next_pos + crlf.size();
  945. while (pos < body.size()) {
  946. next_pos = body.find(crlf, pos);
  947. if (next_pos == std::string::npos) {
  948. return false;
  949. }
  950. std::string name;
  951. MultipartFile file;
  952. auto header = body.substr(pos, (next_pos - pos));
  953. while (pos != next_pos) {
  954. std::smatch m;
  955. if (std::regex_match(header, m, re_content_type)) {
  956. file.content_type = m[1];
  957. } else if (std::regex_match(header, m, re_content_disposition)) {
  958. name = m[1];
  959. file.filename = m[2];
  960. }
  961. pos = next_pos + crlf.size();
  962. next_pos = body.find(crlf, pos);
  963. if (next_pos == std::string::npos) {
  964. return false;
  965. }
  966. header = body.substr(pos, (next_pos - pos));
  967. }
  968. pos = next_pos + crlf.size();
  969. next_pos = body.find(crlf + dash_boundary, pos);
  970. if (next_pos == std::string::npos) {
  971. return false;
  972. }
  973. file.offset = pos;
  974. file.length = next_pos - pos;
  975. pos = next_pos + crlf.size() + dash_boundary.size();
  976. next_pos = body.find(crlf, pos);
  977. if (next_pos == std::string::npos) {
  978. return false;
  979. }
  980. files.emplace(name, file);
  981. pos = next_pos + crlf.size();
  982. }
  983. return true;
  984. }
  985. inline std::string to_lower(const char* beg, const char* end)
  986. {
  987. std::string out;
  988. auto it = beg;
  989. while (it != end) {
  990. out += ::tolower(*it);
  991. it++;
  992. }
  993. return out;
  994. }
  995. inline void make_range_header_core(std::string&) {}
  996. template<typename uint64_t>
  997. inline void make_range_header_core(std::string& field, uint64_t value)
  998. {
  999. if (!field.empty()) {
  1000. field += ", ";
  1001. }
  1002. field += std::to_string(value) + "-";
  1003. }
  1004. template<typename uint64_t, typename... Args>
  1005. inline void make_range_header_core(std::string& field, uint64_t value1, uint64_t value2, Args... args)
  1006. {
  1007. if (!field.empty()) {
  1008. field += ", ";
  1009. }
  1010. field += std::to_string(value1) + "-" + std::to_string(value2);
  1011. make_range_header_core(field, args...);
  1012. }
  1013. #ifdef CPPHTTPLIB_ZLIB_SUPPORT
  1014. inline bool can_compress(const std::string& content_type) {
  1015. return !content_type.find("text/") ||
  1016. content_type == "image/svg+xml" ||
  1017. content_type == "application/javascript" ||
  1018. content_type == "application/json" ||
  1019. content_type == "application/xml" ||
  1020. content_type == "application/xhtml+xml";
  1021. }
  1022. inline void compress(std::string& content)
  1023. {
  1024. z_stream strm;
  1025. strm.zalloc = Z_NULL;
  1026. strm.zfree = Z_NULL;
  1027. strm.opaque = Z_NULL;
  1028. auto ret = deflateInit2(&strm, Z_DEFAULT_COMPRESSION, Z_DEFLATED, 31, 8, Z_DEFAULT_STRATEGY);
  1029. if (ret != Z_OK) {
  1030. return;
  1031. }
  1032. strm.avail_in = content.size();
  1033. strm.next_in = (Bytef *)content.data();
  1034. std::string compressed;
  1035. const auto bufsiz = 16384;
  1036. char buff[bufsiz];
  1037. do {
  1038. strm.avail_out = bufsiz;
  1039. strm.next_out = (Bytef *)buff;
  1040. deflate(&strm, Z_FINISH);
  1041. compressed.append(buff, bufsiz - strm.avail_out);
  1042. } while (strm.avail_out == 0);
  1043. content.swap(compressed);
  1044. deflateEnd(&strm);
  1045. }
  1046. inline void decompress(std::string& content)
  1047. {
  1048. z_stream strm;
  1049. strm.zalloc = Z_NULL;
  1050. strm.zfree = Z_NULL;
  1051. strm.opaque = Z_NULL;
  1052. // 15 is the value of wbits, which should be at the maximum possible value to ensure
  1053. // that any gzip stream can be decoded. The offset of 16 specifies that the stream
  1054. // to decompress will be formatted with a gzip wrapper.
  1055. auto ret = inflateInit2(&strm, 16 + 15);
  1056. if (ret != Z_OK) {
  1057. return;
  1058. }
  1059. strm.avail_in = content.size();
  1060. strm.next_in = (Bytef *)content.data();
  1061. std::string decompressed;
  1062. const auto bufsiz = 16384;
  1063. char buff[bufsiz];
  1064. do {
  1065. strm.avail_out = bufsiz;
  1066. strm.next_out = (Bytef *)buff;
  1067. inflate(&strm, Z_NO_FLUSH);
  1068. decompressed.append(buff, bufsiz - strm.avail_out);
  1069. } while (strm.avail_out == 0);
  1070. content.swap(decompressed);
  1071. inflateEnd(&strm);
  1072. }
  1073. #endif
  1074. #ifdef _WIN32
  1075. class WSInit {
  1076. public:
  1077. WSInit() {
  1078. WSADATA wsaData;
  1079. WSAStartup(0x0002, &wsaData);
  1080. }
  1081. ~WSInit() {
  1082. WSACleanup();
  1083. }
  1084. };
  1085. static WSInit wsinit_;
  1086. #endif
  1087. } // namespace detail
  1088. // Header utilities
  1089. template<typename uint64_t, typename... Args>
  1090. inline std::pair<std::string, std::string> make_range_header(uint64_t value, Args... args)
  1091. {
  1092. std::string field;
  1093. detail::make_range_header_core(field, value, args...);
  1094. field.insert(0, "bytes=");
  1095. return std::make_pair("Range", field);
  1096. }
  1097. // Request implementation
  1098. inline bool Request::has_header(const char* key) const
  1099. {
  1100. return detail::has_header(headers, key);
  1101. }
  1102. inline std::string Request::get_header_value(const char* key, size_t id) const
  1103. {
  1104. return detail::get_header_value(headers, key, id, "");
  1105. }
  1106. inline size_t Request::get_header_value_count(const char* key) const
  1107. {
  1108. auto r = headers.equal_range(key);
  1109. return std::distance(r.first, r.second);
  1110. }
  1111. inline void Request::set_header(const char* key, const char* val)
  1112. {
  1113. headers.emplace(key, val);
  1114. }
  1115. inline bool Request::has_param(const char* key) const
  1116. {
  1117. return params.find(key) != params.end();
  1118. }
  1119. inline std::string Request::get_param_value(const char* key, size_t id) const
  1120. {
  1121. auto it = params.find(key);
  1122. std::advance(it, id);
  1123. if (it != params.end()) {
  1124. return it->second;
  1125. }
  1126. return std::string();
  1127. }
  1128. inline size_t Request::get_param_value_count(const char* key) const
  1129. {
  1130. auto r = params.equal_range(key);
  1131. return std::distance(r.first, r.second);
  1132. }
  1133. inline bool Request::has_file(const char* key) const
  1134. {
  1135. return files.find(key) != files.end();
  1136. }
  1137. inline MultipartFile Request::get_file_value(const char* key) const
  1138. {
  1139. auto it = files.find(key);
  1140. if (it != files.end()) {
  1141. return it->second;
  1142. }
  1143. return MultipartFile();
  1144. }
  1145. // Response implementation
  1146. inline bool Response::has_header(const char* key) const
  1147. {
  1148. return headers.find(key) != headers.end();
  1149. }
  1150. inline std::string Response::get_header_value(const char* key, size_t id) const
  1151. {
  1152. return detail::get_header_value(headers, key, id, "");
  1153. }
  1154. inline size_t Response::get_header_value_count(const char* key) const
  1155. {
  1156. auto r = headers.equal_range(key);
  1157. return std::distance(r.first, r.second);
  1158. }
  1159. inline void Response::set_header(const char* key, const char* val)
  1160. {
  1161. headers.emplace(key, val);
  1162. }
  1163. inline void Response::set_redirect(const char* url)
  1164. {
  1165. set_header("Location", url);
  1166. status = 302;
  1167. }
  1168. inline void Response::set_content(const char* s, size_t n, const char* content_type)
  1169. {
  1170. body.assign(s, n);
  1171. set_header("Content-Type", content_type);
  1172. }
  1173. inline void Response::set_content(const std::string& s, const char* content_type)
  1174. {
  1175. body = s;
  1176. set_header("Content-Type", content_type);
  1177. }
  1178. // Rstream implementation
  1179. template <typename ...Args>
  1180. inline void Stream::write_format(const char* fmt, const Args& ...args)
  1181. {
  1182. const auto bufsiz = 2048;
  1183. char buf[bufsiz];
  1184. #if defined(_MSC_VER) && _MSC_VER < 1900
  1185. auto n = _snprintf_s(buf, bufsiz, bufsiz - 1, fmt, args...);
  1186. #else
  1187. auto n = snprintf(buf, bufsiz - 1, fmt, args...);
  1188. #endif
  1189. if (n > 0) {
  1190. if (n >= bufsiz - 1) {
  1191. std::vector<char> glowable_buf(bufsiz);
  1192. while (n >= static_cast<int>(glowable_buf.size() - 1)) {
  1193. glowable_buf.resize(glowable_buf.size() * 2);
  1194. #if defined(_MSC_VER) && _MSC_VER < 1900
  1195. n = _snprintf_s(&glowable_buf[0], glowable_buf.size(), glowable_buf.size() - 1, fmt, args...);
  1196. #else
  1197. n = snprintf(&glowable_buf[0], glowable_buf.size() - 1, fmt, args...);
  1198. #endif
  1199. }
  1200. write(&glowable_buf[0], n);
  1201. } else {
  1202. write(buf, n);
  1203. }
  1204. }
  1205. }
  1206. // Socket stream implementation
  1207. inline SocketStream::SocketStream(socket_t sock): sock_(sock)
  1208. {
  1209. }
  1210. inline SocketStream::~SocketStream()
  1211. {
  1212. }
  1213. inline int SocketStream::read(char* ptr, size_t size)
  1214. {
  1215. return recv(sock_, ptr, static_cast<int>(size), 0);
  1216. }
  1217. inline int SocketStream::write(const char* ptr, size_t size)
  1218. {
  1219. return send(sock_, ptr, static_cast<int>(size), 0);
  1220. }
  1221. inline int SocketStream::write(const char* ptr)
  1222. {
  1223. return write(ptr, strlen(ptr));
  1224. }
  1225. inline std::string SocketStream::get_remote_addr() const {
  1226. return detail::get_remote_addr(sock_);
  1227. }
  1228. // Buffer stream implementation
  1229. inline int BufferStream::read(char* ptr, size_t size)
  1230. {
  1231. #if defined(_MSC_VER) && _MSC_VER < 1900
  1232. return static_cast<int>(buffer._Copy_s(ptr, size, size));
  1233. #else
  1234. return static_cast<int>(buffer.copy(ptr, size));
  1235. #endif
  1236. }
  1237. inline int BufferStream::write(const char* ptr, size_t size)
  1238. {
  1239. buffer.append(ptr, size);
  1240. return static_cast<int>(size);
  1241. }
  1242. inline int BufferStream::write(const char* ptr)
  1243. {
  1244. size_t size = strlen(ptr);
  1245. buffer.append(ptr, size);
  1246. return static_cast<int>(size);
  1247. }
  1248. inline std::string BufferStream::get_remote_addr() const {
  1249. return "";
  1250. }
  1251. inline const std::string& BufferStream::get_buffer() const {
  1252. return buffer;
  1253. }
  1254. // HTTP server implementation
  1255. inline Server::Server()
  1256. : keep_alive_max_count_(5)
  1257. , is_running_(false)
  1258. , svr_sock_(INVALID_SOCKET)
  1259. , running_threads_(0)
  1260. {
  1261. #ifndef _WIN32
  1262. signal(SIGPIPE, SIG_IGN);
  1263. #endif
  1264. }
  1265. inline Server::~Server()
  1266. {
  1267. }
  1268. inline Server& Server::Get(const char* pattern, Handler handler)
  1269. {
  1270. get_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
  1271. return *this;
  1272. }
  1273. inline Server& Server::Post(const char* pattern, Handler handler)
  1274. {
  1275. post_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
  1276. return *this;
  1277. }
  1278. inline Server& Server::Put(const char* pattern, Handler handler)
  1279. {
  1280. put_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
  1281. return *this;
  1282. }
  1283. inline Server& Server::Delete(const char* pattern, Handler handler)
  1284. {
  1285. delete_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
  1286. return *this;
  1287. }
  1288. inline Server& Server::Options(const char* pattern, Handler handler)
  1289. {
  1290. options_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
  1291. return *this;
  1292. }
  1293. inline bool Server::set_base_dir(const char* path)
  1294. {
  1295. if (detail::is_dir(path)) {
  1296. base_dir_ = path;
  1297. return true;
  1298. }
  1299. return false;
  1300. }
  1301. inline void Server::set_error_handler(Handler handler)
  1302. {
  1303. error_handler_ = handler;
  1304. }
  1305. inline void Server::set_logger(Logger logger)
  1306. {
  1307. logger_ = logger;
  1308. }
  1309. inline void Server::set_keep_alive_max_count(size_t count)
  1310. {
  1311. keep_alive_max_count_ = count;
  1312. }
  1313. inline int Server::bind_to_any_port(const char* host, int socket_flags)
  1314. {
  1315. return bind_internal(host, 0, socket_flags);
  1316. }
  1317. inline bool Server::listen_after_bind() {
  1318. return listen_internal();
  1319. }
  1320. inline bool Server::listen(const char* host, int port, int socket_flags)
  1321. {
  1322. if (bind_internal(host, port, socket_flags) < 0)
  1323. return false;
  1324. return listen_internal();
  1325. }
  1326. inline bool Server::is_running() const
  1327. {
  1328. return is_running_;
  1329. }
  1330. inline void Server::stop()
  1331. {
  1332. if (is_running_) {
  1333. assert(svr_sock_ != INVALID_SOCKET);
  1334. auto sock = svr_sock_;
  1335. svr_sock_ = INVALID_SOCKET;
  1336. detail::shutdown_socket(sock);
  1337. detail::close_socket(sock);
  1338. }
  1339. }
  1340. inline bool Server::parse_request_line(const char* s, Request& req)
  1341. {
  1342. static std::regex re("(GET|HEAD|POST|PUT|DELETE|OPTIONS) (([^?]+)(?:\\?(.+?))?) (HTTP/1\\.[01])\r\n");
  1343. std::cmatch m;
  1344. if (std::regex_match(s, m, re)) {
  1345. req.version = std::string(m[5]);
  1346. req.method = std::string(m[1]);
  1347. req.target = std::string(m[2]);
  1348. req.path = detail::decode_url(m[3]);
  1349. // Parse query text
  1350. auto len = std::distance(m[4].first, m[4].second);
  1351. if (len > 0) {
  1352. detail::parse_query_text(m[4], req.params);
  1353. }
  1354. return true;
  1355. }
  1356. return false;
  1357. }
  1358. inline void Server::write_response(Stream& strm, bool last_connection, const Request& req, Response& res)
  1359. {
  1360. assert(res.status != -1);
  1361. if (400 <= res.status && error_handler_) {
  1362. error_handler_(req, res);
  1363. }
  1364. // Response line
  1365. strm.write_format("HTTP/1.1 %d %s\r\n",
  1366. res.status,
  1367. detail::status_message(res.status));
  1368. // Headers
  1369. if (last_connection ||
  1370. req.get_header_value("Connection") == "close") {
  1371. res.set_header("Connection", "close");
  1372. }
  1373. if (!last_connection &&
  1374. req.get_header_value("Connection") == "Keep-Alive") {
  1375. res.set_header("Connection", "Keep-Alive");
  1376. }
  1377. if (res.body.empty()) {
  1378. if (!res.has_header("Content-Length")) {
  1379. if (res.streamcb) {
  1380. // Streamed response
  1381. res.set_header("Transfer-Encoding", "chunked");
  1382. } else {
  1383. res.set_header("Content-Length", "0");
  1384. }
  1385. }
  1386. } else {
  1387. #ifdef CPPHTTPLIB_ZLIB_SUPPORT
  1388. // TODO: 'Accpet-Encoding' has gzip, not gzip;q=0
  1389. const auto& encodings = req.get_header_value("Accept-Encoding");
  1390. if (encodings.find("gzip") != std::string::npos &&
  1391. detail::can_compress(res.get_header_value("Content-Type"))) {
  1392. detail::compress(res.body);
  1393. res.set_header("Content-Encoding", "gzip");
  1394. }
  1395. #endif
  1396. if (!res.has_header("Content-Type")) {
  1397. res.set_header("Content-Type", "text/plain");
  1398. }
  1399. auto length = std::to_string(res.body.size());
  1400. res.set_header("Content-Length", length.c_str());
  1401. }
  1402. detail::write_headers(strm, res);
  1403. // Body
  1404. if (req.method != "HEAD") {
  1405. if (!res.body.empty()) {
  1406. strm.write(res.body.c_str(), res.body.size());
  1407. } else if (res.streamcb) {
  1408. bool chunked_response = !res.has_header("Content-Length");
  1409. uint64_t offset = 0;
  1410. bool data_available = true;
  1411. while (data_available) {
  1412. std::string chunk = res.streamcb(offset);
  1413. offset += chunk.size();
  1414. data_available = !chunk.empty();
  1415. // Emit chunked response header and footer for each chunk
  1416. if (chunked_response)
  1417. chunk = detail::from_i_to_hex(chunk.size()) + "\r\n" + chunk + "\r\n";
  1418. if (strm.write(chunk.c_str(), chunk.size()) < 0)
  1419. break; // Stop on error
  1420. }
  1421. }
  1422. }
  1423. // Log
  1424. if (logger_) {
  1425. logger_(req, res);
  1426. }
  1427. }
  1428. inline bool Server::handle_file_request(Request& req, Response& res)
  1429. {
  1430. if (!base_dir_.empty() && detail::is_valid_path(req.path)) {
  1431. std::string path = base_dir_ + req.path;
  1432. if (!path.empty() && path.back() == '/') {
  1433. path += "index.html";
  1434. }
  1435. if (detail::is_file(path)) {
  1436. detail::read_file(path, res.body);
  1437. auto type = detail::find_content_type(path);
  1438. if (type) {
  1439. res.set_header("Content-Type", type);
  1440. }
  1441. res.status = 200;
  1442. return true;
  1443. }
  1444. }
  1445. return false;
  1446. }
  1447. inline socket_t Server::create_server_socket(const char* host, int port, int socket_flags) const
  1448. {
  1449. return detail::create_socket(host, port,
  1450. [](socket_t sock, struct addrinfo& ai) -> bool {
  1451. if (::bind(sock, ai.ai_addr, static_cast<int>(ai.ai_addrlen))) {
  1452. return false;
  1453. }
  1454. if (::listen(sock, 5)) { // Listen through 5 channels
  1455. return false;
  1456. }
  1457. return true;
  1458. }, socket_flags);
  1459. }
  1460. inline int Server::bind_internal(const char* host, int port, int socket_flags)
  1461. {
  1462. if (!is_valid()) {
  1463. return -1;
  1464. }
  1465. svr_sock_ = create_server_socket(host, port, socket_flags);
  1466. if (svr_sock_ == INVALID_SOCKET) {
  1467. return -1;
  1468. }
  1469. if (port == 0) {
  1470. struct sockaddr_storage address;
  1471. socklen_t len = sizeof(address);
  1472. if (getsockname(svr_sock_, reinterpret_cast<struct sockaddr *>(&address), &len) == -1) {
  1473. return -1;
  1474. }
  1475. if (address.ss_family == AF_INET) {
  1476. return ntohs(reinterpret_cast<struct sockaddr_in*>(&address)->sin_port);
  1477. } else if (address.ss_family == AF_INET6) {
  1478. return ntohs(reinterpret_cast<struct sockaddr_in6*>(&address)->sin6_port);
  1479. } else {
  1480. return -1;
  1481. }
  1482. } else {
  1483. return port;
  1484. }
  1485. }
  1486. inline bool Server::listen_internal()
  1487. {
  1488. auto ret = true;
  1489. is_running_ = true;
  1490. for (;;) {
  1491. auto val = detail::select_read(svr_sock_, 0, 100000);
  1492. if (val == 0) { // Timeout
  1493. if (svr_sock_ == INVALID_SOCKET) {
  1494. // The server socket was closed by 'stop' method.
  1495. break;
  1496. }
  1497. continue;
  1498. }
  1499. socket_t sock = accept(svr_sock_, NULL, NULL);
  1500. if (sock == INVALID_SOCKET) {
  1501. if (svr_sock_ != INVALID_SOCKET) {
  1502. detail::close_socket(svr_sock_);
  1503. ret = false;
  1504. } else {
  1505. ; // The server socket was closed by user.
  1506. }
  1507. break;
  1508. }
  1509. // TODO: Use thread pool...
  1510. std::thread([=]() {
  1511. {
  1512. std::lock_guard<std::mutex> guard(running_threads_mutex_);
  1513. running_threads_++;
  1514. }
  1515. read_and_close_socket(sock);
  1516. {
  1517. std::lock_guard<std::mutex> guard(running_threads_mutex_);
  1518. running_threads_--;
  1519. }
  1520. }).detach();
  1521. }
  1522. // TODO: Use thread pool...
  1523. for (;;) {
  1524. std::this_thread::sleep_for(std::chrono::milliseconds(10));
  1525. std::lock_guard<std::mutex> guard(running_threads_mutex_);
  1526. if (!running_threads_) {
  1527. break;
  1528. }
  1529. }
  1530. is_running_ = false;
  1531. return ret;
  1532. }
  1533. inline bool Server::routing(Request& req, Response& res)
  1534. {
  1535. if (req.method == "GET" && handle_file_request(req, res)) {
  1536. return true;
  1537. }
  1538. if (req.method == "GET" || req.method == "HEAD") {
  1539. return dispatch_request(req, res, get_handlers_);
  1540. } else if (req.method == "POST") {
  1541. return dispatch_request(req, res, post_handlers_);
  1542. } else if (req.method == "PUT") {
  1543. return dispatch_request(req, res, put_handlers_);
  1544. } else if (req.method == "DELETE") {
  1545. return dispatch_request(req, res, delete_handlers_);
  1546. } else if (req.method == "OPTIONS") {
  1547. return dispatch_request(req, res, options_handlers_);
  1548. }
  1549. return false;
  1550. }
  1551. inline bool Server::dispatch_request(Request& req, Response& res, Handlers& handlers)
  1552. {
  1553. for (const auto& x: handlers) {
  1554. const auto& pattern = x.first;
  1555. const auto& handler = x.second;
  1556. if (std::regex_match(req.path, req.matches, pattern)) {
  1557. handler(req, res);
  1558. return true;
  1559. }
  1560. }
  1561. return false;
  1562. }
  1563. inline bool Server::process_request(Stream& strm, bool last_connection, bool& connection_close)
  1564. {
  1565. const auto bufsiz = 2048;
  1566. char buf[bufsiz];
  1567. detail::stream_line_reader reader(strm, buf, bufsiz);
  1568. // Connection has been closed on client
  1569. if (!reader.getline()) {
  1570. return false;
  1571. }
  1572. Request req;
  1573. Response res;
  1574. res.version = "HTTP/1.1";
  1575. // Request line and headers
  1576. if (!parse_request_line(reader.ptr(), req) || !detail::read_headers(strm, req.headers)) {
  1577. res.status = 400;
  1578. write_response(strm, last_connection, req, res);
  1579. return true;
  1580. }
  1581. if (req.get_header_value("Connection") == "close") {
  1582. connection_close = true;
  1583. }
  1584. req.set_header("REMOTE_ADDR", strm.get_remote_addr().c_str());
  1585. // Body
  1586. if (req.method == "POST" || req.method == "PUT") {
  1587. if (!detail::read_content(strm, req)) {
  1588. res.status = 400;
  1589. write_response(strm, last_connection, req, res);
  1590. return true;
  1591. }
  1592. const auto& content_type = req.get_header_value("Content-Type");
  1593. if (req.get_header_value("Content-Encoding") == "gzip") {
  1594. #ifdef CPPHTTPLIB_ZLIB_SUPPORT
  1595. detail::decompress(req.body);
  1596. #else
  1597. res.status = 415;
  1598. write_response(strm, last_connection, req, res);
  1599. return true;
  1600. #endif
  1601. }
  1602. if (!content_type.find("application/x-www-form-urlencoded")) {
  1603. detail::parse_query_text(req.body, req.params);
  1604. } else if(!content_type.find("multipart/form-data")) {
  1605. std::string boundary;
  1606. if (!detail::parse_multipart_boundary(content_type, boundary) ||
  1607. !detail::parse_multipart_formdata(boundary, req.body, req.files)) {
  1608. res.status = 400;
  1609. write_response(strm, last_connection, req, res);
  1610. return true;
  1611. }
  1612. }
  1613. }
  1614. if (routing(req, res)) {
  1615. if (res.status == -1) {
  1616. res.status = 200;
  1617. }
  1618. } else {
  1619. res.status = 404;
  1620. }
  1621. write_response(strm, last_connection, req, res);
  1622. return true;
  1623. }
  1624. inline bool Server::is_valid() const
  1625. {
  1626. return true;
  1627. }
  1628. inline bool Server::read_and_close_socket(socket_t sock)
  1629. {
  1630. return detail::read_and_close_socket(
  1631. sock,
  1632. keep_alive_max_count_,
  1633. [this](Stream& strm, bool last_connection, bool& connection_close) {
  1634. return process_request(strm, last_connection, connection_close);
  1635. });
  1636. }
  1637. // HTTP client implementation
  1638. inline Client::Client(
  1639. const char* host, int port, time_t timeout_sec)
  1640. : host_(host)
  1641. , port_(port)
  1642. , timeout_sec_(timeout_sec)
  1643. , host_and_port_(host_ + ":" + std::to_string(port_))
  1644. {
  1645. }
  1646. inline Client::~Client()
  1647. {
  1648. }
  1649. inline bool Client::is_valid() const
  1650. {
  1651. return true;
  1652. }
  1653. inline socket_t Client::create_client_socket() const
  1654. {
  1655. return detail::create_socket(host_.c_str(), port_,
  1656. [=](socket_t sock, struct addrinfo& ai) -> bool {
  1657. detail::set_nonblocking(sock, true);
  1658. auto ret = connect(sock, ai.ai_addr, static_cast<int>(ai.ai_addrlen));
  1659. if (ret < 0) {
  1660. if (detail::is_connection_error() ||
  1661. !detail::wait_until_socket_is_ready(sock, timeout_sec_, 0)) {
  1662. detail::close_socket(sock);
  1663. return false;
  1664. }
  1665. }
  1666. detail::set_nonblocking(sock, false);
  1667. return true;
  1668. });
  1669. }
  1670. inline bool Client::read_response_line(Stream& strm, Response& res)
  1671. {
  1672. const auto bufsiz = 2048;
  1673. char buf[bufsiz];
  1674. detail::stream_line_reader reader(strm, buf, bufsiz);
  1675. if (!reader.getline()) {
  1676. return false;
  1677. }
  1678. const static std::regex re("(HTTP/1\\.[01]) (\\d+?) .*\r\n");
  1679. std::cmatch m;
  1680. if (std::regex_match(reader.ptr(), m, re)) {
  1681. res.version = std::string(m[1]);
  1682. res.status = std::stoi(std::string(m[2]));
  1683. }
  1684. return true;
  1685. }
  1686. inline bool Client::send(Request& req, Response& res)
  1687. {
  1688. if (req.path.empty()) {
  1689. return false;
  1690. }
  1691. auto sock = create_client_socket();
  1692. if (sock == INVALID_SOCKET) {
  1693. return false;
  1694. }
  1695. return read_and_close_socket(sock, req, res);
  1696. }
  1697. inline void Client::write_request(Stream& strm, Request& req)
  1698. {
  1699. BufferStream bstrm;
  1700. // Request line
  1701. auto path = detail::encode_url(req.path);
  1702. bstrm.write_format("%s %s HTTP/1.1\r\n",
  1703. req.method.c_str(),
  1704. path.c_str());
  1705. // Headers
  1706. if (!req.has_header("Host")) {
  1707. if (is_ssl()) {
  1708. if (port_ == 443) {
  1709. req.set_header("Host", host_.c_str());
  1710. } else {
  1711. req.set_header("Host", host_and_port_.c_str());
  1712. }
  1713. } else {
  1714. if (port_ == 80) {
  1715. req.set_header("Host", host_.c_str());
  1716. } else {
  1717. req.set_header("Host", host_and_port_.c_str());
  1718. }
  1719. }
  1720. }
  1721. if (!req.has_header("Accept")) {
  1722. req.set_header("Accept", "*/*");
  1723. }
  1724. if (!req.has_header("User-Agent")) {
  1725. req.set_header("User-Agent", "cpp-httplib/0.2");
  1726. }
  1727. // TODO: Support KeepAlive connection
  1728. // if (!req.has_header("Connection")) {
  1729. req.set_header("Connection", "close");
  1730. // }
  1731. if (req.body.empty()) {
  1732. if (req.method == "POST" || req.method == "PUT") {
  1733. req.set_header("Content-Length", "0");
  1734. }
  1735. } else {
  1736. if (!req.has_header("Content-Type")) {
  1737. req.set_header("Content-Type", "text/plain");
  1738. }
  1739. auto length = std::to_string(req.body.size());
  1740. req.set_header("Content-Length", length.c_str());
  1741. }
  1742. detail::write_headers(bstrm, req);
  1743. // Body
  1744. if (!req.body.empty()) {
  1745. bstrm.write(req.body.c_str(), req.body.size());
  1746. }
  1747. // Flush buffer
  1748. auto& data = bstrm.get_buffer();
  1749. strm.write(data.data(), data.size());
  1750. }
  1751. inline bool Client::process_request(Stream& strm, Request& req, Response& res, bool& connection_close)
  1752. {
  1753. // Send request
  1754. write_request(strm, req);
  1755. // Receive response and headers
  1756. if (!read_response_line(strm, res) || !detail::read_headers(strm, res.headers)) {
  1757. return false;
  1758. }
  1759. if (res.get_header_value("Connection") == "close" || res.version == "HTTP/1.0") {
  1760. connection_close = true;
  1761. }
  1762. // Body
  1763. if (req.method != "HEAD") {
  1764. if (!detail::read_content(strm, res, req.progress)) {
  1765. return false;
  1766. }
  1767. if (res.get_header_value("Content-Encoding") == "gzip") {
  1768. #ifdef CPPHTTPLIB_ZLIB_SUPPORT
  1769. detail::decompress(res.body);
  1770. #else
  1771. return false;
  1772. #endif
  1773. }
  1774. }
  1775. return true;
  1776. }
  1777. inline bool Client::read_and_close_socket(socket_t sock, Request& req, Response& res)
  1778. {
  1779. return detail::read_and_close_socket(
  1780. sock,
  1781. 0,
  1782. [&](Stream& strm, bool /*last_connection*/, bool& connection_close) {
  1783. return process_request(strm, req, res, connection_close);
  1784. });
  1785. }
  1786. inline bool Client::is_ssl() const
  1787. {
  1788. return false;
  1789. }
  1790. inline std::shared_ptr<Response> Client::Get(const char* path, Progress progress)
  1791. {
  1792. return Get(path, Headers(), progress);
  1793. }
  1794. inline std::shared_ptr<Response> Client::Get(const char* path, const Headers& headers, Progress progress)
  1795. {
  1796. Request req;
  1797. req.method = "GET";
  1798. req.path = path;
  1799. req.headers = headers;
  1800. req.progress = progress;
  1801. auto res = std::make_shared<Response>();
  1802. return send(req, *res) ? res : nullptr;
  1803. }
  1804. inline std::shared_ptr<Response> Client::Head(const char* path)
  1805. {
  1806. return Head(path, Headers());
  1807. }
  1808. inline std::shared_ptr<Response> Client::Head(const char* path, const Headers& headers)
  1809. {
  1810. Request req;
  1811. req.method = "HEAD";
  1812. req.headers = headers;
  1813. req.path = path;
  1814. auto res = std::make_shared<Response>();
  1815. return send(req, *res) ? res : nullptr;
  1816. }
  1817. inline std::shared_ptr<Response> Client::Post(
  1818. const char* path, const std::string& body, const char* content_type)
  1819. {
  1820. return Post(path, Headers(), body, content_type);
  1821. }
  1822. inline std::shared_ptr<Response> Client::Post(
  1823. const char* path, const Headers& headers, const std::string& body, const char* content_type)
  1824. {
  1825. Request req;
  1826. req.method = "POST";
  1827. req.headers = headers;
  1828. req.path = path;
  1829. req.headers.emplace("Content-Type", content_type);
  1830. req.body = body;
  1831. auto res = std::make_shared<Response>();
  1832. return send(req, *res) ? res : nullptr;
  1833. }
  1834. inline std::shared_ptr<Response> Client::Post(const char* path, const Params& params)
  1835. {
  1836. return Post(path, Headers(), params);
  1837. }
  1838. inline std::shared_ptr<Response> Client::Post(const char* path, const Headers& headers, const Params& params)
  1839. {
  1840. std::string query;
  1841. for (auto it = params.begin(); it != params.end(); ++it) {
  1842. if (it != params.begin()) {
  1843. query += "&";
  1844. }
  1845. query += it->first;
  1846. query += "=";
  1847. query += it->second;
  1848. }
  1849. return Post(path, headers, query, "application/x-www-form-urlencoded");
  1850. }
  1851. inline std::shared_ptr<Response> Client::Put(
  1852. const char* path, const std::string& body, const char* content_type)
  1853. {
  1854. return Put(path, Headers(), body, content_type);
  1855. }
  1856. inline std::shared_ptr<Response> Client::Put(
  1857. const char* path, const Headers& headers, const std::string& body, const char* content_type)
  1858. {
  1859. Request req;
  1860. req.method = "PUT";
  1861. req.headers = headers;
  1862. req.path = path;
  1863. req.headers.emplace("Content-Type", content_type);
  1864. req.body = body;
  1865. auto res = std::make_shared<Response>();
  1866. return send(req, *res) ? res : nullptr;
  1867. }
  1868. inline std::shared_ptr<Response> Client::Delete(const char* path)
  1869. {
  1870. return Delete(path, Headers());
  1871. }
  1872. inline std::shared_ptr<Response> Client::Delete(const char* path, const Headers& headers)
  1873. {
  1874. Request req;
  1875. req.method = "DELETE";
  1876. req.path = path;
  1877. req.headers = headers;
  1878. auto res = std::make_shared<Response>();
  1879. return send(req, *res) ? res : nullptr;
  1880. }
  1881. inline std::shared_ptr<Response> Client::Options(const char* path)
  1882. {
  1883. return Options(path, Headers());
  1884. }
  1885. inline std::shared_ptr<Response> Client::Options(const char* path, const Headers& headers)
  1886. {
  1887. Request req;
  1888. req.method = "OPTIONS";
  1889. req.path = path;
  1890. req.headers = headers;
  1891. auto res = std::make_shared<Response>();
  1892. return send(req, *res) ? res : nullptr;
  1893. }
  1894. /*
  1895. * SSL Implementation
  1896. */
  1897. #ifdef CPPHTTPLIB_OPENSSL_SUPPORT
  1898. namespace detail {
  1899. template <typename U, typename V, typename T>
  1900. inline bool read_and_close_socket_ssl(
  1901. socket_t sock, size_t keep_alive_max_count,
  1902. // TODO: OpenSSL 1.0.2 occasionally crashes...
  1903. // The upcoming 1.1.0 is going to be thread safe.
  1904. SSL_CTX* ctx, std::mutex& ctx_mutex,
  1905. U SSL_connect_or_accept, V setup,
  1906. T callback)
  1907. {
  1908. SSL* ssl = nullptr;
  1909. {
  1910. std::lock_guard<std::mutex> guard(ctx_mutex);
  1911. ssl = SSL_new(ctx);
  1912. if (!ssl) {
  1913. return false;
  1914. }
  1915. }
  1916. auto bio = BIO_new_socket(sock, BIO_NOCLOSE);
  1917. SSL_set_bio(ssl, bio, bio);
  1918. setup(ssl);
  1919. SSL_connect_or_accept(ssl);
  1920. bool ret = false;
  1921. if (keep_alive_max_count > 0) {
  1922. auto count = keep_alive_max_count;
  1923. while (count > 0 &&
  1924. detail::select_read(sock,
  1925. CPPHTTPLIB_KEEPALIVE_TIMEOUT_SECOND,
  1926. CPPHTTPLIB_KEEPALIVE_TIMEOUT_USECOND) > 0) {
  1927. SSLSocketStream strm(sock, ssl);
  1928. auto last_connection = count == 1;
  1929. auto connection_close = false;
  1930. ret = callback(strm, last_connection, connection_close);
  1931. if (!ret || connection_close) {
  1932. break;
  1933. }
  1934. count--;
  1935. }
  1936. } else {
  1937. SSLSocketStream strm(sock, ssl);
  1938. auto dummy_connection_close = false;
  1939. ret = callback(strm, true, dummy_connection_close);
  1940. }
  1941. SSL_shutdown(ssl);
  1942. {
  1943. std::lock_guard<std::mutex> guard(ctx_mutex);
  1944. SSL_free(ssl);
  1945. }
  1946. close_socket(sock);
  1947. return ret;
  1948. }
  1949. class SSLInit {
  1950. public:
  1951. SSLInit() {
  1952. SSL_load_error_strings();
  1953. SSL_library_init();
  1954. }
  1955. ~SSLInit() {
  1956. ERR_free_strings();
  1957. }
  1958. };
  1959. static SSLInit sslinit_;
  1960. } // namespace detail
  1961. // SSL socket stream implementation
  1962. inline SSLSocketStream::SSLSocketStream(socket_t sock, SSL* ssl)
  1963. : sock_(sock), ssl_(ssl)
  1964. {
  1965. }
  1966. inline SSLSocketStream::~SSLSocketStream()
  1967. {
  1968. }
  1969. inline int SSLSocketStream::read(char* ptr, size_t size)
  1970. {
  1971. return SSL_read(ssl_, ptr, size);
  1972. }
  1973. inline int SSLSocketStream::write(const char* ptr, size_t size)
  1974. {
  1975. return SSL_write(ssl_, ptr, size);
  1976. }
  1977. inline int SSLSocketStream::write(const char* ptr)
  1978. {
  1979. return write(ptr, strlen(ptr));
  1980. }
  1981. inline std::string SSLSocketStream::get_remote_addr() const {
  1982. return detail::get_remote_addr(sock_);
  1983. }
  1984. // SSL HTTP server implementation
  1985. inline SSLServer::SSLServer(const char* cert_path, const char* private_key_path)
  1986. {
  1987. ctx_ = SSL_CTX_new(SSLv23_server_method());
  1988. if (ctx_) {
  1989. SSL_CTX_set_options(ctx_,
  1990. SSL_OP_ALL | SSL_OP_NO_SSLv2 | SSL_OP_NO_SSLv3 |
  1991. SSL_OP_NO_COMPRESSION |
  1992. SSL_OP_NO_SESSION_RESUMPTION_ON_RENEGOTIATION);
  1993. // auto ecdh = EC_KEY_new_by_curve_name(NID_X9_62_prime256v1);
  1994. // SSL_CTX_set_tmp_ecdh(ctx_, ecdh);
  1995. // EC_KEY_free(ecdh);
  1996. if (SSL_CTX_use_certificate_chain_file(ctx_, cert_path) != 1 ||
  1997. SSL_CTX_use_PrivateKey_file(ctx_, private_key_path, SSL_FILETYPE_PEM) != 1) {
  1998. SSL_CTX_free(ctx_);
  1999. ctx_ = nullptr;
  2000. }
  2001. }
  2002. }
  2003. inline SSLServer::~SSLServer()
  2004. {
  2005. if (ctx_) {
  2006. SSL_CTX_free(ctx_);
  2007. }
  2008. }
  2009. inline bool SSLServer::is_valid() const
  2010. {
  2011. return ctx_;
  2012. }
  2013. inline bool SSLServer::read_and_close_socket(socket_t sock)
  2014. {
  2015. return detail::read_and_close_socket_ssl(
  2016. sock,
  2017. keep_alive_max_count_,
  2018. ctx_, ctx_mutex_,
  2019. SSL_accept,
  2020. [](SSL* /*ssl*/) {},
  2021. [this](Stream& strm, bool last_connection, bool& connection_close) {
  2022. return process_request(strm, last_connection, connection_close);
  2023. });
  2024. }
  2025. // SSL HTTP client implementation
  2026. inline SSLClient::SSLClient(const char* host, int port, time_t timeout_sec)
  2027. : Client(host, port, timeout_sec)
  2028. {
  2029. ctx_ = SSL_CTX_new(SSLv23_client_method());
  2030. }
  2031. inline SSLClient::~SSLClient()
  2032. {
  2033. if (ctx_) {
  2034. SSL_CTX_free(ctx_);
  2035. }
  2036. }
  2037. inline bool SSLClient::is_valid() const
  2038. {
  2039. return ctx_;
  2040. }
  2041. inline bool SSLClient::read_and_close_socket(socket_t sock, Request& req, Response& res)
  2042. {
  2043. return is_valid() && detail::read_and_close_socket_ssl(
  2044. sock, 0,
  2045. ctx_, ctx_mutex_,
  2046. SSL_connect,
  2047. [&](SSL* ssl) {
  2048. SSL_set_tlsext_host_name(ssl, host_.c_str());
  2049. },
  2050. [&](Stream& strm, bool /*last_connection*/, bool& connection_close) {
  2051. return process_request(strm, req, res, connection_close);
  2052. });
  2053. }
  2054. inline bool SSLClient::is_ssl() const
  2055. {
  2056. return true;
  2057. }
  2058. #endif
  2059. } // namespace httplib
  2060. #endif //CPPHTTPLIB_HTTPLIB_H
  2061. // vim: et ts=4 sw=4 cin cino={1s ff=unix