cpp-httplib/httplib.h

3358 lines
93 KiB
C
Raw Normal View History

2012-09-22 21:40:46 -07:00
//
2012-09-27 18:05:36 -07:00
// httplib.h
2012-09-22 21:40:46 -07:00
//
2019-04-11 05:13:31 -07:00
// Copyright (c) 2019 Yuji Hirose. All rights reserved.
// MIT License
2012-09-22 21:40:46 -07:00
//
#ifndef CPPHTTPLIB_HTTPLIB_H
#define CPPHTTPLIB_HTTPLIB_H
2012-09-25 19:09:56 -07:00
2017-12-06 22:20:59 -07:00
#ifdef _WIN32
#ifndef _CRT_SECURE_NO_WARNINGS
2012-09-26 08:49:04 -07:00
#define _CRT_SECURE_NO_WARNINGS
#endif //_CRT_SECURE_NO_WARNINGS
#ifndef _CRT_NONSTDC_NO_DEPRECATE
#define _CRT_NONSTDC_NO_DEPRECATE
#endif //_CRT_NONSTDC_NO_DEPRECATE
2017-12-07 11:10:20 -07:00
#if defined(_MSC_VER) && _MSC_VER < 1900
2012-10-12 13:09:39 -07:00
#define snprintf _snprintf_s
#endif // _MSC_VER
2013-07-04 15:18:52 -07:00
2017-12-07 06:28:06 -07:00
#ifndef S_ISREG
2019-04-11 05:13:31 -07:00
#define S_ISREG(m) (((m)&S_IFREG) == S_IFREG)
#endif // S_ISREG
2017-12-07 06:28:06 -07:00
#ifndef S_ISDIR
2019-04-11 05:13:31 -07:00
#define S_ISDIR(m) (((m)&S_IFDIR) == S_IFDIR)
#endif // S_ISDIR
2019-02-25 11:09:31 -07:00
#ifndef NOMINMAX
#define NOMINMAX
2019-04-11 05:13:31 -07:00
#endif // NOMINMAX
2012-09-25 19:09:56 -07:00
#include <io.h>
2012-09-22 21:40:46 -07:00
#include <winsock2.h>
2015-01-14 16:51:53 -07:00
#include <ws2tcpip.h>
2012-09-22 21:40:46 -07:00
2019-03-27 04:04:26 -07:00
#pragma comment(lib, "ws2_32.lib")
#ifndef strcasecmp
#define strcasecmp _stricmp
2019-04-11 05:13:31 -07:00
#endif // strcasecmp
2012-09-22 21:40:46 -07:00
typedef SOCKET socket_t;
#else
2019-04-11 05:13:31 -07:00
#include <arpa/inet.h>
2013-04-24 03:09:19 -07:00
#include <cstring>
2019-04-11 05:13:31 -07:00
#include <netdb.h>
2012-09-22 21:40:46 -07:00
#include <netinet/in.h>
2019-04-11 05:13:31 -07:00
#include <pthread.h>
#include <signal.h>
2018-05-07 01:59:08 -07:00
#include <sys/select.h>
2019-04-11 05:13:31 -07:00
#include <sys/socket.h>
#include <unistd.h>
2012-09-22 21:40:46 -07:00
typedef int socket_t;
2018-05-10 20:54:53 -07:00
#define INVALID_SOCKET (-1)
#endif //_WIN32
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
#include <assert.h>
2019-07-17 05:56:49 -07:00
#include <atomic>
2019-08-03 00:18:15 -07:00
#include <condition_variable>
2019-04-11 05:13:31 -07:00
#include <fcntl.h>
2013-07-04 15:18:52 -07:00
#include <fstream>
#include <functional>
#include <list>
#include <map>
2013-04-24 03:09:19 -07:00
#include <memory>
2018-04-16 19:12:45 -07:00
#include <mutex>
2019-07-23 06:52:12 -07:00
#include <random>
#include <regex>
#include <string>
2015-01-14 16:51:53 -07:00
#include <sys/stat.h>
2019-04-11 05:13:31 -07:00
#include <thread>
2017-04-21 20:00:00 -07:00
#ifdef CPPHTTPLIB_OPENSSL_SUPPORT
2019-02-22 06:52:38 -07:00
#include <openssl/err.h>
2019-04-11 05:13:31 -07:00
#include <openssl/ssl.h>
2019-05-07 13:41:33 -07:00
#include <openssl/x509v3.h>
2019-06-20 08:45:11 -07:00
#if OPENSSL_VERSION_NUMBER < 0x10100000L
#include <openssl/crypto.h>
2019-06-20 09:43:17 -07:00
inline const unsigned char *ASN1_STRING_get0_data(const ASN1_STRING *asn1) {
2019-06-20 08:45:11 -07:00
return M_ASN1_STRING_data(asn1);
}
#endif
2017-04-21 20:00:00 -07:00
#endif
2017-12-28 18:47:52 -07:00
#ifdef CPPHTTPLIB_ZLIB_SUPPORT
#include <zlib.h>
#endif
/*
* Configuration
*/
#define CPPHTTPLIB_KEEPALIVE_TIMEOUT_SECOND 5
#define CPPHTTPLIB_KEEPALIVE_TIMEOUT_USECOND 0
2019-04-12 20:34:27 -07:00
#define CPPHTTPLIB_KEEPALIVE_MAX_COUNT 5
2019-06-04 19:53:37 -07:00
#define CPPHTTPLIB_READ_TIMEOUT_SECOND 5
#define CPPHTTPLIB_READ_TIMEOUT_USECOND 0
2019-04-10 09:21:42 -07:00
#define CPPHTTPLIB_REQUEST_URI_MAX_LENGTH 8192
2019-06-17 08:33:43 -07:00
#define CPPHTTPLIB_PAYLOAD_MAX_LENGTH (std::numeric_limits<size_t>::max)()
2019-07-17 05:56:49 -07:00
#define CPPHTTPLIB_RECV_BUFSIZ size_t(4096u)
2019-08-03 00:18:15 -07:00
#define CPPHTTPLIB_THREAD_POOL_COUNT 8
2019-04-11 05:13:31 -07:00
namespace httplib {
2012-09-22 21:40:46 -07:00
2017-12-10 20:34:37 -07:00
namespace detail {
struct ci {
2019-04-11 05:13:31 -07:00
bool operator()(const std::string &s1, const std::string &s2) const {
return std::lexicographical_compare(
s1.begin(), s1.end(), s2.begin(), s2.end(),
[](char c1, char c2) { return ::tolower(c1) < ::tolower(c2); });
}
2017-12-10 20:34:37 -07:00
};
} // namespace detail
2017-12-03 19:25:38 -07:00
enum class HttpVersion { v1_0 = 0, v1_1 };
2019-04-11 05:13:31 -07:00
typedef std::multimap<std::string, std::string, detail::ci> Headers;
2017-12-12 20:20:40 -07:00
2019-04-11 05:13:31 -07:00
typedef std::multimap<std::string, std::string> Params;
typedef std::smatch Match;
2019-07-17 18:33:47 -07:00
typedef std::function<void(const char *data, uint64_t len)> Out;
typedef std::function<void()> Done;
typedef std::function<void(uint64_t offset, uint64_t length, Out out,
Done done)>
ContentProvider;
typedef std::function<bool(const char *data, uint64_t data_length,
uint64_t offset, uint64_t content_length)>
ContentReceiver;
2019-04-11 05:13:31 -07:00
typedef std::function<bool(uint64_t current, uint64_t total)> Progress;
2012-09-22 21:40:46 -07:00
2017-12-05 17:19:07 -07:00
struct MultipartFile {
2019-04-11 05:13:31 -07:00
std::string filename;
std::string content_type;
size_t offset = 0;
size_t length = 0;
2017-12-05 17:19:07 -07:00
};
typedef std::multimap<std::string, MultipartFile> MultipartFiles;
2019-07-23 06:52:12 -07:00
struct MultipartFormData {
std::string name;
std::string content;
std::string filename;
std::string content_type;
};
typedef std::vector<MultipartFormData> MultipartFormDataItems;
typedef std::pair<int64_t, int64_t> Range;
typedef std::vector<Range> Ranges;
2012-09-24 04:57:09 -07:00
struct Request {
2019-04-11 05:13:31 -07:00
std::string version;
std::string method;
std::string target;
std::string path;
Headers headers;
std::string body;
Params params;
MultipartFiles files;
Ranges ranges;
2019-04-11 05:13:31 -07:00
Match matches;
2019-06-20 15:52:28 -07:00
#ifdef CPPHTTPLIB_OPENSSL_SUPPORT
const SSL *ssl;
#endif
2019-04-11 05:13:31 -07:00
bool has_header(const char *key) const;
std::string get_header_value(const char *key, size_t id = 0) const;
size_t get_header_value_count(const char *key) const;
void set_header(const char *key, const char *val);
void set_header(const char *key, const std::string &val);
2019-04-11 05:13:31 -07:00
bool has_param(const char *key) const;
std::string get_param_value(const char *key, size_t id = 0) const;
size_t get_param_value_count(const char *key) const;
bool has_file(const char *key) const;
MultipartFile get_file_value(const char *key) const;
2012-09-22 21:40:46 -07:00
};
2012-09-24 04:57:09 -07:00
struct Response {
2019-04-11 05:13:31 -07:00
std::string version;
int status;
Headers headers;
std::string body;
2019-07-17 18:33:47 -07:00
ContentReceiver content_receiver;
2019-07-17 18:33:47 -07:00
Progress progress;
2019-04-11 05:13:31 -07:00
bool has_header(const char *key) const;
std::string get_header_value(const char *key, size_t id = 0) const;
size_t get_header_value_count(const char *key) const;
void set_header(const char *key, const char *val);
void set_header(const char *key, const std::string &val);
2019-04-11 05:13:31 -07:00
void set_redirect(const char *uri);
void set_content(const char *s, size_t n, const char *content_type);
void set_content(const std::string &s, const char *content_type);
void set_content_provider(
uint64_t length,
std::function<void(uint64_t offset, uint64_t length, Out out)> provider,
2019-08-06 02:12:05 -07:00
std::function<void()> resource_releaser = [] {});
2019-04-11 05:13:31 -07:00
void set_chunked_content_provider(
std::function<void(uint64_t offset, Out out, Done done)> provider,
2019-08-06 02:12:05 -07:00
std::function<void()> resource_releaser = [] {});
Response() : status(-1), content_provider_resource_length(0) {}
~Response() {
2019-08-06 02:12:05 -07:00
if (content_provider_resource_releaser) {
content_provider_resource_releaser();
}
}
uint64_t content_provider_resource_length;
ContentProvider content_provider;
std::function<void()> content_provider_resource_releaser;
2012-09-24 04:57:09 -07:00
};
2017-04-21 20:00:00 -07:00
class Stream {
public:
2019-04-11 05:13:31 -07:00
virtual ~Stream() {}
virtual int read(char *ptr, size_t size) = 0;
virtual int write(const char *ptr, size_t size1) = 0;
virtual int write(const char *ptr) = 0;
virtual int write(const std::string &s) = 0;
2019-04-11 05:13:31 -07:00
virtual std::string get_remote_addr() const = 0;
template <typename... Args>
2019-07-21 18:34:49 -07:00
int write_format(const char *fmt, const Args &... args);
2017-04-21 20:00:00 -07:00
};
class SocketStream : public Stream {
public:
2019-04-11 05:13:31 -07:00
SocketStream(socket_t sock);
virtual ~SocketStream();
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
virtual int read(char *ptr, size_t size);
virtual int write(const char *ptr, size_t size);
virtual int write(const char *ptr);
virtual int write(const std::string &s);
2019-04-11 05:13:31 -07:00
virtual std::string get_remote_addr() const;
2017-04-21 20:00:00 -07:00
private:
2019-04-11 05:13:31 -07:00
socket_t sock_;
2017-04-21 20:00:00 -07:00
};
2018-10-28 00:15:22 -07:00
class BufferStream : public Stream {
public:
2019-04-11 05:13:31 -07:00
BufferStream() {}
virtual ~BufferStream() {}
2018-10-28 00:15:22 -07:00
2019-04-11 05:13:31 -07:00
virtual int read(char *ptr, size_t size);
virtual int write(const char *ptr, size_t size);
virtual int write(const char *ptr);
virtual int write(const std::string &s);
2019-04-11 05:13:31 -07:00
virtual std::string get_remote_addr() const;
2018-10-28 00:15:22 -07:00
2019-04-11 05:13:31 -07:00
const std::string &get_buffer() const;
2018-10-28 00:15:22 -07:00
private:
2019-04-11 05:13:31 -07:00
std::string buffer;
2018-10-28 00:15:22 -07:00
};
2019-08-02 21:15:05 -07:00
class TaskQueue {
public:
TaskQueue() {}
virtual ~TaskQueue() {}
virtual void enqueue(std::function<void()> fn) = 0;
2019-08-02 21:15:05 -07:00
virtual void shutdown() = 0;
};
2019-08-03 00:18:15 -07:00
#if CPPHTTPLIB_THREAD_POOL_COUNT > 0
class ThreadPool : public TaskQueue {
2019-08-02 19:27:44 -07:00
public:
2019-08-06 02:10:41 -07:00
ThreadPool(size_t n) : shutdown_(false) {
2019-08-03 00:18:15 -07:00
while (n) {
auto t = std::make_shared<std::thread>(worker(*this));
threads_.push_back(t);
n--;
}
}
ThreadPool(const ThreadPool &) = delete;
virtual ~ThreadPool() {}
virtual void enqueue(std::function<void()> fn) override {
std::unique_lock<std::mutex> lock(mutex_);
jobs_.push_back(fn);
cond_.notify_one();
}
virtual void shutdown() override {
// Stop all worker threads...
{
std::unique_lock<std::mutex> lock(mutex_);
shutdown_ = true;
}
2019-08-06 02:10:41 -07:00
cond_.notify_all();
2019-08-03 00:18:15 -07:00
// Join...
for (auto t : threads_) {
t->join();
}
}
private:
struct worker {
worker(ThreadPool &pool) : pool_(pool) {}
void operator()() {
for (;;) {
2019-08-05 16:31:43 -07:00
std::function<void()> fn;
{
std::unique_lock<std::mutex> lock(pool_.mutex_);
2019-08-03 00:18:15 -07:00
2019-08-05 16:31:43 -07:00
pool_.cond_.wait(
lock, [&] { return !pool_.jobs_.empty() || pool_.shutdown_; });
2019-08-02 19:27:44 -07:00
2019-08-06 02:10:41 -07:00
if (pool_.shutdown_ && pool_.jobs_.empty()) { break; }
2019-08-03 00:18:15 -07:00
2019-08-05 16:31:43 -07:00
fn = pool_.jobs_.front();
pool_.jobs_.pop_front();
}
2019-08-03 00:18:15 -07:00
assert(true == (bool)fn);
fn();
}
}
ThreadPool &pool_;
};
friend struct worker;
std::vector<std::shared_ptr<std::thread>> threads_;
std::list<std::function<void()>> jobs_;
bool shutdown_;
std::condition_variable cond_;
std::mutex mutex_;
};
#else
class Threads : public TaskQueue {
public:
Threads() : running_threads_(0) {}
virtual ~Threads() {}
virtual void enqueue(std::function<void()> fn) override {
2019-08-02 19:27:44 -07:00
std::thread([=]() {
{
std::lock_guard<std::mutex> guard(running_threads_mutex_);
running_threads_++;
}
fn();
{
std::lock_guard<std::mutex> guard(running_threads_mutex_);
running_threads_--;
}
}).detach();
}
2019-08-02 21:15:05 -07:00
virtual void shutdown() override {
2019-08-02 19:27:44 -07:00
for (;;) {
std::this_thread::sleep_for(std::chrono::milliseconds(10));
std::lock_guard<std::mutex> guard(running_threads_mutex_);
if (!running_threads_) { break; }
}
}
private:
std::mutex running_threads_mutex_;
int running_threads_;
};
2019-08-03 00:18:15 -07:00
#endif
2019-08-02 19:27:44 -07:00
2012-09-22 21:40:46 -07:00
class Server {
public:
2019-04-11 05:13:31 -07:00
typedef std::function<void(const Request &, Response &)> Handler;
typedef std::function<void(const Request &, const Response &)> Logger;
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
Server();
2019-04-11 05:13:31 -07:00
virtual ~Server();
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
virtual bool is_valid() const;
2019-04-11 05:13:31 -07:00
Server &Get(const char *pattern, Handler handler);
Server &Post(const char *pattern, Handler handler);
2018-05-06 18:16:35 -07:00
2019-04-11 05:13:31 -07:00
Server &Put(const char *pattern, Handler handler);
Server &Patch(const char *pattern, Handler handler);
Server &Delete(const char *pattern, Handler handler);
Server &Options(const char *pattern, Handler handler);
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
bool set_base_dir(const char *path);
2019-08-25 14:19:20 -07:00
void set_file_request_handler(Handler handler);
2013-07-04 15:18:52 -07:00
2019-04-11 05:13:31 -07:00
void set_error_handler(Handler handler);
void set_logger(Logger logger);
2012-09-27 17:54:54 -07:00
2019-04-11 05:13:31 -07:00
void set_keep_alive_max_count(size_t count);
2019-04-12 20:34:27 -07:00
void set_payload_max_length(uint64_t length);
2019-08-02 18:47:48 -07:00
2019-04-11 05:13:31 -07:00
int bind_to_any_port(const char *host, int socket_flags = 0);
bool listen_after_bind();
2019-04-11 05:13:31 -07:00
bool listen(const char *host, int port, int socket_flags = 0);
2019-04-11 05:13:31 -07:00
bool is_running() const;
void stop();
2012-09-22 21:40:46 -07:00
2019-08-03 00:18:15 -07:00
std::function<TaskQueue *(void)> new_task_queue;
2019-08-02 21:15:05 -07:00
2017-04-21 20:00:00 -07:00
protected:
2019-04-11 05:13:31 -07:00
bool process_request(Stream &strm, bool last_connection,
2019-06-20 15:52:28 -07:00
bool &connection_close,
2019-07-28 16:12:44 -07:00
std::function<void(Request &)> setup_request);
2019-04-11 05:13:31 -07:00
size_t keep_alive_max_count_;
2019-04-12 20:34:27 -07:00
size_t payload_max_length_;
2012-09-22 21:40:46 -07:00
private:
2019-04-11 05:13:31 -07:00
typedef std::vector<std::pair<std::regex, Handler>> Handlers;
socket_t create_server_socket(const char *host, int port,
int socket_flags) const;
int bind_internal(const char *host, int port, int socket_flags);
bool listen_internal();
bool routing(Request &req, Response &res);
bool handle_file_request(Request &req, Response &res);
bool dispatch_request(Request &req, Response &res, Handlers &handlers);
bool parse_request_line(const char *s, Request &req);
2019-07-21 18:34:49 -07:00
bool write_response(Stream &strm, bool last_connection, const Request &req,
2019-04-11 05:13:31 -07:00
Response &res);
bool write_content_with_provider(Stream &strm, const Request &req,
Response &res, const std::string &boundary,
const std::string &content_type);
2019-04-11 05:13:31 -07:00
virtual bool read_and_close_socket(socket_t sock);
std::atomic<bool> is_running_;
std::atomic<socket_t> svr_sock_;
2019-04-11 05:13:31 -07:00
std::string base_dir_;
2019-08-25 14:19:20 -07:00
Handler file_request_handler_;
2019-04-11 05:13:31 -07:00
Handlers get_handlers_;
Handlers post_handlers_;
Handlers put_handlers_;
Handlers patch_handlers_;
Handlers delete_handlers_;
Handlers options_handlers_;
Handler error_handler_;
Logger logger_;
2012-10-02 17:39:13 -07:00
};
class Client {
public:
2019-04-11 05:13:31 -07:00
Client(const char *host, int port = 80, time_t timeout_sec = 300);
2019-04-11 05:13:31 -07:00
virtual ~Client();
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
virtual bool is_valid() const;
2019-04-11 05:13:31 -07:00
std::shared_ptr<Response> Get(const char *path, Progress progress = nullptr);
std::shared_ptr<Response> Get(const char *path, const Headers &headers,
Progress progress = nullptr);
2018-05-06 18:16:35 -07:00
2019-07-17 18:33:47 -07:00
std::shared_ptr<Response> Get(const char *path,
ContentReceiver content_receiver,
Progress progress = nullptr);
std::shared_ptr<Response> Get(const char *path, const Headers &headers,
ContentReceiver content_receiver,
Progress progress = nullptr);
2019-04-11 05:13:31 -07:00
std::shared_ptr<Response> Head(const char *path);
std::shared_ptr<Response> Head(const char *path, const Headers &headers);
2018-05-06 18:16:35 -07:00
2019-04-11 05:13:31 -07:00
std::shared_ptr<Response> Post(const char *path, const std::string &body,
const char *content_type);
std::shared_ptr<Response> Post(const char *path, const Headers &headers,
const std::string &body,
const char *content_type);
2018-05-06 18:16:35 -07:00
2019-04-11 05:13:31 -07:00
std::shared_ptr<Response> Post(const char *path, const Params &params);
std::shared_ptr<Response> Post(const char *path, const Headers &headers,
const Params &params);
2017-12-12 20:20:40 -07:00
2019-07-23 06:52:12 -07:00
std::shared_ptr<Response> Post(const char *path,
const MultipartFormDataItems &items);
std::shared_ptr<Response> Post(const char *path, const Headers &headers,
const MultipartFormDataItems &items);
2019-04-11 05:13:31 -07:00
std::shared_ptr<Response> Put(const char *path, const std::string &body,
const char *content_type);
std::shared_ptr<Response> Put(const char *path, const Headers &headers,
const std::string &body,
const char *content_type);
2017-12-12 20:20:40 -07:00
2019-04-11 05:13:31 -07:00
std::shared_ptr<Response> Patch(const char *path, const std::string &body,
const char *content_type);
std::shared_ptr<Response> Patch(const char *path, const Headers &headers,
const std::string &body,
const char *content_type);
2019-03-12 05:49:08 -07:00
2019-05-05 10:31:42 -07:00
std::shared_ptr<Response> Delete(const char *path,
const std::string &body = std::string(),
const char *content_type = nullptr);
std::shared_ptr<Response> Delete(const char *path, const Headers &headers,
const std::string &body = std::string(),
const char *content_type = nullptr);
2017-12-12 20:20:40 -07:00
2019-04-11 05:13:31 -07:00
std::shared_ptr<Response> Options(const char *path);
std::shared_ptr<Response> Options(const char *path, const Headers &headers);
2019-04-11 05:13:31 -07:00
bool send(Request &req, Response &res);
2017-04-21 20:00:00 -07:00
protected:
2019-04-11 05:13:31 -07:00
bool process_request(Stream &strm, Request &req, Response &res,
bool &connection_close);
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
const std::string host_;
const int port_;
time_t timeout_sec_;
const std::string host_and_port_;
2017-09-07 11:24:33 -07:00
2012-10-02 17:39:13 -07:00
private:
2019-04-11 05:13:31 -07:00
socket_t create_client_socket() const;
bool read_response_line(Stream &strm, Response &res);
void write_request(Stream &strm, Request &req);
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
virtual bool read_and_close_socket(socket_t sock, Request &req,
Response &res);
virtual bool is_ssl() const;
2012-09-22 21:40:46 -07:00
};
2017-04-21 20:00:00 -07:00
#ifdef CPPHTTPLIB_OPENSSL_SUPPORT
class SSLSocketStream : public Stream {
public:
2019-04-11 05:13:31 -07:00
SSLSocketStream(socket_t sock, SSL *ssl);
virtual ~SSLSocketStream();
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
virtual int read(char *ptr, size_t size);
virtual int write(const char *ptr, size_t size);
virtual int write(const char *ptr);
virtual int write(const std::string &s);
2019-04-11 05:13:31 -07:00
virtual std::string get_remote_addr() const;
2017-04-21 20:00:00 -07:00
private:
2019-04-11 05:13:31 -07:00
socket_t sock_;
SSL *ssl_;
2017-04-21 20:00:00 -07:00
};
class SSLServer : public Server {
public:
2019-06-11 17:57:02 -07:00
SSLServer(const char *cert_path, const char *private_key_path,
2019-06-11 18:18:45 -07:00
const char *client_ca_cert_file_path = nullptr,
const char *client_ca_cert_dir_path = nullptr);
2019-04-11 05:13:31 -07:00
virtual ~SSLServer();
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
virtual bool is_valid() const;
2017-04-21 20:00:00 -07:00
private:
2019-04-11 05:13:31 -07:00
virtual bool read_and_close_socket(socket_t sock);
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
SSL_CTX *ctx_;
std::mutex ctx_mutex_;
2017-04-21 20:00:00 -07:00
};
class SSLClient : public Client {
public:
SSLClient(const char *host, int port = 443, time_t timeout_sec = 300,
2019-06-11 17:57:02 -07:00
const char *client_cert_path = nullptr,
const char *client_key_path = nullptr);
2019-04-11 05:13:31 -07:00
virtual ~SSLClient();
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
virtual bool is_valid() const;
2019-06-11 18:18:45 -07:00
void set_ca_cert_path(const char *ca_ceert_file_path,
const char *ca_cert_dir_path = nullptr);
void enable_server_certificate_verification(bool enabled);
2019-05-07 13:41:33 -07:00
long get_openssl_verify_result() const;
2017-04-21 20:00:00 -07:00
private:
2019-04-11 05:13:31 -07:00
virtual bool read_and_close_socket(socket_t sock, Request &req,
Response &res);
virtual bool is_ssl() const;
2017-04-21 20:00:00 -07:00
bool verify_host(X509 *server_cert) const;
bool verify_host_with_subject_alt_name(X509 *server_cert) const;
bool verify_host_with_common_name(X509 *server_cert) const;
bool check_host_name(const char *pattern, size_t pattern_len) const;
2019-05-07 13:41:33 -07:00
2019-04-11 05:13:31 -07:00
SSL_CTX *ctx_;
std::mutex ctx_mutex_;
std::vector<std::string> host_components_;
2019-06-11 18:18:45 -07:00
std::string ca_cert_file_path_;
std::string ca_cert_dir_path_;
bool server_certificate_verification_ = false;
2019-05-07 13:41:33 -07:00
long verify_result_ = 0;
2017-04-21 20:00:00 -07:00
};
#endif
/*
* Implementation
*/
namespace detail {
2012-09-22 21:40:46 -07:00
2019-07-17 12:09:41 -07:00
inline bool is_hex(char c, int &v) {
if (0x20 <= c && isdigit(c)) {
v = c - '0';
return true;
} else if ('A' <= c && c <= 'F') {
v = c - 'A' + 10;
return true;
} else if ('a' <= c && c <= 'f') {
v = c - 'a' + 10;
return true;
}
return false;
2019-07-17 05:56:49 -07:00
}
2019-07-17 12:09:41 -07:00
inline bool from_hex_to_i(const std::string &s, size_t i, size_t cnt,
int &val) {
if (i >= s.size()) { return false; }
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
val = 0;
for (; cnt; i++, cnt--) {
if (!s[i]) { return false; }
int v = 0;
if (is_hex(s[i], v)) {
val = val * 16 + v;
} else {
return false;
}
}
return true;
}
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
inline std::string from_i_to_hex(uint64_t n) {
const char *charset = "0123456789abcdef";
std::string ret;
do {
ret = charset[n & 15] + ret;
n >>= 4;
} while (n > 0);
return ret;
}
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
inline size_t to_utf8(int code, char *buff) {
if (code < 0x0080) {
buff[0] = (code & 0x7F);
return 1;
} else if (code < 0x0800) {
buff[0] = (0xC0 | ((code >> 6) & 0x1F));
buff[1] = (0x80 | (code & 0x3F));
return 2;
} else if (code < 0xD800) {
buff[0] = (0xE0 | ((code >> 12) & 0xF));
buff[1] = (0x80 | ((code >> 6) & 0x3F));
buff[2] = (0x80 | (code & 0x3F));
return 3;
} else if (code < 0xE000) { // D800 - DFFF is invalid...
return 0;
} else if (code < 0x10000) {
buff[0] = (0xE0 | ((code >> 12) & 0xF));
buff[1] = (0x80 | ((code >> 6) & 0x3F));
buff[2] = (0x80 | (code & 0x3F));
return 3;
} else if (code < 0x110000) {
buff[0] = (0xF0 | ((code >> 18) & 0x7));
buff[1] = (0x80 | ((code >> 12) & 0x3F));
buff[2] = (0x80 | ((code >> 6) & 0x3F));
buff[3] = (0x80 | (code & 0x3F));
return 4;
}
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
// NOTREACHED
return 0;
}
2019-07-17 05:56:49 -07:00
2019-07-19 08:38:06 -07:00
// NOTE: This code came up with the following stackoverflow post:
// https://stackoverflow.com/questions/180947/base64-decode-snippet-in-c
inline std::string base64_encode(const std::string &in) {
static const auto lookup =
"ABCDEFGHIJKLMNOPQRSTUVWXYZabcdefghijklmnopqrstuvwxyz0123456789+/";
std::string out;
out.reserve(in.size());
int val = 0;
int valb = -6;
for (uint8_t c : in) {
val = (val << 8) + c;
valb += 8;
while (valb >= 0) {
out.push_back(lookup[(val >> valb) & 0x3F]);
valb -= 6;
}
}
2019-07-23 06:52:12 -07:00
if (valb > -6) { out.push_back(lookup[((val << 8) >> (valb + 8)) & 0x3F]); }
2019-07-19 08:38:06 -07:00
while (out.size() % 4) {
out.push_back('=');
}
return out;
}
2019-07-17 12:09:41 -07:00
inline bool is_file(const std::string &path) {
struct stat st;
return stat(path.c_str(), &st) >= 0 && S_ISREG(st.st_mode);
}
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
inline bool is_dir(const std::string &path) {
struct stat st;
return stat(path.c_str(), &st) >= 0 && S_ISDIR(st.st_mode);
2019-07-17 05:56:49 -07:00
}
2019-07-17 12:09:41 -07:00
inline bool is_valid_path(const std::string &path) {
size_t level = 0;
size_t i = 0;
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
// Skip slash
while (i < path.size() && path[i] == '/') {
i++;
}
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
while (i < path.size()) {
// Read component
auto beg = i;
while (i < path.size() && path[i] != '/') {
i++;
}
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
auto len = i - beg;
assert(len > 0);
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
if (!path.compare(beg, len, ".")) {
;
} else if (!path.compare(beg, len, "..")) {
if (level == 0) { return false; }
level--;
} else {
level++;
}
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
// Skip slash
while (i < path.size() && path[i] == '/') {
i++;
}
}
2019-07-17 05:56:49 -07:00
2019-07-17 12:09:41 -07:00
return true;
}
inline void read_file(const std::string &path, std::string &out) {
std::ifstream fs(path, std::ios_base::binary);
fs.seekg(0, std::ios_base::end);
auto size = fs.tellg();
fs.seekg(0);
out.resize(static_cast<size_t>(size));
fs.read(&out[0], size);
}
inline std::string file_extension(const std::string &path) {
std::smatch m;
auto pat = std::regex("\\.([a-zA-Z0-9]+)$");
if (std::regex_search(path, m, pat)) { return m[1].str(); }
return std::string();
2019-07-17 05:56:49 -07:00
}
2019-04-11 05:13:31 -07:00
template <class Fn> void split(const char *b, const char *e, char d, Fn fn) {
int i = 0;
int beg = 0;
2012-09-24 20:13:01 -07:00
2019-04-11 05:13:31 -07:00
while (e ? (b + i != e) : (b[i] != '\0')) {
if (b[i] == d) {
fn(&b[beg], &b[i]);
beg = i + 1;
2012-09-24 20:13:01 -07:00
}
2019-04-11 05:13:31 -07:00
i++;
}
2012-09-24 20:13:01 -07:00
2019-04-11 05:13:31 -07:00
if (i) { fn(&b[beg], &b[i]); }
2012-09-24 20:13:01 -07:00
}
2017-12-10 13:11:03 -07:00
// NOTE: until the read size reaches `fixed_buffer_size`, use `fixed_buffer`
// to store data. The call can set memory on stack for performance.
2017-12-09 14:45:40 -07:00
class stream_line_reader {
2017-12-06 21:52:34 -07:00
public:
2019-04-11 05:13:31 -07:00
stream_line_reader(Stream &strm, char *fixed_buffer, size_t fixed_buffer_size)
: strm_(strm), fixed_buffer_(fixed_buffer),
fixed_buffer_size_(fixed_buffer_size) {}
2019-04-11 05:13:31 -07:00
const char *ptr() const {
if (glowable_buffer_.empty()) {
return fixed_buffer_;
} else {
return glowable_buffer_.data();
2017-12-06 21:52:34 -07:00
}
2019-04-11 05:13:31 -07:00
}
2019-04-11 05:13:31 -07:00
size_t size() const {
if (glowable_buffer_.empty()) {
return fixed_buffer_used_size_;
} else {
return glowable_buffer_.size();
2019-04-10 09:21:42 -07:00
}
2019-04-11 05:13:31 -07:00
}
2019-04-10 09:21:42 -07:00
2019-04-11 05:13:31 -07:00
bool getline() {
fixed_buffer_used_size_ = 0;
glowable_buffer_.clear();
2017-12-06 21:52:34 -07:00
2019-04-11 05:13:31 -07:00
for (size_t i = 0;; i++) {
char byte;
auto n = strm_.read(&byte, 1);
2019-04-11 05:13:31 -07:00
if (n < 0) {
return false;
} else if (n == 0) {
if (i == 0) {
return false;
2017-12-06 21:52:34 -07:00
} else {
2019-04-11 05:13:31 -07:00
break;
2017-12-06 21:52:34 -07:00
}
2019-04-11 05:13:31 -07:00
}
append(byte);
if (byte == '\n') { break; }
2017-12-02 08:24:41 -07:00
}
2019-04-11 05:13:31 -07:00
return true;
}
private:
void append(char c) {
if (fixed_buffer_used_size_ < fixed_buffer_size_ - 1) {
fixed_buffer_[fixed_buffer_used_size_++] = c;
fixed_buffer_[fixed_buffer_used_size_] = '\0';
} else {
if (glowable_buffer_.empty()) {
assert(fixed_buffer_[fixed_buffer_used_size_] == '\0');
glowable_buffer_.assign(fixed_buffer_, fixed_buffer_used_size_);
}
glowable_buffer_ += c;
}
}
Stream &strm_;
char *fixed_buffer_;
const size_t fixed_buffer_size_;
size_t fixed_buffer_used_size_;
std::string glowable_buffer_;
2017-12-06 21:52:34 -07:00
};
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
inline int close_socket(socket_t sock) {
2017-12-06 22:20:59 -07:00
#ifdef _WIN32
2019-04-11 05:13:31 -07:00
return closesocket(sock);
2015-01-14 16:51:53 -07:00
#else
2019-04-11 05:13:31 -07:00
return close(sock);
2015-01-14 16:51:53 -07:00
#endif
}
2019-04-11 05:13:31 -07:00
inline int select_read(socket_t sock, time_t sec, time_t usec) {
fd_set fds;
FD_ZERO(&fds);
FD_SET(sock, &fds);
2019-04-11 05:13:31 -07:00
timeval tv;
tv.tv_sec = static_cast<long>(sec);
tv.tv_usec = static_cast<long>(usec);
2019-05-07 17:11:45 -07:00
return select(static_cast<int>(sock + 1), &fds, nullptr, nullptr, &tv);
}
2019-04-11 05:13:31 -07:00
inline bool wait_until_socket_is_ready(socket_t sock, time_t sec, time_t usec) {
fd_set fdsr;
FD_ZERO(&fdsr);
FD_SET(sock, &fdsr);
2019-04-11 05:13:31 -07:00
auto fdsw = fdsr;
auto fdse = fdsr;
2019-04-11 05:13:31 -07:00
timeval tv;
tv.tv_sec = static_cast<long>(sec);
tv.tv_usec = static_cast<long>(usec);
2019-04-11 05:13:31 -07:00
if (select(static_cast<int>(sock + 1), &fdsr, &fdsw, &fdse, &tv) < 0) {
return false;
} else if (FD_ISSET(sock, &fdsr) || FD_ISSET(sock, &fdsw)) {
int error = 0;
socklen_t len = sizeof(error);
if (getsockopt(sock, SOL_SOCKET, SO_ERROR, (char *)&error, &len) < 0 ||
error) {
return false;
}
} else {
return false;
}
2019-04-11 05:13:31 -07:00
return true;
}
template <typename T>
2019-04-11 05:13:31 -07:00
inline bool read_and_close_socket(socket_t sock, size_t keep_alive_max_count,
T callback) {
bool ret = false;
if (keep_alive_max_count > 0) {
auto count = keep_alive_max_count;
while (count > 0 &&
detail::select_read(sock, CPPHTTPLIB_KEEPALIVE_TIMEOUT_SECOND,
CPPHTTPLIB_KEEPALIVE_TIMEOUT_USECOND) > 0) {
SocketStream strm(sock);
auto last_connection = count == 1;
auto connection_close = false;
ret = callback(strm, last_connection, connection_close);
if (!ret || connection_close) { break; }
count--;
}
2019-04-11 05:13:31 -07:00
} else {
SocketStream strm(sock);
auto dummy_connection_close = false;
ret = callback(strm, true, dummy_connection_close);
}
2019-04-11 05:13:31 -07:00
close_socket(sock);
return ret;
}
2019-04-11 05:13:31 -07:00
inline int shutdown_socket(socket_t sock) {
2017-12-06 22:20:59 -07:00
#ifdef _WIN32
2019-04-11 05:13:31 -07:00
return shutdown(sock, SD_BOTH);
#else
2019-04-11 05:13:31 -07:00
return shutdown(sock, SHUT_RDWR);
#endif
}
2012-10-02 17:39:13 -07:00
template <typename Fn>
2019-04-11 05:13:31 -07:00
socket_t create_socket(const char *host, int port, Fn fn,
int socket_flags = 0) {
2017-12-06 22:20:59 -07:00
#ifdef _WIN32
2017-12-07 06:28:06 -07:00
#define SO_SYNCHRONOUS_NONALERT 0x20
#define SO_OPENTYPE 0x7008
2019-04-11 05:13:31 -07:00
int opt = SO_SYNCHRONOUS_NONALERT;
setsockopt(INVALID_SOCKET, SOL_SOCKET, SO_OPENTYPE, (char *)&opt,
sizeof(opt));
2012-09-25 19:09:56 -07:00
#endif
2019-04-11 05:13:31 -07:00
// Get address info
struct addrinfo hints;
struct addrinfo *result;
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
memset(&hints, 0, sizeof(struct addrinfo));
hints.ai_family = AF_UNSPEC;
hints.ai_socktype = SOCK_STREAM;
hints.ai_flags = socket_flags;
hints.ai_protocol = 0;
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
auto service = std::to_string(port);
2015-01-14 16:51:53 -07:00
2019-04-11 05:13:31 -07:00
if (getaddrinfo(host, service.c_str(), &hints, &result)) {
return INVALID_SOCKET;
}
2015-01-14 16:51:53 -07:00
2019-04-11 05:13:31 -07:00
for (auto rp = result; rp; rp = rp->ai_next) {
// Create a socket
2019-06-20 14:11:44 -07:00
#ifdef _WIN32
2019-07-03 07:51:52 -07:00
auto sock = WSASocketW(rp->ai_family, rp->ai_socktype, rp->ai_protocol,
nullptr, 0, WSA_FLAG_NO_HANDLE_INHERIT);
2019-06-20 14:11:44 -07:00
#else
2019-04-11 05:13:31 -07:00
auto sock = socket(rp->ai_family, rp->ai_socktype, rp->ai_protocol);
2019-06-20 14:11:44 -07:00
#endif
2019-04-11 05:13:31 -07:00
if (sock == INVALID_SOCKET) { continue; }
2015-01-14 16:51:53 -07:00
2019-06-20 14:11:44 -07:00
#ifndef _WIN32
if (fcntl(sock, F_SETFD, FD_CLOEXEC) == -1) { continue; }
#endif
2019-04-11 05:13:31 -07:00
// Make 'reuse address' option available
int yes = 1;
setsockopt(sock, SOL_SOCKET, SO_REUSEADDR, (char *)&yes, sizeof(yes));
2019-06-28 09:08:47 -07:00
#ifdef SO_REUSEPORT
setsockopt(sock, SOL_SOCKET, SO_REUSEPORT, (char *)&yes, sizeof(yes));
#endif
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
// bind or connect
if (fn(sock, *rp)) {
freeaddrinfo(result);
return sock;
2015-01-14 16:51:53 -07:00
}
2019-04-11 05:13:31 -07:00
close_socket(sock);
}
freeaddrinfo(result);
return INVALID_SOCKET;
2012-10-02 17:39:13 -07:00
}
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
inline void set_nonblocking(socket_t sock, bool nonblocking) {
#ifdef _WIN32
2019-04-11 05:13:31 -07:00
auto flags = nonblocking ? 1UL : 0UL;
ioctlsocket(sock, FIONBIO, &flags);
#else
2019-04-11 05:13:31 -07:00
auto flags = fcntl(sock, F_GETFL, 0);
fcntl(sock, F_SETFL,
nonblocking ? (flags | O_NONBLOCK) : (flags & (~O_NONBLOCK)));
#endif
2012-09-22 21:40:46 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool is_connection_error() {
#ifdef _WIN32
2019-04-11 05:13:31 -07:00
return WSAGetLastError() != WSAEWOULDBLOCK;
#else
2019-04-11 05:13:31 -07:00
return errno != EINPROGRESS;
#endif
2012-10-02 17:39:13 -07:00
}
2012-09-25 20:21:57 -07:00
inline std::string get_remote_addr(socket_t sock) {
2019-04-11 05:13:31 -07:00
struct sockaddr_storage addr;
socklen_t len = sizeof(addr);
2018-04-29 13:14:47 -07:00
2019-04-11 05:13:31 -07:00
if (!getpeername(sock, (struct sockaddr *)&addr, &len)) {
char ipstr[NI_MAXHOST];
2018-04-29 13:14:47 -07:00
2019-04-11 05:13:31 -07:00
if (!getnameinfo((struct sockaddr *)&addr, len, ipstr, sizeof(ipstr),
nullptr, 0, NI_NUMERICHOST)) {
return ipstr;
}
2019-04-11 05:13:31 -07:00
}
2019-04-11 05:13:31 -07:00
return std::string();
}
2019-04-11 05:13:31 -07:00
inline const char *find_content_type(const std::string &path) {
auto ext = file_extension(path);
if (ext == "txt") {
return "text/plain";
} else if (ext == "html") {
return "text/html";
} else if (ext == "css") {
return "text/css";
} else if (ext == "jpeg" || ext == "jpg") {
return "image/jpg";
} else if (ext == "png") {
return "image/png";
} else if (ext == "gif") {
return "image/gif";
} else if (ext == "svg") {
return "image/svg+xml";
} else if (ext == "ico") {
return "image/x-icon";
} else if (ext == "json") {
return "application/json";
} else if (ext == "pdf") {
return "application/pdf";
} else if (ext == "js") {
return "application/javascript";
} else if (ext == "xml") {
return "application/xml";
} else if (ext == "xhtml") {
return "application/xhtml+xml";
}
return nullptr;
}
inline const char *status_message(int status) {
switch (status) {
case 200: return "OK";
2019-07-29 06:47:50 -07:00
case 206: return "Partial Content";
2019-04-11 05:13:31 -07:00
case 301: return "Moved Permanently";
case 302: return "Found";
case 303: return "See Other";
case 304: return "Not Modified";
case 400: return "Bad Request";
case 403: return "Forbidden";
case 404: return "Not Found";
2019-04-12 20:34:27 -07:00
case 413: return "Payload Too Large";
2019-04-11 05:13:31 -07:00
case 414: return "Request-URI Too Long";
case 415: return "Unsupported Media Type";
2019-07-29 06:47:50 -07:00
case 416: return "Range Not Satisfiable";
2019-04-11 05:13:31 -07:00
default:
case 500: return "Internal Server Error";
}
}
2019-07-17 12:09:41 -07:00
#ifdef CPPHTTPLIB_ZLIB_SUPPORT
inline bool can_compress(const std::string &content_type) {
return !content_type.find("text/") || content_type == "image/svg+xml" ||
content_type == "application/javascript" ||
content_type == "application/json" ||
content_type == "application/xml" ||
content_type == "application/xhtml+xml";
}
inline bool compress(std::string &content) {
2019-07-17 12:09:41 -07:00
z_stream strm;
strm.zalloc = Z_NULL;
strm.zfree = Z_NULL;
strm.opaque = Z_NULL;
auto ret = deflateInit2(&strm, Z_DEFAULT_COMPRESSION, Z_DEFLATED, 31, 8,
Z_DEFAULT_STRATEGY);
if (ret != Z_OK) { return false; }
2019-07-17 12:09:41 -07:00
strm.avail_in = content.size();
strm.next_in = (Bytef *)content.data();
std::string compressed;
const auto bufsiz = 16384;
char buff[bufsiz];
do {
strm.avail_out = bufsiz;
strm.next_out = (Bytef *)buff;
ret = deflate(&strm, Z_FINISH);
assert(ret != Z_STREAM_ERROR);
2019-07-17 12:09:41 -07:00
compressed.append(buff, bufsiz - strm.avail_out);
} while (strm.avail_out == 0);
assert(ret == Z_STREAM_END);
assert(strm.avail_in == 0);
2019-07-17 12:09:41 -07:00
content.swap(compressed);
deflateEnd(&strm);
return true;
2019-07-17 12:09:41 -07:00
}
2019-07-17 18:33:47 -07:00
class decompressor {
public:
decompressor() {
strm.zalloc = Z_NULL;
strm.zfree = Z_NULL;
strm.opaque = Z_NULL;
// 15 is the value of wbits, which should be at the maximum possible value
// to ensure that any gzip stream can be decoded. The offset of 16 specifies
// that the stream to decompress will be formatted with a gzip wrapper.
is_valid_ = inflateInit2(&strm, 16 + 15) == Z_OK;
}
~decompressor() { inflateEnd(&strm); }
bool is_valid() const { return is_valid_; }
template <typename T>
bool decompress(const char *data, size_t data_length, T callback) {
2019-07-17 18:33:47 -07:00
int ret = Z_OK;
strm.avail_in = data_length;
2019-07-17 18:33:47 -07:00
strm.next_in = (Bytef *)data;
const auto bufsiz = 16384;
char buff[bufsiz];
do {
strm.avail_out = bufsiz;
strm.next_out = (Bytef *)buff;
ret = inflate(&strm, Z_NO_FLUSH);
assert(ret != Z_STREAM_ERROR);
switch (ret) {
case Z_NEED_DICT:
case Z_DATA_ERROR:
case Z_MEM_ERROR: inflateEnd(&strm); return false;
}
if (!callback(buff, bufsiz - strm.avail_out)) { return false; }
2019-07-17 18:33:47 -07:00
} while (strm.avail_out == 0);
2019-07-26 11:38:10 -07:00
return ret == Z_STREAM_END;
2019-07-17 18:33:47 -07:00
}
private:
bool is_valid_;
z_stream strm;
};
2019-07-17 12:09:41 -07:00
#endif
2019-04-11 05:13:31 -07:00
inline bool has_header(const Headers &headers, const char *key) {
return headers.find(key) != headers.end();
}
inline const char *get_header_value(const Headers &headers, const char *key,
size_t id = 0, const char *def = nullptr) {
auto it = headers.find(key);
std::advance(it, id);
if (it != headers.end()) { return it->second.c_str(); }
return def;
}
inline uint64_t get_header_value_uint64(const Headers &headers, const char *key,
2019-04-12 20:34:27 -07:00
int def = 0) {
auto it = headers.find(key);
if (it != headers.end()) {
return std::strtoull(it->second.data(), nullptr, 10);
}
return def;
}
2019-04-11 05:13:31 -07:00
inline bool read_headers(Stream &strm, Headers &headers) {
static std::regex re(R"((.+?):\s*(.+?)\s*\r\n)");
const auto bufsiz = 2048;
char buf[bufsiz];
stream_line_reader reader(strm, buf, bufsiz);
for (;;) {
if (!reader.getline()) { return false; }
if (!strcmp(reader.ptr(), "\r\n")) { break; }
std::cmatch m;
if (std::regex_match(reader.ptr(), m, re)) {
auto key = std::string(m[1]);
auto val = std::string(m[2]);
headers.emplace(key, val);
2012-10-02 17:39:13 -07:00
}
2019-04-11 05:13:31 -07:00
}
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
return true;
2012-10-02 17:39:13 -07:00
}
typedef std::function<bool(const char *data, uint64_t data_length)>
ContentReceiverCore;
2019-07-17 05:56:49 -07:00
inline bool read_content_with_length(Stream &strm, size_t len,
Progress progress,
ContentReceiverCore out) {
2019-07-17 05:56:49 -07:00
char buf[CPPHTTPLIB_RECV_BUFSIZ];
2019-04-11 05:13:31 -07:00
size_t r = 0;
while (r < len) {
2019-07-17 05:56:49 -07:00
auto n = strm.read(buf, std::min((len - r), CPPHTTPLIB_RECV_BUFSIZ));
2019-04-11 05:13:31 -07:00
if (n <= 0) { return false; }
2017-12-06 21:52:34 -07:00
if (!out(buf, n)) { return false; }
2019-07-17 05:56:49 -07:00
2019-04-11 05:13:31 -07:00
r += n;
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
if (progress) {
if (!progress(r, len)) { return false; }
2012-09-25 20:21:57 -07:00
}
2019-04-11 05:13:31 -07:00
}
2012-10-03 18:55:01 -07:00
2019-04-11 05:13:31 -07:00
return true;
2012-10-03 18:55:01 -07:00
}
2019-05-07 13:41:50 -07:00
inline void skip_content_with_length(Stream &strm, size_t len) {
2019-06-29 17:39:18 -07:00
char buf[CPPHTTPLIB_RECV_BUFSIZ];
2019-05-07 13:41:50 -07:00
size_t r = 0;
while (r < len) {
2019-07-17 05:56:49 -07:00
auto n = strm.read(buf, std::min((len - r), CPPHTTPLIB_RECV_BUFSIZ));
2019-05-07 13:41:50 -07:00
if (n <= 0) { return; }
r += n;
}
}
inline bool read_content_without_length(Stream &strm, ContentReceiverCore out) {
2019-06-29 17:39:18 -07:00
char buf[CPPHTTPLIB_RECV_BUFSIZ];
2019-04-11 05:13:31 -07:00
for (;;) {
2019-06-29 17:39:18 -07:00
auto n = strm.read(buf, CPPHTTPLIB_RECV_BUFSIZ);
2019-04-11 05:13:31 -07:00
if (n < 0) {
return false;
} else if (n == 0) {
return true;
2017-12-03 19:25:38 -07:00
}
if (!out(buf, n)) { return false; }
2019-04-11 05:13:31 -07:00
}
2017-12-03 19:25:38 -07:00
2019-04-11 05:13:31 -07:00
return true;
2017-12-03 19:25:38 -07:00
}
inline bool read_content_chunked(Stream &strm, ContentReceiverCore out) {
2019-04-11 05:13:31 -07:00
const auto bufsiz = 16;
char buf[bufsiz];
2017-12-03 19:25:38 -07:00
2019-04-11 05:13:31 -07:00
stream_line_reader reader(strm, buf, bufsiz);
2017-12-03 19:25:38 -07:00
2019-04-11 05:13:31 -07:00
if (!reader.getline()) { return false; }
2017-12-03 19:25:38 -07:00
2019-04-11 05:13:31 -07:00
auto chunk_len = std::stoi(reader.ptr(), 0, 16);
2017-12-06 21:52:34 -07:00
2019-04-11 05:13:31 -07:00
while (chunk_len > 0) {
if (!read_content_with_length(strm, chunk_len, nullptr, out)) {
2019-04-11 05:13:31 -07:00
return false;
2017-12-03 19:25:38 -07:00
}
2019-04-11 05:13:31 -07:00
if (!reader.getline()) { return false; }
2017-12-03 19:25:38 -07:00
2019-04-11 05:13:31 -07:00
if (strcmp(reader.ptr(), "\r\n")) { break; }
2017-12-03 19:25:38 -07:00
2019-04-11 05:13:31 -07:00
if (!reader.getline()) { return false; }
2017-12-03 19:25:38 -07:00
2019-04-11 05:13:31 -07:00
chunk_len = std::stoi(reader.ptr(), 0, 16);
}
2017-12-03 19:25:38 -07:00
2019-04-11 05:13:31 -07:00
if (chunk_len == 0) {
// Reader terminator after chunks
if (!reader.getline() || strcmp(reader.ptr(), "\r\n")) return false;
}
2019-04-11 05:13:31 -07:00
return true;
2017-12-03 19:25:38 -07:00
}
2019-07-17 05:56:49 -07:00
inline bool is_chunked_transfer_encoding(const Headers &headers) {
return !strcasecmp(get_header_value(headers, "Transfer-Encoding", 0, ""),
"chunked");
}
template <typename T>
2019-07-17 05:56:49 -07:00
bool read_content(Stream &strm, T &x, uint64_t payload_max_length, int &status,
Progress progress, ContentReceiverCore receiver) {
2019-07-17 18:33:47 -07:00
ContentReceiverCore out = [&](const char *buf, size_t n) {
return receiver(buf, n);
};
2019-07-17 18:33:47 -07:00
#ifdef CPPHTTPLIB_ZLIB_SUPPORT
detail::decompressor decompressor;
if (!decompressor.is_valid()) {
status = 500;
return false;
}
2019-07-17 05:56:49 -07:00
2019-07-17 18:33:47 -07:00
if (x.get_header_value("Content-Encoding") == "gzip") {
out = [&](const char *buf, size_t n) {
return decompressor.decompress(
buf, n, [&](const char *buf, size_t n) { return receiver(buf, n); });
2019-07-17 18:33:47 -07:00
};
}
#else
2019-07-17 05:56:49 -07:00
if (x.get_header_value("Content-Encoding") == "gzip") {
status = 415;
return false;
}
#endif
auto ret = true;
auto exceed_payload_max_length = false;
if (is_chunked_transfer_encoding(x.headers)) {
2019-07-17 18:33:47 -07:00
ret = read_content_chunked(strm, out);
2019-07-17 05:56:49 -07:00
} else if (!has_header(x.headers, "Content-Length")) {
2019-07-17 18:33:47 -07:00
ret = read_content_without_length(strm, out);
2019-07-17 05:56:49 -07:00
} else {
auto len = get_header_value_uint64(x.headers, "Content-Length", 0);
2019-07-17 05:56:49 -07:00
if (len > 0) {
if ((len > payload_max_length) ||
// For 32-bit platform
(sizeof(size_t) < sizeof(uint64_t) &&
len > std::numeric_limits<size_t>::max())) {
exceed_payload_max_length = true;
skip_content_with_length(strm, len);
ret = false;
} else {
2019-07-17 18:33:47 -07:00
ret = read_content_with_length(strm, len, progress, out);
2019-04-11 05:13:31 -07:00
}
}
2019-07-17 05:56:49 -07:00
}
2019-04-12 20:34:27 -07:00
2019-07-17 18:33:47 -07:00
if (!ret) { status = exceed_payload_max_length ? 413 : 400; }
2019-07-17 05:56:49 -07:00
return ret;
2019-04-11 05:13:31 -07:00
}
2019-07-21 18:34:49 -07:00
template <typename T> inline int write_headers(Stream &strm, const T &info) {
auto write_len = 0;
2019-04-11 05:13:31 -07:00
for (const auto &x : info.headers) {
2019-07-23 06:52:12 -07:00
auto len =
strm.write_format("%s: %s\r\n", x.first.c_str(), x.second.c_str());
if (len < 0) { return len; }
2019-07-21 18:34:49 -07:00
write_len += len;
}
auto len = strm.write("\r\n");
2019-07-23 06:52:12 -07:00
if (len < 0) { return len; }
2019-07-21 18:34:49 -07:00
write_len += len;
return write_len;
2019-04-11 05:13:31 -07:00
}
inline int write_content(Stream &strm, ContentProvider content_provider,
uint64_t offset, uint64_t length) {
uint64_t begin_offset = offset;
uint64_t end_offset = offset + length;
while (offset < end_offset) {
2019-08-03 17:43:15 -07:00
int64_t written_length = 0;
content_provider(
offset, end_offset - offset,
[&](const char *d, uint64_t l) {
offset += l;
written_length = strm.write(d, l);
},
[&](void) { written_length = -1; });
2019-08-03 17:43:15 -07:00
if (written_length < 0) { return static_cast<int>(written_length); }
}
2019-08-03 17:43:15 -07:00
return static_cast<int>(offset - begin_offset);
}
inline int write_content_chunked(Stream &strm,
ContentProvider content_provider) {
2019-07-17 12:09:41 -07:00
uint64_t offset = 0;
auto data_available = true;
2019-08-03 17:43:15 -07:00
uint64_t total_written_length = 0;
2019-07-17 12:09:41 -07:00
while (data_available) {
2019-08-03 17:43:15 -07:00
int64_t written_length = 0;
content_provider(
offset, 0,
[&](const char *d, uint64_t l) {
data_available = l > 0;
offset += l;
2019-07-17 12:09:41 -07:00
// Emit chunked response header and footer for each chunk
auto chunk = from_i_to_hex(l) + "\r\n" + std::string(d, l) + "\r\n";
written_length = strm.write(chunk);
},
[&](void) {
data_available = false;
written_length = strm.write("0\r\n\r\n");
});
2019-07-17 12:09:41 -07:00
2019-08-03 17:43:15 -07:00
if (written_length < 0) { return static_cast<int>(written_length); }
total_written_length += written_length;
2019-07-17 12:09:41 -07:00
}
2019-08-03 17:43:15 -07:00
return static_cast<int>(total_written_length);
2019-07-17 12:09:41 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::string encode_url(const std::string &s) {
std::string result;
for (auto i = 0; s[i]; i++) {
switch (s[i]) {
case ' ': result += "%20"; break;
case '+': result += "%2B"; break;
case '\r': result += "%0D"; break;
case '\n': result += "%0A"; break;
case '\'': result += "%27"; break;
case ',': result += "%2C"; break;
case ':': result += "%3A"; break;
case ';': result += "%3B"; break;
default:
auto c = static_cast<uint8_t>(s[i]);
if (c >= 0x80) {
result += '%';
char hex[4];
size_t len = snprintf(hex, sizeof(hex) - 1, "%02X", c);
assert(len == 2);
result.append(hex, len);
} else {
result += s[i];
}
break;
}
}
return result;
}
inline std::string decode_url(const std::string &s) {
std::string result;
for (size_t i = 0; i < s.size(); i++) {
if (s[i] == '%' && i + 1 < s.size()) {
if (s[i + 1] == 'u') {
int val = 0;
if (from_hex_to_i(s, i + 2, 4, val)) {
// 4 digits Unicode codes
char buff[4];
size_t len = to_utf8(val, buff);
if (len > 0) { result.append(buff, len); }
i += 5; // 'u0000'
} else {
result += s[i];
2017-12-03 20:31:00 -07:00
}
2019-04-11 05:13:31 -07:00
} else {
int val = 0;
if (from_hex_to_i(s, i + 1, 2, val)) {
// 2 digits hex codes
result += val;
i += 2; // '00'
2012-10-11 20:52:34 -07:00
} else {
2019-04-11 05:13:31 -07:00
result += s[i];
2012-10-11 20:52:34 -07:00
}
2019-04-11 05:13:31 -07:00
}
} else if (s[i] == '+') {
result += ' ';
} else {
result += s[i];
2012-10-11 20:52:34 -07:00
}
2019-04-11 05:13:31 -07:00
}
2012-10-11 20:52:34 -07:00
2019-04-11 05:13:31 -07:00
return result;
2012-10-11 20:52:34 -07:00
}
2019-04-11 05:13:31 -07:00
inline void parse_query_text(const std::string &s, Params &params) {
split(&s[0], &s[s.size()], '&', [&](const char *b, const char *e) {
std::string key;
std::string val;
split(b, e, '=', [&](const char *b, const char *e) {
if (key.empty()) {
key.assign(b, e);
} else {
val.assign(b, e);
}
2012-10-03 20:47:59 -07:00
});
2019-04-11 05:13:31 -07:00
params.emplace(key, decode_url(val));
});
2012-10-03 20:47:59 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool parse_multipart_boundary(const std::string &content_type,
std::string &boundary) {
auto pos = content_type.find("boundary=");
if (pos == std::string::npos) { return false; }
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
boundary = content_type.substr(pos + 9);
return true;
2017-12-05 17:19:07 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool parse_multipart_formdata(const std::string &boundary,
const std::string &body,
MultipartFiles &files) {
static std::string dash = "--";
static std::string crlf = "\r\n";
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
static std::regex re_content_type("Content-Type: (.*?)",
std::regex_constants::icase);
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
static std::regex re_content_disposition(
"Content-Disposition: form-data; name=\"(.*?)\"(?:; filename=\"(.*?)\")?",
std::regex_constants::icase);
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
auto dash_boundary = dash + boundary;
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
auto pos = body.find(dash_boundary);
if (pos != 0) { return false; }
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
pos += dash_boundary.size();
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
auto next_pos = body.find(crlf, pos);
if (next_pos == std::string::npos) { return false; }
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
pos = next_pos + crlf.size();
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
while (pos < body.size()) {
next_pos = body.find(crlf, pos);
if (next_pos == std::string::npos) { return false; }
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
std::string name;
MultipartFile file;
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
auto header = body.substr(pos, (next_pos - pos));
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
while (pos != next_pos) {
std::smatch m;
if (std::regex_match(header, m, re_content_type)) {
file.content_type = m[1];
} else if (std::regex_match(header, m, re_content_disposition)) {
name = m[1];
file.filename = m[2];
}
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
pos = next_pos + crlf.size();
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
next_pos = body.find(crlf, pos);
if (next_pos == std::string::npos) { return false; }
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
header = body.substr(pos, (next_pos - pos));
}
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
pos = next_pos + crlf.size();
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
next_pos = body.find(crlf + dash_boundary, pos);
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
if (next_pos == std::string::npos) { return false; }
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
file.offset = pos;
file.length = next_pos - pos;
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
pos = next_pos + crlf.size() + dash_boundary.size();
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
next_pos = body.find(crlf, pos);
if (next_pos == std::string::npos) { return false; }
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
files.emplace(name, file);
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
pos = next_pos + crlf.size();
}
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
return true;
2017-12-05 17:19:07 -07:00
}
inline bool parse_range_header(const std::string &s, Ranges &ranges) {
try {
static auto re = std::regex(R"(bytes=(\d*-\d*(?:,\s*\d*-\d*)*))");
std::smatch m;
if (std::regex_match(s, m, re)) {
auto pos = m.position(1);
auto len = m.length(1);
detail::split(
&s[pos], &s[pos + len], ',', [&](const char *b, const char *e) {
static auto re = std::regex(R"(\s*(\d*)-(\d*))");
std::cmatch m;
if (std::regex_match(b, e, m, re)) {
uint64_t first = -1;
if (!m.str(1).empty()) { first = std::stoll(m.str(1)); }
uint64_t last = -1;
if (!m.str(2).empty()) { last = std::stoll(m.str(2)); }
if (int64_t(first) != -1 && int64_t(last) != -1 && first > last) {
throw std::runtime_error("invalid range error");
}
ranges.emplace_back(std::make_pair(first, last));
}
});
return true;
}
return false;
} catch (...) { return false; }
}
2019-04-11 05:13:31 -07:00
inline std::string to_lower(const char *beg, const char *end) {
std::string out;
auto it = beg;
while (it != end) {
out += ::tolower(*it);
it++;
}
return out;
2017-12-12 20:20:40 -07:00
}
2019-07-23 06:52:12 -07:00
inline std::string make_multipart_data_boundary() {
static const char data[] =
"0123456789ABCDEFGHIJKLMNOPQRSTUVWXYZabcdefghijklmnopqrstuvwxyz";
std::random_device seed_gen;
std::mt19937 engine(seed_gen());
std::string result = "--cpp-httplib-multipart-data-";
2019-07-23 06:52:12 -07:00
for (auto i = 0; i < 16; i++) {
result += data[engine() % (sizeof(data) - 1)];
}
return result;
}
inline std::pair<uint64_t, uint64_t>
get_range_offset_and_length(const Request &req, uint64_t content_length,
size_t index) {
auto r = req.ranges[index];
if (r.first == -1 && r.second == -1) {
return std::make_pair(0, content_length);
}
if (r.first == -1) {
r.first = content_length - r.second;
r.second = content_length - 1;
}
if (r.second == -1) { r.second = content_length - 1; }
return std::make_pair(r.first, r.second - r.first + 1);
}
inline std::string make_content_range_header_field(uint64_t offset,
uint64_t length,
uint64_t content_length) {
std::string field = "bytes ";
field += std::to_string(offset);
field += "-";
field += std::to_string(offset + length - 1);
field += "/";
field += std::to_string(content_length);
return field;
}
template <typename SToken, typename CToken, typename Content>
bool process_multipart_ranges_data(const Request &req, Response &res,
const std::string &boundary,
const std::string &content_type,
SToken stoken, CToken ctoken,
Content content) {
for (size_t i = 0; i < req.ranges.size(); i++) {
ctoken("--");
stoken(boundary);
ctoken("\r\n");
if (!content_type.empty()) {
ctoken("Content-Type: ");
stoken(content_type);
ctoken("\r\n");
}
auto offsets = detail::get_range_offset_and_length(req, res.body.size(), i);
auto offset = offsets.first;
auto length = offsets.second;
ctoken("Content-Range: ");
stoken(make_content_range_header_field(offset, length, res.body.size()));
ctoken("\r\n");
ctoken("\r\n");
if (!content(offset, length)) { return false; }
ctoken("\r\n");
}
ctoken("--");
stoken(boundary);
ctoken("--\r\n");
return true;
}
inline std::string make_multipart_ranges_data(const Request &req, Response &res,
const std::string &boundary,
const std::string &content_type) {
std::string data;
process_multipart_ranges_data(
req, res, boundary, content_type,
[&](const std::string &token) { data += token; },
[&](const char *token) { data += token; },
[&](uint64_t offset, uint64_t length) {
data += res.body.substr(offset, length);
return true;
});
return data;
}
inline uint64_t
get_multipart_ranges_data_length(const Request &req, Response &res,
const std::string &boundary,
const std::string &content_type) {
uint64_t data_length = 0;
process_multipart_ranges_data(
req, res, boundary, content_type,
[&](const std::string &token) { data_length += token.size(); },
[&](const char *token) { data_length += strlen(token); },
[&](uint64_t /*offset*/, uint64_t length) {
data_length += length;
return true;
});
return data_length;
}
2017-12-12 20:20:40 -07:00
inline bool write_multipart_ranges_data(Stream &strm, const Request &req,
Response &res,
const std::string &boundary,
const std::string &content_type) {
return process_multipart_ranges_data(
req, res, boundary, content_type,
[&](const std::string &token) { strm.write(token); },
[&](const char *token) { strm.write(token); },
[&](uint64_t offset, uint64_t length) {
return detail::write_content(strm, res.content_provider, offset,
length) >= 0;
});
2017-12-12 20:20:40 -07:00
}
2019-08-02 18:47:48 -07:00
inline std::pair<uint64_t, uint64_t>
get_range_offset_and_length(const Request &req, const Response &res,
size_t index) {
auto r = req.ranges[index];
if (r.second == -1) { r.second = res.content_provider_resource_length - 1; }
return std::make_pair(r.first, r.second - r.first + 1);
2017-12-12 20:20:40 -07:00
}
2017-12-06 22:20:59 -07:00
#ifdef _WIN32
class WSInit {
public:
2019-04-11 05:13:31 -07:00
WSInit() {
WSADATA wsaData;
WSAStartup(0x0002, &wsaData);
}
2019-04-11 05:13:31 -07:00
~WSInit() { WSACleanup(); }
};
static WSInit wsinit_;
#endif
2017-12-12 20:20:40 -07:00
} // namespace detail
// Header utilities
inline std::pair<std::string, std::string> make_range_header(Ranges ranges) {
std::string field = "bytes=";
auto i = 0;
for (auto r : ranges) {
if (i != 0) { field += ", "; }
if (r.first != -1) { field += std::to_string(r.first); }
field += '-';
if (r.second != -1) { field += std::to_string(r.second); }
i++;
}
2019-04-11 05:13:31 -07:00
return std::make_pair("Range", field);
2017-12-10 20:34:37 -07:00
}
2019-07-23 06:52:12 -07:00
inline std::pair<std::string, std::string>
make_basic_authentication_header(const std::string &username,
const std::string &password) {
2019-07-19 08:38:06 -07:00
auto field = "Basic " + detail::base64_encode(username + ":" + password);
return std::make_pair("Authorization", field);
}
// Request implementation
2019-04-11 05:13:31 -07:00
inline bool Request::has_header(const char *key) const {
return detail::has_header(headers, key);
2012-10-03 17:11:22 -07:00
}
2012-09-25 20:21:57 -07:00
2019-04-11 05:13:31 -07:00
inline std::string Request::get_header_value(const char *key, size_t id) const {
return detail::get_header_value(headers, key, id, "");
2018-12-17 19:07:38 -07:00
}
2019-04-11 05:13:31 -07:00
inline size_t Request::get_header_value_count(const char *key) const {
auto r = headers.equal_range(key);
return std::distance(r.first, r.second);
2012-10-03 17:11:22 -07:00
}
2012-09-25 20:21:57 -07:00
2019-04-11 05:13:31 -07:00
inline void Request::set_header(const char *key, const char *val) {
headers.emplace(key, val);
}
inline void Request::set_header(const char *key, const std::string &val) {
headers.emplace(key, val);
}
2019-04-11 05:13:31 -07:00
inline bool Request::has_param(const char *key) const {
return params.find(key) != params.end();
2012-10-03 20:47:59 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::string Request::get_param_value(const char *key, size_t id) const {
auto it = params.find(key);
std::advance(it, id);
if (it != params.end()) { return it->second; }
return std::string();
}
2019-04-11 05:13:31 -07:00
inline size_t Request::get_param_value_count(const char *key) const {
auto r = params.equal_range(key);
return std::distance(r.first, r.second);
2018-12-17 19:07:38 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool Request::has_file(const char *key) const {
return files.find(key) != files.end();
2017-12-05 17:19:07 -07:00
}
2019-04-11 05:13:31 -07:00
inline MultipartFile Request::get_file_value(const char *key) const {
auto it = files.find(key);
if (it != files.end()) { return it->second; }
return MultipartFile();
2017-12-05 17:19:07 -07:00
}
// Response implementation
2019-04-11 05:13:31 -07:00
inline bool Response::has_header(const char *key) const {
return headers.find(key) != headers.end();
2012-10-03 17:11:22 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::string Response::get_header_value(const char *key,
size_t id) const {
return detail::get_header_value(headers, key, id, "");
2018-12-17 19:07:38 -07:00
}
2019-04-11 05:13:31 -07:00
inline size_t Response::get_header_value_count(const char *key) const {
auto r = headers.equal_range(key);
return std::distance(r.first, r.second);
2012-10-03 17:11:22 -07:00
}
2019-04-11 05:13:31 -07:00
inline void Response::set_header(const char *key, const char *val) {
headers.emplace(key, val);
2012-09-25 20:21:57 -07:00
}
inline void Response::set_header(const char *key, const std::string &val) {
headers.emplace(key, val);
}
2019-04-11 05:13:31 -07:00
inline void Response::set_redirect(const char *url) {
set_header("Location", url);
status = 302;
2012-09-25 19:09:56 -07:00
}
2019-04-11 05:13:31 -07:00
inline void Response::set_content(const char *s, size_t n,
const char *content_type) {
body.assign(s, n);
set_header("Content-Type", content_type);
}
2019-04-11 05:13:31 -07:00
inline void Response::set_content(const std::string &s,
const char *content_type) {
body = s;
set_header("Content-Type", content_type);
2012-09-25 19:09:56 -07:00
}
inline void Response::set_content_provider(
uint64_t length,
std::function<void(uint64_t offset, uint64_t length, Out out)> provider,
std::function<void()> resource_releaser) {
assert(length > 0);
content_provider_resource_length = length;
content_provider = [provider](uint64_t offset, uint64_t length, Out out,
Done) { provider(offset, length, out); };
content_provider_resource_releaser = resource_releaser;
}
inline void Response::set_chunked_content_provider(
std::function<void(uint64_t offset, Out out, Done done)> provider,
std::function<void()> resource_releaser) {
content_provider_resource_length = 0;
content_provider = [provider](uint64_t offset, uint64_t, Out out, Done done) {
provider(offset, out, done);
};
content_provider_resource_releaser = resource_releaser;
}
2017-12-10 13:11:03 -07:00
// Rstream implementation
2019-04-11 05:13:31 -07:00
template <typename... Args>
2019-07-21 18:34:49 -07:00
inline int Stream::write_format(const char *fmt, const Args &... args) {
2019-04-11 05:13:31 -07:00
const auto bufsiz = 2048;
char buf[bufsiz];
2017-12-10 13:11:03 -07:00
#if defined(_MSC_VER) && _MSC_VER < 1900
2019-04-11 05:13:31 -07:00
auto n = _snprintf_s(buf, bufsiz, bufsiz - 1, fmt, args...);
#else
2019-04-11 05:13:31 -07:00
auto n = snprintf(buf, bufsiz - 1, fmt, args...);
#endif
2019-07-23 06:52:12 -07:00
if (n <= 0) { return n; }
2017-12-10 13:11:03 -07:00
2019-07-21 18:34:49 -07:00
if (n >= bufsiz - 1) {
std::vector<char> glowable_buf(bufsiz);
while (n >= static_cast<int>(glowable_buf.size() - 1)) {
glowable_buf.resize(glowable_buf.size() * 2);
2017-12-10 13:11:03 -07:00
#if defined(_MSC_VER) && _MSC_VER < 1900
2019-07-21 18:34:49 -07:00
n = _snprintf_s(&glowable_buf[0], glowable_buf.size(),
glowable_buf.size() - 1, fmt, args...);
2017-12-10 13:11:03 -07:00
#else
2019-07-21 18:34:49 -07:00
n = snprintf(&glowable_buf[0], glowable_buf.size() - 1, fmt, args...);
2017-12-10 13:11:03 -07:00
#endif
}
2019-07-21 18:34:49 -07:00
return write(&glowable_buf[0], n);
} else {
return write(buf, n);
2019-04-11 05:13:31 -07:00
}
2017-12-10 13:11:03 -07:00
}
2017-04-21 20:00:00 -07:00
// Socket stream implementation
2019-04-11 05:13:31 -07:00
inline SocketStream::SocketStream(socket_t sock) : sock_(sock) {}
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
inline SocketStream::~SocketStream() {}
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
inline int SocketStream::read(char *ptr, size_t size) {
2019-06-04 19:53:37 -07:00
if (detail::select_read(sock_, CPPHTTPLIB_READ_TIMEOUT_SECOND,
CPPHTTPLIB_READ_TIMEOUT_USECOND) > 0) {
return recv(sock_, ptr, static_cast<int>(size), 0);
}
return -1;
2017-04-21 20:00:00 -07:00
}
2019-04-11 05:13:31 -07:00
inline int SocketStream::write(const char *ptr, size_t size) {
return send(sock_, ptr, static_cast<int>(size), 0);
2017-04-21 20:00:00 -07:00
}
2019-04-11 05:13:31 -07:00
inline int SocketStream::write(const char *ptr) {
return write(ptr, strlen(ptr));
2017-04-21 20:00:00 -07:00
}
inline int SocketStream::write(const std::string &s) {
return write(s.data(), s.size());
}
2018-10-28 00:15:22 -07:00
inline std::string SocketStream::get_remote_addr() const {
2019-04-11 05:13:31 -07:00
return detail::get_remote_addr(sock_);
}
2018-10-28 00:15:22 -07:00
// Buffer stream implementation
2019-04-11 05:13:31 -07:00
inline int BufferStream::read(char *ptr, size_t size) {
2019-01-15 06:08:34 -07:00
#if defined(_MSC_VER) && _MSC_VER < 1900
2019-04-11 05:13:31 -07:00
return static_cast<int>(buffer._Copy_s(ptr, size, size));
2018-10-28 00:15:22 -07:00
#else
2019-04-11 05:13:31 -07:00
return static_cast<int>(buffer.copy(ptr, size));
2018-10-28 00:15:22 -07:00
#endif
}
2019-04-11 05:13:31 -07:00
inline int BufferStream::write(const char *ptr, size_t size) {
buffer.append(ptr, size);
return static_cast<int>(size);
2018-10-28 00:15:22 -07:00
}
2019-04-11 05:13:31 -07:00
inline int BufferStream::write(const char *ptr) {
return write(ptr, strlen(ptr));
}
inline int BufferStream::write(const std::string &s) {
return write(s.data(), s.size());
2018-10-28 00:15:22 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::string BufferStream::get_remote_addr() const { return ""; }
2018-10-28 00:15:22 -07:00
2019-04-11 05:13:31 -07:00
inline const std::string &BufferStream::get_buffer() const { return buffer; }
2018-10-28 00:15:22 -07:00
// HTTP server implementation
inline Server::Server()
2019-04-12 20:34:27 -07:00
: keep_alive_max_count_(CPPHTTPLIB_KEEPALIVE_MAX_COUNT),
payload_max_length_(CPPHTTPLIB_PAYLOAD_MAX_LENGTH), is_running_(false),
2019-08-02 19:27:44 -07:00
svr_sock_(INVALID_SOCKET) {
2017-12-06 22:20:59 -07:00
#ifndef _WIN32
2019-04-11 05:13:31 -07:00
signal(SIGPIPE, SIG_IGN);
2017-07-06 19:04:59 -07:00
#endif
2019-08-03 00:18:15 -07:00
new_task_queue = [] {
#if CPPHTTPLIB_THREAD_POOL_COUNT > 0
return new ThreadPool(CPPHTTPLIB_THREAD_POOL_COUNT);
#else
return new Threads();
#endif
};
2012-09-22 21:40:46 -07:00
}
2019-04-11 05:13:31 -07:00
inline Server::~Server() {}
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
inline Server &Server::Get(const char *pattern, Handler handler) {
get_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
return *this;
2012-09-22 21:40:46 -07:00
}
2019-04-11 05:13:31 -07:00
inline Server &Server::Post(const char *pattern, Handler handler) {
post_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
return *this;
2012-09-22 21:40:46 -07:00
}
2019-04-11 05:13:31 -07:00
inline Server &Server::Put(const char *pattern, Handler handler) {
put_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
return *this;
2018-05-06 18:16:35 -07:00
}
2019-04-11 05:13:31 -07:00
inline Server &Server::Patch(const char *pattern, Handler handler) {
patch_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
return *this;
2019-03-12 05:49:08 -07:00
}
2019-04-11 05:13:31 -07:00
inline Server &Server::Delete(const char *pattern, Handler handler) {
delete_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
return *this;
2018-05-06 18:16:35 -07:00
}
2019-04-11 05:13:31 -07:00
inline Server &Server::Options(const char *pattern, Handler handler) {
options_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
return *this;
2018-05-06 18:16:35 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool Server::set_base_dir(const char *path) {
if (detail::is_dir(path)) {
base_dir_ = path;
return true;
}
return false;
2013-07-04 15:18:52 -07:00
}
2019-08-25 14:19:20 -07:00
inline void Server::set_file_request_handler(Handler handler) {
file_request_handler_ = handler;
}
2019-04-11 05:13:31 -07:00
inline void Server::set_error_handler(Handler handler) {
error_handler_ = handler;
2012-09-27 17:54:54 -07:00
}
2019-04-11 05:13:31 -07:00
inline void Server::set_logger(Logger logger) { logger_ = logger; }
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
inline void Server::set_keep_alive_max_count(size_t count) {
keep_alive_max_count_ = count;
}
2019-04-12 20:34:27 -07:00
inline void Server::set_payload_max_length(uint64_t length) {
payload_max_length_ = length;
}
2019-04-11 05:13:31 -07:00
inline int Server::bind_to_any_port(const char *host, int socket_flags) {
return bind_internal(host, 0, socket_flags);
}
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
inline bool Server::listen_after_bind() { return listen_internal(); }
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
inline bool Server::listen(const char *host, int port, int socket_flags) {
if (bind_internal(host, port, socket_flags) < 0) return false;
return listen_internal();
2012-09-22 21:40:46 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool Server::is_running() const { return is_running_; }
2019-04-11 05:13:31 -07:00
inline void Server::stop() {
if (is_running_) {
assert(svr_sock_ != INVALID_SOCKET);
2019-07-17 05:56:49 -07:00
std::atomic<socket_t> sock(svr_sock_.exchange(INVALID_SOCKET));
2019-04-11 05:13:31 -07:00
detail::shutdown_socket(sock);
detail::close_socket(sock);
}
2018-04-16 21:05:05 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool Server::parse_request_line(const char *s, Request &req) {
static std::regex re("(GET|HEAD|POST|PUT|PATCH|DELETE|OPTIONS) "
"(([^?]+)(?:\\?(.+?))?) (HTTP/1\\.[01])\r\n");
2012-09-24 04:57:09 -07:00
2019-04-11 05:13:31 -07:00
std::cmatch m;
if (std::regex_match(s, m, re)) {
req.version = std::string(m[5]);
req.method = std::string(m[1]);
req.target = std::string(m[2]);
req.path = detail::decode_url(m[3]);
2012-09-24 20:13:01 -07:00
2019-04-11 05:13:31 -07:00
// Parse query text
auto len = std::distance(m[4].first, m[4].second);
if (len > 0) { detail::parse_query_text(m[4], req.params); }
2012-09-24 04:57:09 -07:00
2019-04-11 05:13:31 -07:00
return true;
}
return false;
2012-09-22 21:40:46 -07:00
}
2019-07-21 18:34:49 -07:00
inline bool Server::write_response(Stream &strm, bool last_connection,
2019-04-11 05:13:31 -07:00
const Request &req, Response &res) {
assert(res.status != -1);
2017-12-02 08:24:41 -07:00
2019-04-11 05:13:31 -07:00
if (400 <= res.status && error_handler_) { error_handler_(req, res); }
2017-12-02 08:24:41 -07:00
2019-04-11 05:13:31 -07:00
// Response line
2019-07-21 18:34:49 -07:00
if (!strm.write_format("HTTP/1.1 %d %s\r\n", res.status,
2019-07-23 06:52:12 -07:00
detail::status_message(res.status))) {
2019-07-21 18:34:49 -07:00
return false;
}
2019-04-11 05:13:31 -07:00
// Headers
if (last_connection || req.get_header_value("Connection") == "close") {
res.set_header("Connection", "close");
}
2018-09-23 09:02:17 -07:00
2019-04-11 05:13:31 -07:00
if (!last_connection && req.get_header_value("Connection") == "Keep-Alive") {
res.set_header("Connection", "Keep-Alive");
}
if (!res.has_header("Content-Type")) {
res.set_header("Content-Type", "text/plain");
}
if (!res.has_header("Accept-Ranges")) {
res.set_header("Accept-Ranges", "bytes");
}
std::string content_type;
std::string boundary;
if (req.ranges.size() > 1) {
boundary = detail::make_multipart_data_boundary();
auto it = res.headers.find("Content-Type");
if (it != res.headers.end()) {
content_type = it->second;
res.headers.erase(it);
}
res.headers.emplace("Content-Type",
"multipart/byteranges; boundary=" + boundary);
}
2019-04-11 05:13:31 -07:00
if (res.body.empty()) {
if (res.content_provider_resource_length > 0) {
uint64_t length = 0;
if (req.ranges.empty()) {
length = res.content_provider_resource_length;
} else if (req.ranges.size() == 1) {
2019-08-06 02:12:05 -07:00
auto offsets = detail::get_range_offset_and_length(
req, res.content_provider_resource_length, 0);
auto offset = offsets.first;
length = offsets.second;
auto content_range = detail::make_content_range_header_field(
offset, length, res.content_provider_resource_length);
res.set_header("Content-Range", content_range);
} else {
length = detail::get_multipart_ranges_data_length(req, res, boundary,
content_type);
}
res.set_header("Content-Length", std::to_string(length));
} else {
if (res.content_provider) {
2019-04-11 05:13:31 -07:00
res.set_header("Transfer-Encoding", "chunked");
} else {
res.set_header("Content-Length", "0");
}
}
} else {
if (req.ranges.empty()) {
;
} else if (req.ranges.size() == 1) {
auto offsets =
detail::get_range_offset_and_length(req, res.body.size(), 0);
auto offset = offsets.first;
auto length = offsets.second;
auto content_range = detail::make_content_range_header_field(
offset, length, res.body.size());
res.set_header("Content-Range", content_range);
res.body = res.body.substr(offset, length);
} else {
res.body =
detail::make_multipart_ranges_data(req, res, boundary, content_type);
}
2017-12-28 18:47:52 -07:00
#ifdef CPPHTTPLIB_ZLIB_SUPPORT
2019-04-11 05:13:31 -07:00
// TODO: 'Accpet-Encoding' has gzip, not gzip;q=0
const auto &encodings = req.get_header_value("Accept-Encoding");
if (encodings.find("gzip") != std::string::npos &&
detail::can_compress(res.get_header_value("Content-Type"))) {
if (detail::compress(res.body)) {
res.set_header("Content-Encoding", "gzip");
}
2019-04-11 05:13:31 -07:00
}
2017-12-28 18:47:52 -07:00
#endif
2019-04-11 05:13:31 -07:00
auto length = std::to_string(res.body.size());
res.set_header("Content-Length", length);
2019-04-11 05:13:31 -07:00
}
2019-07-23 06:52:12 -07:00
if (!detail::write_headers(strm, res)) { return false; }
2017-12-02 08:24:41 -07:00
2019-04-11 05:13:31 -07:00
// Body
if (req.method != "HEAD") {
if (!res.body.empty()) {
if (!strm.write(res.body)) { return false; }
} else if (res.content_provider) {
if (!write_content_with_provider(strm, req, res, boundary,
content_type)) {
return false;
}
2017-12-02 08:24:41 -07:00
}
2019-04-11 05:13:31 -07:00
}
// Log
if (logger_) { logger_(req, res); }
2019-07-21 18:34:49 -07:00
return true;
2017-12-02 08:24:41 -07:00
}
inline bool
Server::write_content_with_provider(Stream &strm, const Request &req,
Response &res, const std::string &boundary,
const std::string &content_type) {
if (res.content_provider_resource_length) {
if (req.ranges.empty()) {
if (detail::write_content(strm, res.content_provider, 0,
res.content_provider_resource_length) < 0) {
return false;
}
} else if (req.ranges.size() == 1) {
2019-08-06 02:12:05 -07:00
auto offsets = detail::get_range_offset_and_length(
req, res.content_provider_resource_length, 0);
auto offset = offsets.first;
auto length = offsets.second;
if (detail::write_content(strm, res.content_provider, offset, length) <
0) {
return false;
}
} else {
if (!detail::write_multipart_ranges_data(strm, req, res, boundary,
content_type)) {
return false;
}
}
} else {
if (detail::write_content_chunked(strm, res.content_provider) < 0) {
return false;
}
}
return true;
}
2019-04-11 05:13:31 -07:00
inline bool Server::handle_file_request(Request &req, Response &res) {
if (!base_dir_.empty() && detail::is_valid_path(req.path)) {
std::string path = base_dir_ + req.path;
2013-07-04 15:18:52 -07:00
2019-04-11 05:13:31 -07:00
if (!path.empty() && path.back() == '/') { path += "index.html"; }
2013-07-04 15:18:52 -07:00
2019-04-11 05:13:31 -07:00
if (detail::is_file(path)) {
detail::read_file(path, res.body);
auto type = detail::find_content_type(path);
if (type) { res.set_header("Content-Type", type); }
res.status = 200;
2019-08-25 14:19:20 -07:00
if (file_request_handler_) {
file_request_handler_(req, res);
}
2019-04-11 05:13:31 -07:00
return true;
2013-07-04 19:08:06 -07:00
}
2019-04-11 05:13:31 -07:00
}
2013-07-04 15:18:52 -07:00
2019-04-11 05:13:31 -07:00
return false;
2013-07-04 15:18:52 -07:00
}
2019-04-11 05:13:31 -07:00
inline socket_t Server::create_server_socket(const char *host, int port,
int socket_flags) const {
return detail::create_socket(
host, port,
[](socket_t sock, struct addrinfo &ai) -> bool {
if (::bind(sock, ai.ai_addr, static_cast<int>(ai.ai_addrlen))) {
return false;
}
2019-04-11 05:13:31 -07:00
if (::listen(sock, 5)) { // Listen through 5 channels
return false;
}
2019-04-11 05:13:31 -07:00
return true;
},
socket_flags);
}
2019-04-11 05:13:31 -07:00
inline int Server::bind_internal(const char *host, int port, int socket_flags) {
if (!is_valid()) { return -1; }
2019-04-11 05:13:31 -07:00
svr_sock_ = create_server_socket(host, port, socket_flags);
if (svr_sock_ == INVALID_SOCKET) { return -1; }
2018-04-17 10:09:39 -07:00
2019-04-11 05:13:31 -07:00
if (port == 0) {
struct sockaddr_storage address;
socklen_t len = sizeof(address);
if (getsockname(svr_sock_, reinterpret_cast<struct sockaddr *>(&address),
&len) == -1) {
return -1;
}
if (address.ss_family == AF_INET) {
return ntohs(reinterpret_cast<struct sockaddr_in *>(&address)->sin_port);
} else if (address.ss_family == AF_INET6) {
return ntohs(
reinterpret_cast<struct sockaddr_in6 *>(&address)->sin6_port);
} else {
return -1;
}
} else {
return port;
}
}
2019-04-11 05:13:31 -07:00
inline bool Server::listen_internal() {
auto ret = true;
is_running_ = true;
2019-08-02 21:15:05 -07:00
{
2019-08-03 00:18:15 -07:00
std::unique_ptr<TaskQueue> task_queue(new_task_queue());
2019-06-20 11:59:00 -07:00
2019-08-02 21:15:05 -07:00
for (;;) {
if (svr_sock_ == INVALID_SOCKET) {
// The server socket was closed by 'stop' method.
break;
}
auto val = detail::select_read(svr_sock_, 0, 100000);
2019-08-02 21:15:05 -07:00
if (val == 0) { // Timeout
continue;
}
2018-04-16 19:12:45 -07:00
2019-08-02 21:15:05 -07:00
socket_t sock = accept(svr_sock_, nullptr, nullptr);
2018-04-16 19:12:45 -07:00
2019-08-02 21:15:05 -07:00
if (sock == INVALID_SOCKET) {
if (svr_sock_ != INVALID_SOCKET) {
detail::close_socket(svr_sock_);
ret = false;
} else {
; // The server socket was closed by user.
}
break;
2019-04-11 05:13:31 -07:00
}
2019-08-02 21:15:05 -07:00
2019-08-03 00:18:15 -07:00
task_queue->enqueue([=]() { read_and_close_socket(sock); });
}
2019-08-02 21:15:05 -07:00
task_queue->shutdown();
2019-04-11 05:13:31 -07:00
}
is_running_ = false;
return ret;
}
2019-04-11 05:13:31 -07:00
inline bool Server::routing(Request &req, Response &res) {
if (req.method == "GET" && handle_file_request(req, res)) { return true; }
2013-07-04 15:18:52 -07:00
2019-04-11 05:13:31 -07:00
if (req.method == "GET" || req.method == "HEAD") {
return dispatch_request(req, res, get_handlers_);
} else if (req.method == "POST") {
return dispatch_request(req, res, post_handlers_);
} else if (req.method == "PUT") {
return dispatch_request(req, res, put_handlers_);
} else if (req.method == "PATCH") {
return dispatch_request(req, res, patch_handlers_);
} else if (req.method == "DELETE") {
return dispatch_request(req, res, delete_handlers_);
} else if (req.method == "OPTIONS") {
return dispatch_request(req, res, options_handlers_);
}
return false;
2012-10-03 21:38:32 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool Server::dispatch_request(Request &req, Response &res,
Handlers &handlers) {
for (const auto &x : handlers) {
const auto &pattern = x.first;
const auto &handler = x.second;
2012-10-03 18:55:01 -07:00
2019-04-11 05:13:31 -07:00
if (std::regex_match(req.path, req.matches, pattern)) {
handler(req, res);
return true;
2012-10-03 18:55:01 -07:00
}
2019-04-11 05:13:31 -07:00
}
return false;
2012-10-03 18:55:01 -07:00
}
2019-06-20 15:52:28 -07:00
inline bool
Server::process_request(Stream &strm, bool last_connection,
bool &connection_close,
std::function<void(Request &)> setup_request) {
2019-04-11 05:13:31 -07:00
const auto bufsiz = 2048;
char buf[bufsiz];
2019-04-11 05:13:31 -07:00
detail::stream_line_reader reader(strm, buf, bufsiz);
2019-04-11 05:13:31 -07:00
// Connection has been closed on client
if (!reader.getline()) { return false; }
2019-04-11 05:13:31 -07:00
Request req;
Response res;
2012-09-24 20:13:01 -07:00
2019-04-11 05:13:31 -07:00
res.version = "HTTP/1.1";
2019-04-11 05:13:31 -07:00
// Check if the request URI doesn't exceed the limit
if (reader.size() > CPPHTTPLIB_REQUEST_URI_MAX_LENGTH) {
2019-08-06 23:21:22 -07:00
Headers dummy;
detail::read_headers(strm, dummy);
2019-04-11 05:13:31 -07:00
res.status = 414;
2019-07-21 18:34:49 -07:00
return write_response(strm, last_connection, req, res);
2019-04-11 05:13:31 -07:00
}
2019-04-10 09:21:42 -07:00
2019-04-11 05:13:31 -07:00
// Request line and headers
if (!parse_request_line(reader.ptr(), req) ||
!detail::read_headers(strm, req.headers)) {
res.status = 400;
2019-07-21 18:34:49 -07:00
return write_response(strm, last_connection, req, res);
2019-04-11 05:13:31 -07:00
}
2019-04-11 05:13:31 -07:00
if (req.get_header_value("Connection") == "close") {
connection_close = true;
}
2012-09-24 20:13:01 -07:00
if (req.version == "HTTP/1.0" &&
req.get_header_value("Connection") != "Keep-Alive") {
connection_close = true;
}
req.set_header("REMOTE_ADDR", strm.get_remote_addr());
2019-04-11 05:13:31 -07:00
// Body
if (req.method == "POST" || req.method == "PUT" || req.method == "PATCH") {
if (!detail::read_content(strm, req, payload_max_length_, res.status,
Progress(), [&](const char *buf, size_t n) {
req.body.append(buf, n);
return true;
})) {
2019-07-21 18:34:49 -07:00
return write_response(strm, last_connection, req, res);
2019-04-11 05:13:31 -07:00
}
2017-12-02 08:24:41 -07:00
2019-04-11 05:13:31 -07:00
const auto &content_type = req.get_header_value("Content-Type");
2017-12-05 17:19:07 -07:00
2019-04-11 05:13:31 -07:00
if (!content_type.find("application/x-www-form-urlencoded")) {
detail::parse_query_text(req.body, req.params);
} else if (!content_type.find("multipart/form-data")) {
std::string boundary;
if (!detail::parse_multipart_boundary(content_type, boundary) ||
!detail::parse_multipart_formdata(boundary, req.body, req.files)) {
res.status = 400;
2019-07-21 18:34:49 -07:00
return write_response(strm, last_connection, req, res);
2019-04-11 05:13:31 -07:00
}
2012-10-02 19:37:14 -07:00
}
2019-04-11 05:13:31 -07:00
}
2012-10-02 19:37:14 -07:00
if (req.has_header("Range")) {
const auto &range_header_value = req.get_header_value("Range");
if (!detail::parse_range_header(range_header_value, req.ranges)) {
// TODO: error
}
}
2019-06-20 15:52:28 -07:00
if (setup_request) { setup_request(req); }
2019-04-11 05:13:31 -07:00
if (routing(req, res)) {
if (res.status == -1) { res.status = req.ranges.empty() ? 200 : 206; }
2019-04-11 05:13:31 -07:00
} else {
res.status = 404;
}
2012-09-22 21:40:46 -07:00
2019-07-21 18:34:49 -07:00
return write_response(strm, last_connection, req, res);
}
2019-04-11 05:13:31 -07:00
inline bool Server::is_valid() const { return true; }
inline bool Server::read_and_close_socket(socket_t sock) {
return detail::read_and_close_socket(
sock, keep_alive_max_count_,
[this](Stream &strm, bool last_connection, bool &connection_close) {
return process_request(strm, last_connection, connection_close,
nullptr);
2019-04-11 05:13:31 -07:00
});
2017-04-21 20:00:00 -07:00
}
2012-10-02 17:39:13 -07:00
// HTTP client implementation
2019-04-11 05:13:31 -07:00
inline Client::Client(const char *host, int port, time_t timeout_sec)
: host_(host), port_(port), timeout_sec_(timeout_sec),
host_and_port_(host_ + ":" + std::to_string(port_)) {}
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
inline Client::~Client() {}
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
inline bool Client::is_valid() const { return true; }
2019-04-11 05:13:31 -07:00
inline socket_t Client::create_client_socket() const {
return detail::create_socket(
host_.c_str(), port_, [=](socket_t sock, struct addrinfo &ai) -> bool {
detail::set_nonblocking(sock, true);
2019-04-11 05:13:31 -07:00
auto ret = connect(sock, ai.ai_addr, static_cast<int>(ai.ai_addrlen));
if (ret < 0) {
if (detail::is_connection_error() ||
!detail::wait_until_socket_is_ready(sock, timeout_sec_, 0)) {
detail::close_socket(sock);
return false;
}
}
2019-04-11 05:13:31 -07:00
detail::set_nonblocking(sock, false);
return true;
});
}
2019-04-11 05:13:31 -07:00
inline bool Client::read_response_line(Stream &strm, Response &res) {
const auto bufsiz = 2048;
char buf[bufsiz];
2017-12-06 21:52:34 -07:00
2019-04-11 05:13:31 -07:00
detail::stream_line_reader reader(strm, buf, bufsiz);
2017-12-06 21:52:34 -07:00
2019-04-11 05:13:31 -07:00
if (!reader.getline()) { return false; }
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
const static std::regex re("(HTTP/1\\.[01]) (\\d+?) .*\r\n");
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
std::cmatch m;
if (std::regex_match(reader.ptr(), m, re)) {
res.version = std::string(m[1]);
res.status = std::stoi(std::string(m[2]));
}
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
return true;
2012-10-02 17:39:13 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool Client::send(Request &req, Response &res) {
if (req.path.empty()) { return false; }
2017-12-06 22:05:43 -07:00
2019-04-11 05:13:31 -07:00
auto sock = create_client_socket();
if (sock == INVALID_SOCKET) { return false; }
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
return read_and_close_socket(sock, req, res);
}
2017-12-10 13:11:03 -07:00
2019-04-11 05:13:31 -07:00
inline void Client::write_request(Stream &strm, Request &req) {
BufferStream bstrm;
2017-12-10 13:11:03 -07:00
2019-04-11 05:13:31 -07:00
// Request line
auto path = detail::encode_url(req.path);
2017-12-10 13:11:03 -07:00
2019-04-11 05:13:31 -07:00
bstrm.write_format("%s %s HTTP/1.1\r\n", req.method.c_str(), path.c_str());
2017-12-10 13:11:03 -07:00
2019-04-11 05:13:31 -07:00
// Headers
if (!req.has_header("Host")) {
if (is_ssl()) {
if (port_ == 443) {
req.set_header("Host", host_);
2019-04-11 05:13:31 -07:00
} else {
req.set_header("Host", host_and_port_);
2019-04-11 05:13:31 -07:00
}
2018-09-23 09:02:17 -07:00
} else {
2019-04-11 05:13:31 -07:00
if (port_ == 80) {
req.set_header("Host", host_);
2019-04-11 05:13:31 -07:00
} else {
req.set_header("Host", host_and_port_);
2019-04-11 05:13:31 -07:00
}
}
2019-04-11 05:13:31 -07:00
}
if (!req.has_header("Accept")) { req.set_header("Accept", "*/*"); }
2019-04-11 05:13:31 -07:00
if (!req.has_header("User-Agent")) {
req.set_header("User-Agent", "cpp-httplib/0.2");
}
2017-12-10 13:11:03 -07:00
2019-04-11 05:13:31 -07:00
// TODO: Support KeepAlive connection
// if (!req.has_header("Connection")) {
req.set_header("Connection", "close");
// }
if (req.body.empty()) {
if (req.method == "POST" || req.method == "PUT" || req.method == "PATCH") {
req.set_header("Content-Length", "0");
}
} else {
if (!req.has_header("Content-Type")) {
req.set_header("Content-Type", "text/plain");
2017-12-10 13:11:03 -07:00
}
2018-10-28 00:15:22 -07:00
2019-04-11 05:13:31 -07:00
if (!req.has_header("Content-Length")) {
auto length = std::to_string(req.body.size());
req.set_header("Content-Length", length);
2019-04-11 05:13:31 -07:00
}
}
detail::write_headers(bstrm, req);
// Body
if (!req.body.empty()) { bstrm.write(req.body); }
2019-04-11 05:13:31 -07:00
// Flush buffer
auto &data = bstrm.get_buffer();
strm.write(data.data(), data.size());
2017-12-10 13:11:03 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool Client::process_request(Stream &strm, Request &req, Response &res,
bool &connection_close) {
// Send request
write_request(strm, req);
2015-07-15 13:41:11 -07:00
2019-04-11 05:13:31 -07:00
// Receive response and headers
if (!read_response_line(strm, res) ||
!detail::read_headers(strm, res.headers)) {
return false;
}
2017-12-02 08:24:41 -07:00
2019-04-11 05:13:31 -07:00
if (res.get_header_value("Connection") == "close" ||
res.version == "HTTP/1.0") {
connection_close = true;
}
2019-04-11 05:13:31 -07:00
// Body
if (req.method != "HEAD") {
detail::ContentReceiverCore out = [&](const char *buf, size_t n) {
2019-07-17 18:33:47 -07:00
res.body.append(buf, n);
return true;
2019-07-17 18:33:47 -07:00
};
if (res.content_receiver) {
auto offset = std::make_shared<uint64_t>();
auto length = get_header_value_uint64(res.headers, "Content-Length", 0);
auto receiver = res.content_receiver;
out = [offset, length, receiver](const char *buf, size_t n) {
auto ret = receiver(buf, n, *offset, length);
(*offset) += n;
return ret;
};
2019-07-17 18:33:47 -07:00
}
2019-07-17 05:56:49 -07:00
int dummy_status;
2019-04-12 20:34:27 -07:00
if (!detail::read_content(strm, res, std::numeric_limits<uint64_t>::max(),
2019-07-17 18:33:47 -07:00
dummy_status, res.progress, out)) {
2019-04-12 20:34:27 -07:00
return false;
}
2019-04-11 05:13:31 -07:00
}
2012-10-02 17:39:13 -07:00
2019-04-11 05:13:31 -07:00
return true;
2017-04-21 20:00:00 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool Client::read_and_close_socket(socket_t sock, Request &req,
Response &res) {
return detail::read_and_close_socket(
sock, 0,
[&](Stream &strm, bool /*last_connection*/, bool &connection_close) {
return process_request(strm, req, res, connection_close);
});
2012-10-02 17:39:13 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool Client::is_ssl() const { return false; }
2018-12-13 17:37:44 -07:00
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Get(const char *path,
Progress progress) {
return Get(path, Headers(), progress);
2017-12-12 20:20:40 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response>
Client::Get(const char *path, const Headers &headers, Progress progress) {
Request req;
req.method = "GET";
req.path = path;
req.headers = headers;
2019-04-11 05:13:31 -07:00
auto res = std::make_shared<Response>();
2019-07-17 18:33:47 -07:00
res->progress = progress;
return send(req, *res) ? res : nullptr;
}
inline std::shared_ptr<Response> Client::Get(const char *path,
ContentReceiver content_receiver,
Progress progress) {
return Get(path, Headers(), content_receiver, progress);
}
inline std::shared_ptr<Response> Client::Get(const char *path,
const Headers &headers,
ContentReceiver content_receiver,
Progress progress) {
Request req;
req.method = "GET";
req.path = path;
req.headers = headers;
auto res = std::make_shared<Response>();
res->content_receiver = content_receiver;
res->progress = progress;
2019-04-11 05:13:31 -07:00
return send(req, *res) ? res : nullptr;
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Head(const char *path) {
return Head(path, Headers());
2017-12-12 20:20:40 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Head(const char *path,
const Headers &headers) {
Request req;
req.method = "HEAD";
req.headers = headers;
req.path = path;
2012-10-12 14:41:58 -07:00
2019-04-11 05:13:31 -07:00
auto res = std::make_shared<Response>();
2012-10-12 14:41:58 -07:00
2019-04-11 05:13:31 -07:00
return send(req, *res) ? res : nullptr;
2012-10-12 14:41:58 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Post(const char *path,
const std::string &body,
const char *content_type) {
return Post(path, Headers(), body, content_type);
2017-12-12 20:20:40 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Post(const char *path,
const Headers &headers,
const std::string &body,
const char *content_type) {
Request req;
req.method = "POST";
req.headers = headers;
req.path = path;
2017-06-28 17:12:11 -07:00
2019-04-11 05:13:31 -07:00
req.headers.emplace("Content-Type", content_type);
req.body = body;
2019-04-11 05:13:31 -07:00
auto res = std::make_shared<Response>();
2019-04-11 05:13:31 -07:00
return send(req, *res) ? res : nullptr;
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Post(const char *path,
const Params &params) {
return Post(path, Headers(), params);
2017-12-12 20:20:40 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response>
Client::Post(const char *path, const Headers &headers, const Params &params) {
std::string query;
for (auto it = params.begin(); it != params.end(); ++it) {
if (it != params.begin()) { query += "&"; }
query += it->first;
query += "=";
query += detail::encode_url(it->second);
2019-04-11 05:13:31 -07:00
}
2012-10-11 20:52:34 -07:00
2019-04-11 05:13:31 -07:00
return Post(path, headers, query, "application/x-www-form-urlencoded");
2018-05-06 18:16:35 -07:00
}
2019-07-23 06:52:12 -07:00
inline std::shared_ptr<Response>
Client::Post(const char *path, const MultipartFormDataItems &items) {
return Post(path, Headers(), items);
}
inline std::shared_ptr<Response>
Client::Post(const char *path, const Headers &headers,
const MultipartFormDataItems &items) {
Request req;
req.method = "POST";
req.headers = headers;
req.path = path;
auto boundary = detail::make_multipart_data_boundary();
req.headers.emplace("Content-Type",
"multipart/form-data; boundary=" + boundary);
for (const auto &item : items) {
req.body += "--" + boundary + "\r\n";
req.body += "Content-Disposition: form-data; name=\"" + item.name + "\"";
if (!item.filename.empty()) {
req.body += "; filename=\"" + item.filename + "\"";
}
req.body += "\r\n";
if (!item.content_type.empty()) {
req.body += "Content-Type: " + item.content_type + "\r\n";
}
req.body += "\r\n";
req.body += item.content + "\r\n";
}
req.body += "--" + boundary + "--\r\n";
auto res = std::make_shared<Response>();
return send(req, *res) ? res : nullptr;
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Put(const char *path,
const std::string &body,
const char *content_type) {
return Put(path, Headers(), body, content_type);
2018-05-06 18:16:35 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Put(const char *path,
const Headers &headers,
const std::string &body,
const char *content_type) {
Request req;
req.method = "PUT";
req.headers = headers;
req.path = path;
2018-05-06 18:16:35 -07:00
2019-04-11 05:13:31 -07:00
req.headers.emplace("Content-Type", content_type);
req.body = body;
2018-05-06 18:16:35 -07:00
2019-04-11 05:13:31 -07:00
auto res = std::make_shared<Response>();
2018-05-06 18:16:35 -07:00
2019-04-11 05:13:31 -07:00
return send(req, *res) ? res : nullptr;
2018-05-06 18:16:35 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Patch(const char *path,
const std::string &body,
const char *content_type) {
return Patch(path, Headers(), body, content_type);
2019-03-12 05:49:08 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Patch(const char *path,
const Headers &headers,
const std::string &body,
const char *content_type) {
Request req;
req.method = "PATCH";
req.headers = headers;
req.path = path;
2019-03-12 05:49:08 -07:00
2019-04-11 05:13:31 -07:00
req.headers.emplace("Content-Type", content_type);
req.body = body;
2019-03-12 05:49:08 -07:00
2019-04-11 05:13:31 -07:00
auto res = std::make_shared<Response>();
2019-03-12 05:49:08 -07:00
2019-04-11 05:13:31 -07:00
return send(req, *res) ? res : nullptr;
2019-03-12 05:49:08 -07:00
}
2019-05-05 10:31:42 -07:00
inline std::shared_ptr<Response> Client::Delete(const char *path,
const std::string &body,
const char *content_type) {
return Delete(path, Headers(), body, content_type);
2018-05-06 18:16:35 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Delete(const char *path,
2019-05-05 10:31:42 -07:00
const Headers &headers,
const std::string &body,
const char *content_type) {
2019-04-11 05:13:31 -07:00
Request req;
req.method = "DELETE";
req.headers = headers;
2019-05-05 10:31:42 -07:00
req.path = path;
if (content_type) { req.headers.emplace("Content-Type", content_type); }
req.body = body;
2018-05-06 18:16:35 -07:00
2019-04-11 05:13:31 -07:00
auto res = std::make_shared<Response>();
2018-05-06 18:16:35 -07:00
2019-04-11 05:13:31 -07:00
return send(req, *res) ? res : nullptr;
2018-05-06 18:16:35 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Options(const char *path) {
return Options(path, Headers());
2018-05-06 18:16:35 -07:00
}
2019-04-11 05:13:31 -07:00
inline std::shared_ptr<Response> Client::Options(const char *path,
const Headers &headers) {
Request req;
req.method = "OPTIONS";
req.path = path;
req.headers = headers;
2018-05-06 18:16:35 -07:00
2019-04-11 05:13:31 -07:00
auto res = std::make_shared<Response>();
2018-05-06 18:16:35 -07:00
2019-04-11 05:13:31 -07:00
return send(req, *res) ? res : nullptr;
2012-10-11 20:52:34 -07:00
}
2017-04-21 20:00:00 -07:00
/*
* SSL Implementation
*/
#ifdef CPPHTTPLIB_OPENSSL_SUPPORT
namespace detail {
2017-09-07 11:24:33 -07:00
template <typename U, typename V, typename T>
2019-04-11 05:13:31 -07:00
inline bool
read_and_close_socket_ssl(socket_t sock, size_t keep_alive_max_count,
SSL_CTX *ctx, std::mutex &ctx_mutex,
2019-06-11 18:18:45 -07:00
U SSL_connect_or_accept, V setup, T callback) {
2019-04-11 05:13:31 -07:00
SSL *ssl = nullptr;
{
std::lock_guard<std::mutex> guard(ctx_mutex);
ssl = SSL_new(ctx);
2019-06-03 08:06:59 -07:00
}
if (!ssl) {
close_socket(sock);
return false;
2019-04-11 05:13:31 -07:00
}
2017-05-13 20:43:09 -07:00
2019-04-11 05:13:31 -07:00
auto bio = BIO_new_socket(sock, BIO_NOCLOSE);
SSL_set_bio(ssl, bio, bio);
2017-09-07 11:24:33 -07:00
2019-06-03 08:06:59 -07:00
if (!setup(ssl)) {
SSL_shutdown(ssl);
{
std::lock_guard<std::mutex> guard(ctx_mutex);
SSL_free(ssl);
}
close_socket(sock);
return false;
}
2019-04-11 05:13:31 -07:00
bool ret = false;
2018-05-13 21:05:14 -07:00
2019-05-07 13:41:33 -07:00
if (SSL_connect_or_accept(ssl) == 1) {
if (keep_alive_max_count > 0) {
auto count = keep_alive_max_count;
while (count > 0 &&
detail::select_read(sock, CPPHTTPLIB_KEEPALIVE_TIMEOUT_SECOND,
CPPHTTPLIB_KEEPALIVE_TIMEOUT_USECOND) > 0) {
SSLSocketStream strm(sock, ssl);
auto last_connection = count == 1;
auto connection_close = false;
2018-05-13 21:05:14 -07:00
2019-06-20 15:52:28 -07:00
ret = callback(ssl, strm, last_connection, connection_close);
2019-05-07 13:41:33 -07:00
if (!ret || connection_close) { break; }
2019-04-11 05:13:31 -07:00
2019-05-07 13:41:33 -07:00
count--;
}
} else {
SSLSocketStream strm(sock, ssl);
auto dummy_connection_close = false;
2019-06-20 15:52:28 -07:00
ret = callback(ssl, strm, true, dummy_connection_close);
}
2019-06-03 08:06:59 -07:00
}
2017-04-21 20:00:00 -07:00
2019-06-03 08:06:59 -07:00
SSL_shutdown(ssl);
{
std::lock_guard<std::mutex> guard(ctx_mutex);
SSL_free(ssl);
2019-05-07 13:41:33 -07:00
}
2019-06-03 08:06:59 -07:00
close_socket(sock);
2019-04-11 05:13:31 -07:00
return ret;
2017-04-21 20:00:00 -07:00
}
#if OPENSSL_VERSION_NUMBER < 0x10100000L
2019-07-22 03:58:05 -07:00
static std::shared_ptr<std::vector<std::mutex>> openSSL_locks_;
class SSLThreadLocks {
public:
SSLThreadLocks() {
2019-07-22 03:58:05 -07:00
openSSL_locks_ =
std::make_shared<std::vector<std::mutex>>(CRYPTO_num_locks());
CRYPTO_set_locking_callback(locking_callback);
}
2019-07-22 03:58:05 -07:00
~SSLThreadLocks() { CRYPTO_set_locking_callback(nullptr); }
private:
2019-07-22 03:58:05 -07:00
static void locking_callback(int mode, int type, const char * /*file*/,
int /*line*/) {
auto &locks = *openSSL_locks_;
if (mode & CRYPTO_LOCK) {
2019-07-22 03:58:05 -07:00
locks[type].lock();
} else {
2019-07-22 03:58:05 -07:00
locks[type].unlock();
}
}
};
#endif
2017-04-21 20:00:00 -07:00
class SSLInit {
public:
2019-04-11 05:13:31 -07:00
SSLInit() {
SSL_load_error_strings();
SSL_library_init();
}
2019-02-22 06:52:38 -07:00
2019-04-11 05:13:31 -07:00
~SSLInit() { ERR_free_strings(); }
private:
#if OPENSSL_VERSION_NUMBER < 0x10100000L
SSLThreadLocks thread_init_;
#endif
2017-04-21 20:00:00 -07:00
};
static SSLInit sslinit_;
} // namespace detail
// SSL socket stream implementation
2019-04-11 05:13:31 -07:00
inline SSLSocketStream::SSLSocketStream(socket_t sock, SSL *ssl)
: sock_(sock), ssl_(ssl) {}
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
inline SSLSocketStream::~SSLSocketStream() {}
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
inline int SSLSocketStream::read(char *ptr, size_t size) {
2019-06-04 19:53:37 -07:00
if (SSL_pending(ssl_) > 0 ||
detail::select_read(sock_, CPPHTTPLIB_READ_TIMEOUT_SECOND,
CPPHTTPLIB_READ_TIMEOUT_USECOND) > 0) {
return SSL_read(ssl_, ptr, size);
}
return -1;
2017-04-21 20:00:00 -07:00
}
2019-04-11 05:13:31 -07:00
inline int SSLSocketStream::write(const char *ptr, size_t size) {
return SSL_write(ssl_, ptr, size);
2017-04-21 20:00:00 -07:00
}
2019-04-11 05:13:31 -07:00
inline int SSLSocketStream::write(const char *ptr) {
return write(ptr, strlen(ptr));
2017-04-21 20:00:00 -07:00
}
inline int SSLSocketStream::write(const std::string &s) {
return write(s.data(), s.size());
}
2018-10-28 00:15:22 -07:00
inline std::string SSLSocketStream::get_remote_addr() const {
2019-04-11 05:13:31 -07:00
return detail::get_remote_addr(sock_);
}
2017-04-21 20:00:00 -07:00
// SSL HTTP server implementation
2019-06-11 17:57:02 -07:00
inline SSLServer::SSLServer(const char *cert_path, const char *private_key_path,
2019-06-11 18:18:45 -07:00
const char *client_ca_cert_file_path,
const char *client_ca_cert_dir_path) {
2019-04-11 05:13:31 -07:00
ctx_ = SSL_CTX_new(SSLv23_server_method());
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
if (ctx_) {
SSL_CTX_set_options(ctx_,
SSL_OP_ALL | SSL_OP_NO_SSLv2 | SSL_OP_NO_SSLv3 |
2017-04-21 20:00:00 -07:00
SSL_OP_NO_COMPRESSION |
SSL_OP_NO_SESSION_RESUMPTION_ON_RENEGOTIATION);
2019-04-11 05:13:31 -07:00
// auto ecdh = EC_KEY_new_by_curve_name(NID_X9_62_prime256v1);
// SSL_CTX_set_tmp_ecdh(ctx_, ecdh);
// EC_KEY_free(ecdh);
2017-04-21 20:00:00 -07:00
2019-04-11 05:13:31 -07:00
if (SSL_CTX_use_certificate_chain_file(ctx_, cert_path) != 1 ||
SSL_CTX_use_PrivateKey_file(ctx_, private_key_path, SSL_FILETYPE_PEM) !=
1) {
SSL_CTX_free(ctx_);
ctx_ = nullptr;
2019-06-11 18:18:45 -07:00
} else if (client_ca_cert_file_path || client_ca_cert_dir_path) {
// if (client_ca_cert_file_path) {
// auto list = SSL_load_client_CA_file(client_ca_cert_file_path);
// SSL_CTX_set_client_CA_list(ctx_, list);
// }
SSL_CTX_load_verify_locations(ctx_, client_ca_cert_file_path,
client_ca_cert_dir_path);
2019-06-11 17:57:02 -07:00
SSL_CTX_set_verify(
ctx_,
SSL_VERIFY_PEER |
SSL_VERIFY_FAIL_IF_NO_PEER_CERT, // SSL_VERIFY_CLIENT_ONCE,
nullptr);
2017-04-21 20:00:00 -07:00
}
2019-04-11 05:13:31 -07:00
}
2017-04-21 20:00:00 -07:00
}
2019-04-11 05:13:31 -07:00
inline SSLServer::~SSLServer() {
if (ctx_) { SSL_CTX_free(ctx_); }
2017-04-21 20:00:00 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool SSLServer::is_valid() const { return ctx_; }
2019-04-11 05:13:31 -07:00
inline bool SSLServer::read_and_close_socket(socket_t sock) {
return detail::read_and_close_socket_ssl(
sock, keep_alive_max_count_, ctx_, ctx_mutex_, SSL_accept,
2019-05-07 13:41:33 -07:00
[](SSL * /*ssl*/) { return true; },
2019-06-20 15:52:28 -07:00
[this](SSL *ssl, Stream &strm, bool last_connection,
bool &connection_close) {
return process_request(strm, last_connection, connection_close,
[&](Request &req) { req.ssl = ssl; });
2019-06-11 18:18:45 -07:00
});
2017-04-21 20:00:00 -07:00
}
// SSL HTTP client implementation
inline SSLClient::SSLClient(const char *host, int port, time_t timeout_sec,
2019-06-11 17:57:02 -07:00
const char *client_cert_path,
const char *client_key_path)
2019-04-11 05:13:31 -07:00
: Client(host, port, timeout_sec) {
ctx_ = SSL_CTX_new(SSLv23_client_method());
detail::split(&host_[0], &host_[host_.size()], '.',
[&](const char *b, const char *e) {
host_components_.emplace_back(std::string(b, e));
});
2019-06-11 17:57:02 -07:00
if (client_cert_path && client_key_path) {
if (SSL_CTX_use_certificate_file(ctx_, client_cert_path,
SSL_FILETYPE_PEM) != 1 ||
SSL_CTX_use_PrivateKey_file(ctx_, client_key_path, SSL_FILETYPE_PEM) !=
1) {
SSL_CTX_free(ctx_);
ctx_ = nullptr;
}
}
2017-04-21 20:00:00 -07:00
}
2019-04-11 05:13:31 -07:00
inline SSLClient::~SSLClient() {
if (ctx_) { SSL_CTX_free(ctx_); }
2017-04-21 20:00:00 -07:00
}
2019-04-11 05:13:31 -07:00
inline bool SSLClient::is_valid() const { return ctx_; }
2019-06-11 18:18:45 -07:00
inline void SSLClient::set_ca_cert_path(const char *ca_cert_file_path,
const char *ca_cert_dir_path) {
if (ca_cert_file_path) { ca_cert_file_path_ = ca_cert_file_path; }
if (ca_cert_dir_path) { ca_cert_dir_path_ = ca_cert_dir_path; }
2019-05-07 13:41:33 -07:00
}
inline void SSLClient::enable_server_certificate_verification(bool enabled) {
server_certificate_verification_ = enabled;
2019-05-07 13:41:33 -07:00
}
inline long SSLClient::get_openssl_verify_result() const {
return verify_result_;
}
2019-04-11 05:13:31 -07:00
inline bool SSLClient::read_and_close_socket(socket_t sock, Request &req,
Response &res) {
2019-05-07 13:41:33 -07:00
2019-04-11 05:13:31 -07:00
return is_valid() &&
detail::read_and_close_socket_ssl(
2019-05-07 13:41:33 -07:00
sock, 0, ctx_, ctx_mutex_,
[&](SSL *ssl) {
2019-06-11 18:18:45 -07:00
if (ca_cert_file_path_.empty()) {
2019-05-07 13:41:33 -07:00
SSL_CTX_set_verify(ctx_, SSL_VERIFY_NONE, nullptr);
} else {
2019-06-11 18:18:45 -07:00
if (!SSL_CTX_load_verify_locations(
ctx_, ca_cert_file_path_.c_str(), nullptr)) {
2019-05-07 13:41:33 -07:00
return false;
}
SSL_CTX_set_verify(ctx_, SSL_VERIFY_PEER, nullptr);
}
if (SSL_connect(ssl) != 1) { return false; }
if (server_certificate_verification_) {
2019-05-07 13:41:33 -07:00
verify_result_ = SSL_get_verify_result(ssl);
if (verify_result_ != X509_V_OK) { return false; }
auto server_cert = SSL_get_peer_certificate(ssl);
if (server_cert == nullptr) { return false; }
2019-06-20 14:37:18 -07:00
if (!verify_host(server_cert)) {
X509_free(server_cert);
return false;
}
X509_free(server_cert);
2019-05-07 13:41:33 -07:00
}
return true;
},
[&](SSL *ssl) {
SSL_set_tlsext_host_name(ssl, host_.c_str());
return true;
},
2019-06-20 15:52:28 -07:00
[&](SSL * /*ssl*/, Stream &strm, bool /*last_connection*/,
2019-04-11 05:13:31 -07:00
bool &connection_close) {
return process_request(strm, req, res, connection_close);
});
2017-04-21 20:00:00 -07:00
}
2018-12-13 17:37:44 -07:00
2019-04-11 05:13:31 -07:00
inline bool SSLClient::is_ssl() const { return true; }
2019-05-07 13:41:33 -07:00
inline bool SSLClient::verify_host(X509 *server_cert) const {
/* Quote from RFC2818 section 3.1 "Server Identity"
If a subjectAltName extension of type dNSName is present, that MUST
be used as the identity. Otherwise, the (most specific) Common Name
field in the Subject field of the certificate MUST be used. Although
the use of the Common Name is existing practice, it is deprecated and
Certification Authorities are encouraged to use the dNSName instead.
Matching is performed using the matching rules specified by
[RFC2459]. If more than one identity of a given type is present in
the certificate (e.g., more than one dNSName name, a match in any one
of the set is considered acceptable.) Names may contain the wildcard
character * which is considered to match any single domain name
component or component fragment. E.g., *.a.com matches foo.a.com but
not bar.foo.a.com. f*.com matches foo.com but not bar.com.
In some cases, the URI is specified as an IP address rather than a
hostname. In this case, the iPAddress subjectAltName must be present
in the certificate and must exactly match the IP in the URI.
*/
return verify_host_with_subject_alt_name(server_cert) ||
verify_host_with_common_name(server_cert);
2019-05-07 13:41:33 -07:00
}
inline bool
SSLClient::verify_host_with_subject_alt_name(X509 *server_cert) const {
2019-05-07 17:11:45 -07:00
auto ret = false;
auto type = GEN_DNS;
struct in6_addr addr6;
struct in_addr addr;
size_t addr_len = 0;
2019-08-25 13:49:10 -07:00
#ifndef __MINGW32__
if (inet_pton(AF_INET6, host_.c_str(), &addr6)) {
2019-05-07 17:11:45 -07:00
type = GEN_IPADD;
addr_len = sizeof(struct in6_addr);
} else if (inet_pton(AF_INET, host_.c_str(), &addr)) {
2019-05-07 17:11:45 -07:00
type = GEN_IPADD;
addr_len = sizeof(struct in_addr);
}
2019-08-25 13:49:10 -07:00
#endif
2019-05-07 17:11:45 -07:00
2019-06-11 17:57:02 -07:00
auto alt_names = static_cast<const struct stack_st_GENERAL_NAME *>(
2019-05-31 07:30:11 -07:00
X509_get_ext_d2i(server_cert, NID_subject_alt_name, nullptr, nullptr));
2019-05-07 17:11:45 -07:00
if (alt_names) {
auto dsn_matched = false;
auto ip_mached = false;
auto count = sk_GENERAL_NAME_num(alt_names);
2019-05-07 17:11:45 -07:00
for (auto i = 0; i < count && !dsn_matched; i++) {
2019-05-07 17:11:45 -07:00
auto val = sk_GENERAL_NAME_value(alt_names, i);
if (val->type == type) {
2019-06-20 08:45:11 -07:00
auto name = (const char *)ASN1_STRING_get0_data(val->d.ia5);
auto name_len = (size_t)ASN1_STRING_length(val->d.ia5);
2019-05-07 17:11:45 -07:00
if (strlen(name) == name_len) {
2019-05-07 17:11:45 -07:00
switch (type) {
case GEN_DNS: dsn_matched = check_host_name(name, name_len); break;
2019-05-07 17:11:45 -07:00
case GEN_IPADD:
if (!memcmp(&addr6, name, addr_len) ||
!memcmp(&addr, name, addr_len)) {
2019-05-07 17:11:45 -07:00
ip_mached = true;
}
break;
}
}
}
}
if (dsn_matched || ip_mached) { ret = true; }
}
GENERAL_NAMES_free((STACK_OF(GENERAL_NAME) *)alt_names);
return ret;
}
inline bool SSLClient::verify_host_with_common_name(X509 *server_cert) const {
2019-05-07 17:11:45 -07:00
const auto subject_name = X509_get_subject_name(server_cert);
if (subject_name != nullptr) {
char name[BUFSIZ];
auto name_len = X509_NAME_get_text_by_NID(subject_name, NID_commonName,
name, sizeof(name));
if (name_len != -1) { return check_host_name(name, name_len); }
2019-05-07 17:11:45 -07:00
}
return false;
}
inline bool SSLClient::check_host_name(const char *pattern,
size_t pattern_len) const {
2019-06-11 17:57:02 -07:00
if (host_.size() == pattern_len && host_ == pattern) { return true; }
2019-05-07 13:41:33 -07:00
// Wildcard match
// https://bugs.launchpad.net/ubuntu/+source/firefox-3.0/+bug/376484
std::vector<std::string> pattern_components;
detail::split(&pattern[0], &pattern[pattern_len], '.',
[&](const char *b, const char *e) {
pattern_components.emplace_back(std::string(b, e));
});
if (host_components_.size() != pattern_components.size()) { return false; }
auto itr = pattern_components.begin();
for (const auto &h : host_components_) {
auto &p = *itr;
if (p != h && p != "*") {
auto partial_match = (p.size() > 0 && p[p.size() - 1] == '*' &&
!p.compare(0, p.size() - 1, h));
if (!partial_match) { return false; }
}
++itr;
}
2019-05-07 13:41:33 -07:00
return true;
2019-05-07 13:41:33 -07:00
}
2017-04-21 20:00:00 -07:00
#endif
2012-09-27 18:05:36 -07:00
} // namespace httplib
2012-09-22 21:40:46 -07:00
2019-04-11 05:13:31 -07:00
#endif // CPPHTTPLIB_HTTPLIB_H