summaryrefslogtreecommitdiffstats
diff options
context:
space:
mode:
-rw-r--r--externals/httplib/httplib.h4677
-rw-r--r--src/core/CMakeLists.txt17
-rw-r--r--src/core/arm/dynarmic/arm_dynarmic.cpp2
-rw-r--r--src/core/arm/unicorn/arm_unicorn.cpp14
-rw-r--r--src/core/arm/unicorn/arm_unicorn.h2
-rw-r--r--src/core/crypto/key_manager.cpp16
-rw-r--r--src/core/crypto/partition_data_manager.cpp7
-rw-r--r--src/core/file_sys/kernel_executable.cpp2
-rw-r--r--src/core/file_sys/program_metadata.cpp6
-rw-r--r--src/core/file_sys/program_metadata.h4
-rw-r--r--src/core/file_sys/romfs_factory.cpp4
-rw-r--r--src/core/file_sys/savedata_factory.cpp4
-rw-r--r--src/core/file_sys/vfs_libzip.cpp2
-rw-r--r--src/core/file_sys/xts_archive.cpp12
-rw-r--r--src/core/gdbstub/gdbstub.cpp3
-rw-r--r--src/core/hle/kernel/scheduler.cpp46
-rw-r--r--src/core/hle/kernel/scheduler.h36
-rw-r--r--src/core/hle/kernel/thread.cpp48
-rw-r--r--src/core/hle/kernel/vm_manager.cpp2
-rw-r--r--src/core/hle/result.h10
-rw-r--r--src/core/hle/service/acc/acc.cpp6
-rw-r--r--src/core/hle/service/acc/profile_manager.cpp4
-rw-r--r--src/core/hle/service/am/am.cpp4
-rw-r--r--src/core/hle/service/am/applets/web_browser.cpp16
-rw-r--r--src/core/hle/service/aoc/aoc_u.cpp2
-rw-r--r--src/core/hle/service/audio/hwopus.cpp4
-rw-r--r--src/core/hle/service/bcat/backend/boxcat.cpp2
-rw-r--r--src/core/hle/service/filesystem/filesystem.cpp26
-rw-r--r--src/core/hle/service/filesystem/fsp_srv.cpp6
-rw-r--r--src/core/hle/service/mii/mii.cpp6
-rw-r--r--src/core/hle/service/nfp/nfp.cpp3
-rw-r--r--src/core/hle/service/ns/ns.cpp4
-rw-r--r--src/core/hle/service/ns/pl_u.cpp2
-rw-r--r--src/core/hle/service/time/time.cpp26
-rw-r--r--src/core/hle/service/vi/vi.cpp2
-rw-r--r--src/core/perf_stats.cpp2
36 files changed, 3207 insertions, 1822 deletions
diff --git a/externals/httplib/httplib.h b/externals/httplib/httplib.h
index dd9afe693..fa2edcc94 100644
--- a/externals/httplib/httplib.h
+++ b/externals/httplib/httplib.h
@@ -1,357 +1,768 @@
//
// httplib.h
//
-// Copyright (c) 2017 Yuji Hirose. All rights reserved.
+// Copyright (c) 2019 Yuji Hirose. All rights reserved.
// MIT License
//
-#ifndef _CPPHTTPLIB_HTTPLIB_H_
-#define _CPPHTTPLIB_HTTPLIB_H_
+#ifndef CPPHTTPLIB_HTTPLIB_H
+#define CPPHTTPLIB_HTTPLIB_H
+
+/*
+ * Configuration
+ */
+#ifndef CPPHTTPLIB_KEEPALIVE_TIMEOUT_SECOND
+#define CPPHTTPLIB_KEEPALIVE_TIMEOUT_SECOND 5
+#endif
+
+#ifndef CPPHTTPLIB_KEEPALIVE_TIMEOUT_USECOND
+#define CPPHTTPLIB_KEEPALIVE_TIMEOUT_USECOND 0
+#endif
+
+#ifndef CPPHTTPLIB_KEEPALIVE_MAX_COUNT
+#define CPPHTTPLIB_KEEPALIVE_MAX_COUNT 5
+#endif
+
+#ifndef CPPHTTPLIB_READ_TIMEOUT_SECOND
+#define CPPHTTPLIB_READ_TIMEOUT_SECOND 5
+#endif
+
+#ifndef CPPHTTPLIB_READ_TIMEOUT_USECOND
+#define CPPHTTPLIB_READ_TIMEOUT_USECOND 0
+#endif
+
+#ifndef CPPHTTPLIB_REQUEST_URI_MAX_LENGTH
+#define CPPHTTPLIB_REQUEST_URI_MAX_LENGTH 8192
+#endif
+
+#ifndef CPPHTTPLIB_REDIRECT_MAX_COUNT
+#define CPPHTTPLIB_REDIRECT_MAX_COUNT 20
+#endif
+
+#ifndef CPPHTTPLIB_PAYLOAD_MAX_LENGTH
+#define CPPHTTPLIB_PAYLOAD_MAX_LENGTH (std::numeric_limits<size_t>::max)()
+#endif
+
+#ifndef CPPHTTPLIB_RECV_BUFSIZ
+#define CPPHTTPLIB_RECV_BUFSIZ size_t(4096u)
+#endif
+
+#ifndef CPPHTTPLIB_THREAD_POOL_COUNT
+#define CPPHTTPLIB_THREAD_POOL_COUNT 8
+#endif
#ifdef _WIN32
#ifndef _CRT_SECURE_NO_WARNINGS
#define _CRT_SECURE_NO_WARNINGS
-#endif
+#endif //_CRT_SECURE_NO_WARNINGS
+
#ifndef _CRT_NONSTDC_NO_DEPRECATE
#define _CRT_NONSTDC_NO_DEPRECATE
+#endif //_CRT_NONSTDC_NO_DEPRECATE
+
+#if defined(_MSC_VER)
+#ifdef _WIN64
+typedef __int64 ssize_t;
+#else
+typedef int ssize_t;
#endif
-#if defined(_MSC_VER) && _MSC_VER < 1900
+#if _MSC_VER < 1900
#define snprintf _snprintf_s
#endif
+#endif // _MSC_VER
#ifndef S_ISREG
-#define S_ISREG(m) (((m)&S_IFREG)==S_IFREG)
-#endif
+#define S_ISREG(m) (((m)&S_IFREG) == S_IFREG)
+#endif // S_ISREG
+
#ifndef S_ISDIR
-#define S_ISDIR(m) (((m)&S_IFDIR)==S_IFDIR)
-#endif
+#define S_ISDIR(m) (((m)&S_IFDIR) == S_IFDIR)
+#endif // S_ISDIR
+
+#ifndef NOMINMAX
+#define NOMINMAX
+#endif // NOMINMAX
#include <io.h>
#include <winsock2.h>
#include <ws2tcpip.h>
-#undef min
-#undef max
+#ifndef WSA_FLAG_NO_HANDLE_INHERIT
+#define WSA_FLAG_NO_HANDLE_INHERIT 0x80
+#endif
+
+#ifdef _MSC_VER
+#pragma comment(lib, "ws2_32.lib")
+#endif
#ifndef strcasecmp
#define strcasecmp _stricmp
-#endif
+#endif // strcasecmp
typedef SOCKET socket_t;
-#else
-#include <pthread.h>
-#include <unistd.h>
-#include <netdb.h>
+#ifdef CPPHTTPLIB_USE_POLL
+#define poll(fds, nfds, timeout) WSAPoll(fds, nfds, timeout)
+#endif
+
+#else // not _WIN32
+
+#include <arpa/inet.h>
#include <cstring>
+#include <netdb.h>
#include <netinet/in.h>
-#include <arpa/inet.h>
+#ifdef CPPHTTPLIB_USE_POLL
+#include <poll.h>
+#endif
+#include <pthread.h>
#include <signal.h>
-#include <sys/socket.h>
#include <sys/select.h>
+#include <sys/socket.h>
+#include <unistd.h>
typedef int socket_t;
#define INVALID_SOCKET (-1)
-#endif
+#endif //_WIN32
+#include <assert.h>
+#include <atomic>
+#include <condition_variable>
+#include <errno.h>
+#include <fcntl.h>
#include <fstream>
#include <functional>
+#include <list>
#include <map>
#include <memory>
#include <mutex>
+#include <random>
#include <regex>
#include <string>
-#include <thread>
#include <sys/stat.h>
-#include <fcntl.h>
-#include <assert.h>
+#include <thread>
#ifdef CPPHTTPLIB_OPENSSL_SUPPORT
+#include <openssl/err.h>
#include <openssl/ssl.h>
+#include <openssl/x509v3.h>
+
+// #if OPENSSL_VERSION_NUMBER < 0x1010100fL
+// #error Sorry, OpenSSL versions prior to 1.1.1 are not supported
+// #endif
+
+#if OPENSSL_VERSION_NUMBER < 0x10100000L
+#include <openssl/crypto.h>
+inline const unsigned char *ASN1_STRING_get0_data(const ASN1_STRING *asn1) {
+ return M_ASN1_STRING_data(asn1);
+}
+#endif
#endif
#ifdef CPPHTTPLIB_ZLIB_SUPPORT
#include <zlib.h>
#endif
-/*
- * Configuration
- */
-#define CPPHTTPLIB_KEEPALIVE_TIMEOUT_SECOND 5
-#define CPPHTTPLIB_KEEPALIVE_TIMEOUT_USECOND 0
-
-namespace httplib
-{
+namespace httplib {
namespace detail {
struct ci {
- 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);
- });
- }
+ 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); });
+ }
};
} // namespace detail
enum class HttpVersion { v1_0 = 0, v1_1 };
-typedef std::multimap<std::string, std::string, detail::ci> Headers;
+typedef std::multimap<std::string, std::string, detail::ci> Headers;
+
+typedef std::multimap<std::string, std::string> Params;
+typedef std::smatch Match;
+
+typedef std::function<void(const char *data, size_t data_len)> DataSink;
-template<typename uint64_t, typename... Args>
-std::pair<std::string, std::string> make_range_header(uint64_t value, Args... args);
+typedef std::function<void()> Done;
-typedef std::multimap<std::string, std::string> Params;
-typedef std::smatch Match;
-typedef std::function<void (uint64_t current, uint64_t total)> Progress;
+typedef std::function<void(size_t offset, size_t length, DataSink sink,
+ Done done)>
+ ContentProvider;
+
+typedef std::function<bool(const char *data, size_t data_length, size_t offset,
+ uint64_t content_length)>
+ ContentReceiver;
+
+typedef std::function<bool(uint64_t current, uint64_t total)> Progress;
+
+struct Response;
+typedef std::function<bool(const Response &response)> ResponseHandler;
struct MultipartFile {
- std::string filename;
- std::string content_type;
- size_t offset = 0;
- size_t length = 0;
+ std::string filename;
+ std::string content_type;
+ size_t offset = 0;
+ size_t length = 0;
};
typedef std::multimap<std::string, MultipartFile> MultipartFiles;
+struct MultipartFormData {
+ std::string name;
+ std::string content;
+ std::string filename;
+ std::string content_type;
+};
+typedef std::vector<MultipartFormData> MultipartFormDataItems;
+
+typedef std::pair<ssize_t, ssize_t> Range;
+typedef std::vector<Range> Ranges;
+
struct Request {
- std::string version;
- std::string method;
- std::string target;
- std::string path;
- Headers headers;
- std::string body;
- Params params;
- MultipartFiles files;
- Match matches;
-
- Progress progress;
-
- bool has_header(const char* key) const;
- std::string get_header_value(const char* key) const;
- void set_header(const char* key, const char* val);
-
- bool has_param(const char* key) const;
- std::string get_param_value(const char* key) const;
-
- bool has_file(const char* key) const;
- MultipartFile get_file_value(const char* key) const;
+ std::string method;
+ std::string path;
+ Headers headers;
+ std::string body;
+
+ // for server
+ std::string version;
+ std::string target;
+ Params params;
+ MultipartFiles files;
+ Ranges ranges;
+ Match matches;
+
+ // for client
+ size_t redirect_count = CPPHTTPLIB_REDIRECT_MAX_COUNT;
+ ResponseHandler response_handler;
+ ContentReceiver content_receiver;
+ Progress progress;
+
+#ifdef CPPHTTPLIB_OPENSSL_SUPPORT
+ const SSL *ssl;
+#endif
+
+ 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);
+
+ 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;
};
struct Response {
- std::string version;
- int status;
- Headers headers;
- std::string body;
+ std::string version;
+ int status;
+ Headers headers;
+ std::string body;
- bool has_header(const char* key) const;
- std::string get_header_value(const char* key) const;
- void set_header(const char* key, const char* val);
+ 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);
- 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_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);
- Response() : status(-1) {}
+ void set_content_provider(
+ size_t length,
+ std::function<void(size_t offset, size_t length, DataSink sink)> provider,
+ std::function<void()> resource_releaser = [] {});
+
+ void set_chunked_content_provider(
+ std::function<void(size_t offset, DataSink sink, Done done)> provider,
+ std::function<void()> resource_releaser = [] {});
+
+ Response() : status(-1), content_provider_resource_length(0) {}
+
+ ~Response() {
+ if (content_provider_resource_releaser) {
+ content_provider_resource_releaser();
+ }
+ }
+
+ size_t content_provider_resource_length;
+ ContentProvider content_provider;
+ std::function<void()> content_provider_resource_releaser;
};
class Stream {
public:
- 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 std::string get_remote_addr() = 0;
-
- template <typename ...Args>
- void write_format(const char* fmt, const Args& ...args);
+ 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;
+ virtual std::string get_remote_addr() const = 0;
+
+ template <typename... Args>
+ int write_format(const char *fmt, const Args &... args);
};
class SocketStream : public Stream {
public:
- SocketStream(socket_t sock);
- virtual ~SocketStream();
+ SocketStream(socket_t sock);
+ virtual ~SocketStream();
+
+ 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);
+ virtual std::string get_remote_addr() const;
+
+private:
+ socket_t sock_;
+};
+
+class BufferStream : public Stream {
+public:
+ BufferStream() {}
+ virtual ~BufferStream() {}
+
+ 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);
+ virtual std::string get_remote_addr() const;
+
+ const std::string &get_buffer() const;
+
+private:
+ std::string buffer;
+};
+
+class TaskQueue {
+public:
+ TaskQueue() {}
+ virtual ~TaskQueue() {}
+ virtual void enqueue(std::function<void()> fn) = 0;
+ virtual void shutdown() = 0;
+};
- virtual int read(char* ptr, size_t size);
- virtual int write(const char* ptr, size_t size);
- virtual int write(const char* ptr);
- virtual std::string get_remote_addr();
+#if CPPHTTPLIB_THREAD_POOL_COUNT > 0
+class ThreadPool : public TaskQueue {
+public:
+ ThreadPool(size_t n) : shutdown_(false) {
+ 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;
+ }
+
+ cond_.notify_all();
+
+ // Join...
+ for (auto t : threads_) {
+ t->join();
+ }
+ }
private:
- socket_t sock_;
+ struct worker {
+ worker(ThreadPool &pool) : pool_(pool) {}
+
+ void operator()() {
+ for (;;) {
+ std::function<void()> fn;
+ {
+ std::unique_lock<std::mutex> lock(pool_.mutex_);
+
+ pool_.cond_.wait(
+ lock, [&] { return !pool_.jobs_.empty() || pool_.shutdown_; });
+
+ if (pool_.shutdown_ && pool_.jobs_.empty()) { break; }
+
+ fn = pool_.jobs_.front();
+ pool_.jobs_.pop_front();
+ }
+
+ assert(true == static_cast<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 {
+ 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();
+ }
+
+ virtual void shutdown() override {
+ 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_;
};
+#endif
class Server {
public:
- typedef std::function<void (const Request&, Response&)> Handler;
- typedef std::function<void (const Request&, const Response&)> Logger;
+ typedef std::function<void(const Request &, Response &)> Handler;
+ typedef std::function<void(const Request &, const Response &)> Logger;
+
+ Server();
- Server();
+ virtual ~Server();
- virtual ~Server();
+ virtual bool is_valid() const;
- virtual bool is_valid() const;
+ Server &Get(const char *pattern, Handler handler);
+ Server &Post(const char *pattern, Handler handler);
- Server& Get(const char* pattern, Handler handler);
- Server& Post(const char* pattern, Handler handler);
+ 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);
- Server& Put(const char* pattern, Handler handler);
- Server& Delete(const char* pattern, Handler handler);
- Server& Options(const char* pattern, Handler handler);
+ bool set_base_dir(const char *path);
+ void set_file_request_handler(Handler handler);
- bool set_base_dir(const char* path);
+ void set_error_handler(Handler handler);
+ void set_logger(Logger logger);
- void set_error_handler(Handler handler);
- void set_logger(Logger logger);
+ void set_keep_alive_max_count(size_t count);
+ void set_payload_max_length(size_t length);
- void set_keep_alive_max_count(size_t count);
+ int bind_to_any_port(const char *host, int socket_flags = 0);
+ bool listen_after_bind();
- int bind_to_any_port(const char* host, int socket_flags = 0);
- bool listen_after_bind();
+ bool listen(const char *host, int port, int socket_flags = 0);
- bool listen(const char* host, int port, int socket_flags = 0);
+ bool is_running() const;
+ void stop();
- bool is_running() const;
- void stop();
+ std::function<TaskQueue *(void)> new_task_queue;
protected:
- bool process_request(Stream& strm, bool last_connection, bool& connection_close);
+ bool process_request(Stream &strm, bool last_connection,
+ bool &connection_close,
+ std::function<void(Request &)> setup_request);
- size_t keep_alive_max_count_;
+ size_t keep_alive_max_count_;
+ size_t payload_max_length_;
private:
- 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);
- void write_response(Stream& strm, bool last_connection, const Request& req, Response& res);
-
- virtual bool read_and_close_socket(socket_t sock);
-
- bool is_running_;
- socket_t svr_sock_;
- std::string base_dir_;
- Handlers get_handlers_;
- Handlers post_handlers_;
- Handlers put_handlers_;
- Handlers delete_handlers_;
- Handlers options_handlers_;
- Handler error_handler_;
- Logger logger_;
-
- // TODO: Use thread pool...
- std::mutex running_threads_mutex_;
- int running_threads_;
+ 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);
+ bool write_response(Stream &strm, bool last_connection, const Request &req,
+ Response &res);
+ bool write_content_with_provider(Stream &strm, const Request &req,
+ Response &res, const std::string &boundary,
+ const std::string &content_type);
+
+ virtual bool process_and_close_socket(socket_t sock);
+
+ std::atomic<bool> is_running_;
+ std::atomic<socket_t> svr_sock_;
+ std::string base_dir_;
+ Handler file_request_handler_;
+ Handlers get_handlers_;
+ Handlers post_handlers_;
+ Handlers put_handlers_;
+ Handlers patch_handlers_;
+ Handlers delete_handlers_;
+ Handlers options_handlers_;
+ Handler error_handler_;
+ Logger logger_;
};
class Client {
public:
- Client(
- const char* host,
- int port = 80,
- size_t timeout_sec = 300);
+ Client(const char *host, int port = 80, time_t timeout_sec = 300);
+
+ virtual ~Client();
+
+ virtual bool is_valid() const;
+
+ std::shared_ptr<Response> Get(const char *path);
+
+ std::shared_ptr<Response> Get(const char *path, const Headers &headers);
+
+ std::shared_ptr<Response> Get(const char *path, Progress progress);
+
+ std::shared_ptr<Response> Get(const char *path, const Headers &headers,
+ Progress progress);
- virtual ~Client();
+ std::shared_ptr<Response> Get(const char *path,
+ ContentReceiver content_receiver);
- virtual bool is_valid() const;
+ std::shared_ptr<Response> Get(const char *path, const Headers &headers,
+ ContentReceiver content_receiver);
- 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);
+ std::shared_ptr<Response>
+ Get(const char *path, ContentReceiver content_receiver, Progress progress);
- std::shared_ptr<Response> Head(const char* path);
- std::shared_ptr<Response> Head(const char* path, const Headers& headers);
+ std::shared_ptr<Response> Get(const char *path, const Headers &headers,
+ ContentReceiver content_receiver,
+ Progress progress);
- 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);
+ std::shared_ptr<Response> Get(const char *path, const Headers &headers,
+ ResponseHandler response_handler,
+ ContentReceiver content_receiver);
- 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);
+ std::shared_ptr<Response> Get(const char *path, const Headers &headers,
+ ResponseHandler response_handler,
+ ContentReceiver content_receiver,
+ Progress progress);
- 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);
+ std::shared_ptr<Response> Head(const char *path);
- std::shared_ptr<Response> Delete(const char* path);
- std::shared_ptr<Response> Delete(const char* path, const Headers& headers);
+ std::shared_ptr<Response> Head(const char *path, const Headers &headers);
- std::shared_ptr<Response> Options(const char* path);
- std::shared_ptr<Response> Options(const char* path, const Headers& headers);
+ std::shared_ptr<Response> Post(const char *path, const std::string &body,
+ const char *content_type);
- bool send(Request& req, Response& res);
+ std::shared_ptr<Response> Post(const char *path, const Headers &headers,
+ const std::string &body,
+ const char *content_type);
+
+ 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);
+
+ 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);
+
+ 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);
+
+ 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);
+
+ std::shared_ptr<Response> Delete(const char *path);
+
+ std::shared_ptr<Response> Delete(const char *path, const std::string &body,
+ const char *content_type);
+
+ std::shared_ptr<Response> Delete(const char *path, const Headers &headers);
+
+ std::shared_ptr<Response> Delete(const char *path, const Headers &headers,
+ const std::string &body,
+ const char *content_type);
+
+ std::shared_ptr<Response> Options(const char *path);
+
+ std::shared_ptr<Response> Options(const char *path, const Headers &headers);
+
+ bool send(const Request &req, Response &res);
+
+ bool send(const std::vector<Request> &requests,
+ std::vector<Response> &responses);
+
+ void set_keep_alive_max_count(size_t count);
+
+ void follow_location(bool on);
protected:
- bool process_request(Stream& strm, Request& req, Response& res, bool& connection_close);
+ bool process_request(Stream &strm, const Request &req, Response &res,
+ bool last_connection, bool &connection_close);
- const std::string host_;
- const int port_;
- size_t timeout_sec_;
- const std::string host_and_port_;
+ const std::string host_;
+ const int port_;
+ time_t timeout_sec_;
+ const std::string host_and_port_;
+ size_t keep_alive_max_count_;
+ size_t follow_location_;
private:
- socket_t create_client_socket() const;
- bool read_response_line(Stream& strm, Response& res);
- void write_request(Stream& strm, Request& req);
-
- virtual bool read_and_close_socket(socket_t sock, Request& req, Response& res);
+ socket_t create_client_socket() const;
+ bool read_response_line(Stream &strm, Response &res);
+ void write_request(Stream &strm, const Request &req, bool last_connection);
+ bool redirect(const Request &req, Response &res);
+
+ virtual bool process_and_close_socket(
+ socket_t sock, size_t request_count,
+ std::function<bool(Stream &strm, bool last_connection,
+ bool &connection_close)>
+ callback);
+
+ virtual bool is_ssl() const;
};
+inline void Get(std::vector<Request> &requests, const char *path,
+ const Headers &headers) {
+ Request req;
+ req.method = "GET";
+ req.path = path;
+ req.headers = headers;
+ requests.emplace_back(std::move(req));
+}
+
+inline void Get(std::vector<Request> &requests, const char *path) {
+ Get(requests, path, Headers());
+}
+
+inline void Post(std::vector<Request> &requests, const char *path,
+ const Headers &headers, const std::string &body,
+ const char *content_type) {
+ Request req;
+ req.method = "POST";
+ req.path = path;
+ req.headers = headers;
+ req.headers.emplace("Content-Type", content_type);
+ req.body = body;
+ requests.emplace_back(std::move(req));
+}
+
+inline void Post(std::vector<Request> &requests, const char *path,
+ const std::string &body, const char *content_type) {
+ Post(requests, path, Headers(), body, content_type);
+}
+
#ifdef CPPHTTPLIB_OPENSSL_SUPPORT
class SSLSocketStream : public Stream {
public:
- SSLSocketStream(socket_t sock, SSL* ssl);
- virtual ~SSLSocketStream();
+ SSLSocketStream(socket_t sock, SSL *ssl);
+ virtual ~SSLSocketStream();
- virtual int read(char* ptr, size_t size);
- virtual int write(const char* ptr, size_t size);
- virtual int write(const char* ptr);
- virtual std::string get_remote_addr();
+ 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);
+ virtual std::string get_remote_addr() const;
private:
- socket_t sock_;
- SSL* ssl_;
+ socket_t sock_;
+ SSL *ssl_;
};
class SSLServer : public Server {
public:
- SSLServer(
- const char* cert_path, const char* private_key_path);
+ SSLServer(const char *cert_path, const char *private_key_path,
+ const char *client_ca_cert_file_path = nullptr,
+ const char *client_ca_cert_dir_path = nullptr);
- virtual ~SSLServer();
+ virtual ~SSLServer();
- virtual bool is_valid() const;
+ virtual bool is_valid() const;
private:
- virtual bool read_and_close_socket(socket_t sock);
+ virtual bool process_and_close_socket(socket_t sock);
- SSL_CTX* ctx_;
- std::mutex ctx_mutex_;
+ SSL_CTX *ctx_;
+ std::mutex ctx_mutex_;
};
class SSLClient : public Client {
public:
- SSLClient(
- const char* host,
- int port = 80,
- size_t timeout_sec = 300);
+ SSLClient(const char *host, int port = 443, time_t timeout_sec = 300,
+ const char *client_cert_path = nullptr,
+ const char *client_key_path = nullptr);
- virtual ~SSLClient();
+ virtual ~SSLClient();
- virtual bool is_valid() const;
+ virtual bool is_valid() const;
-private:
- virtual bool read_and_close_socket(socket_t sock, Request& req, Response& res);
+ 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);
- SSL_CTX* ctx_;
- std::mutex ctx_mutex_;
+ long get_openssl_verify_result() const;
+
+ SSL_CTX* ssl_context() const noexcept;
+
+private:
+ virtual bool process_and_close_socket(
+ socket_t sock, size_t request_count,
+ std::function<bool(Stream &strm, bool last_connection,
+ bool &connection_close)>
+ callback);
+ virtual bool is_ssl() const;
+
+ 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;
+
+ SSL_CTX *ctx_;
+ std::mutex ctx_mutex_;
+ std::vector<std::string> host_components_;
+ std::string ca_cert_file_path_;
+ std::string ca_cert_dir_path_;
+ bool server_certificate_verification_ = false;
+ long verify_result_ = 0;
};
#endif
@@ -360,913 +771,1237 @@ private:
*/
namespace detail {
-template <class Fn>
-void split(const char* b, const char* e, char d, Fn fn)
-{
- int i = 0;
- int beg = 0;
+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;
+}
- while (e ? (b + i != e) : (b[i] != '\0')) {
- if (b[i] == d) {
- fn(&b[beg], &b[i]);
- beg = i + 1;
- }
- i++;
+inline bool from_hex_to_i(const std::string &s, size_t i, size_t cnt,
+ int &val) {
+ if (i >= s.size()) { return false; }
+
+ 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;
+}
+
+inline std::string from_i_to_hex(size_t n) {
+ const char *charset = "0123456789abcdef";
+ std::string ret;
+ do {
+ ret = charset[n & 15] + ret;
+ n >>= 4;
+ } while (n > 0);
+ return ret;
+}
+
+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;
+ }
+
+ // NOTREACHED
+ return 0;
+}
+
+// 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;
}
+ }
+
+ if (valb > -6) { out.push_back(lookup[((val << 8) >> (valb + 8)) & 0x3F]); }
+
+ while (out.size() % 4) {
+ out.push_back('=');
+ }
+
+ return out;
+}
- if (i) {
- fn(&b[beg], &b[i]);
+inline bool is_file(const std::string &path) {
+ struct stat st;
+ return stat(path.c_str(), &st) >= 0 && S_ISREG(st.st_mode);
+}
+
+inline bool is_dir(const std::string &path) {
+ struct stat st;
+ return stat(path.c_str(), &st) >= 0 && S_ISDIR(st.st_mode);
+}
+
+inline bool is_valid_path(const std::string &path) {
+ size_t level = 0;
+ size_t i = 0;
+
+ // Skip slash
+ while (i < path.size() && path[i] == '/') {
+ i++;
+ }
+
+ while (i < path.size()) {
+ // Read component
+ auto beg = i;
+ while (i < path.size() && path[i] != '/') {
+ i++;
}
+
+ auto len = i - beg;
+ assert(len > 0);
+
+ if (!path.compare(beg, len, ".")) {
+ ;
+ } else if (!path.compare(beg, len, "..")) {
+ if (level == 0) { return false; }
+ level--;
+ } else {
+ level++;
+ }
+
+ // Skip slash
+ while (i < path.size() && path[i] == '/') {
+ i++;
+ }
+ }
+
+ 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();
+}
+
+template <class Fn> void split(const char *b, const char *e, char d, Fn fn) {
+ int i = 0;
+ int beg = 0;
+
+ while (e ? (b + i != e) : (b[i] != '\0')) {
+ if (b[i] == d) {
+ fn(&b[beg], &b[i]);
+ beg = i + 1;
+ }
+ i++;
+ }
+
+ if (i) { fn(&b[beg], &b[i]); }
}
// NOTE: until the read size reaches `fixed_buffer_size`, use `fixed_buffer`
// to store data. The call can set memory on stack for performance.
class stream_line_reader {
public:
- 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) {
+ 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) {}
+
+ const char *ptr() const {
+ if (glowable_buffer_.empty()) {
+ return fixed_buffer_;
+ } else {
+ return glowable_buffer_.data();
}
+ }
- const char* ptr() const {
- if (glowable_buffer_.empty()) {
- return fixed_buffer_;
- } else {
- return glowable_buffer_.data();
- }
+ size_t size() const {
+ if (glowable_buffer_.empty()) {
+ return fixed_buffer_used_size_;
+ } else {
+ return glowable_buffer_.size();
}
+ }
- bool getline() {
- fixed_buffer_used_size_ = 0;
- glowable_buffer_.clear();
-
- for (size_t i = 0; ; i++) {
- char byte;
- auto n = strm_.read(&byte, 1);
-
- if (n < 0) {
- return false;
- } else if (n == 0) {
- if (i == 0) {
- return false;
- } else {
- break;
- }
- }
+ bool getline() {
+ fixed_buffer_used_size_ = 0;
+ glowable_buffer_.clear();
- append(byte);
+ for (size_t i = 0;; i++) {
+ char byte;
+ auto n = strm_.read(&byte, 1);
- if (byte == '\n') {
- break;
- }
+ if (n < 0) {
+ return false;
+ } else if (n == 0) {
+ if (i == 0) {
+ return false;
+ } else {
+ break;
}
+ }
- return true;
- }
+ append(byte);
-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;
- }
+ if (byte == '\n') { break; }
}
- Stream& strm_;
- char* fixed_buffer_;
- const size_t fixed_buffer_size_;
- size_t fixed_buffer_used_size_;
- std::string glowable_buffer_;
+ 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_;
};
-inline int close_socket(socket_t sock)
-{
+inline int close_socket(socket_t sock) {
#ifdef _WIN32
- return closesocket(sock);
+ return closesocket(sock);
#else
- return close(sock);
+ return close(sock);
#endif
}
-inline int select_read(socket_t sock, size_t sec, size_t usec)
-{
- fd_set fds;
- FD_ZERO(&fds);
- FD_SET(sock, &fds);
+inline int select_read(socket_t sock, time_t sec, time_t usec) {
+#ifdef CPPHTTPLIB_USE_POLL
+ struct pollfd pfd_read;
+ pfd_read.fd = sock;
+ pfd_read.events = POLLIN;
- timeval tv;
- tv.tv_sec = sec;
- tv.tv_usec = usec;
+ auto timeout = static_cast<int>(sec * 1000 + usec / 1000);
- return select(sock + 1, &fds, NULL, NULL, &tv);
-}
+ return poll(&pfd_read, 1, timeout);
+#else
+ fd_set fds;
+ FD_ZERO(&fds);
+ FD_SET(sock, &fds);
-inline bool wait_until_socket_is_ready(socket_t sock, size_t sec, size_t usec)
-{
- fd_set fdsr;
- FD_ZERO(&fdsr);
- FD_SET(sock, &fdsr);
+ timeval tv;
+ tv.tv_sec = static_cast<long>(sec);
+ tv.tv_usec = static_cast<long>(usec);
- auto fdsw = fdsr;
- auto fdse = fdsr;
+ return select(static_cast<int>(sock + 1), &fds, nullptr, nullptr, &tv);
+#endif
+}
- timeval tv;
- tv.tv_sec = sec;
- tv.tv_usec = usec;
+inline bool wait_until_socket_is_ready(socket_t sock, time_t sec, time_t usec) {
+#ifdef CPPHTTPLIB_USE_POLL
+ struct pollfd pfd_read;
+ pfd_read.fd = sock;
+ pfd_read.events = POLLIN | POLLOUT;
- if (select(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;
- }
+ auto timeout = static_cast<int>(sec * 1000 + usec / 1000);
- return true;
+ if (poll(&pfd_read, 1, timeout) > 0 &&
+ pfd_read.revents & (POLLIN | POLLOUT)) {
+ int error = 0;
+ socklen_t len = sizeof(error);
+ return getsockopt(sock, SOL_SOCKET, SO_ERROR, reinterpret_cast<char*>(&error), &len) >= 0 &&
+ !error;
+ }
+ return false;
+#else
+ fd_set fdsr;
+ FD_ZERO(&fdsr);
+ FD_SET(sock, &fdsr);
+
+ auto fdsw = fdsr;
+ auto fdse = fdsr;
+
+ timeval tv;
+ tv.tv_sec = static_cast<long>(sec);
+ tv.tv_usec = static_cast<long>(usec);
+
+ if (select(static_cast<int>(sock + 1), &fdsr, &fdsw, &fdse, &tv) > 0 &&
+ (FD_ISSET(sock, &fdsr) || FD_ISSET(sock, &fdsw))) {
+ int error = 0;
+ socklen_t len = sizeof(error);
+ return getsockopt(sock, SOL_SOCKET, SO_ERROR, (char *)&error, &len) >= 0 &&
+ !error;
+ }
+ return false;
+#endif
}
template <typename T>
-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;
- }
+inline bool process_and_close_socket(bool is_client_request, socket_t sock,
+ size_t keep_alive_max_count, T callback) {
+ assert(keep_alive_max_count > 0);
- count--;
- }
- } else {
- SocketStream strm(sock);
- auto dummy_connection_close = false;
- ret = callback(strm, true, dummy_connection_close);
+ bool ret = false;
+
+ if (keep_alive_max_count > 1) {
+ auto count = keep_alive_max_count;
+ while (count > 0 &&
+ (is_client_request ||
+ 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--;
}
+ } else {
+ SocketStream strm(sock);
+ auto dummy_connection_close = false;
+ ret = callback(strm, true, dummy_connection_close);
+ }
- close_socket(sock);
- return ret;
+ close_socket(sock);
+ return ret;
}
-inline int shutdown_socket(socket_t sock)
-{
+inline int shutdown_socket(socket_t sock) {
#ifdef _WIN32
- return shutdown(sock, SD_BOTH);
+ return shutdown(sock, SD_BOTH);
#else
- return shutdown(sock, SHUT_RDWR);
+ return shutdown(sock, SHUT_RDWR);
#endif
}
template <typename Fn>
-socket_t create_socket(const char* host, int port, Fn fn, int socket_flags = 0)
-{
+socket_t create_socket(const char *host, int port, Fn fn,
+ int socket_flags = 0) {
#ifdef _WIN32
#define SO_SYNCHRONOUS_NONALERT 0x20
#define SO_OPENTYPE 0x7008
- int opt = SO_SYNCHRONOUS_NONALERT;
- setsockopt(INVALID_SOCKET, SOL_SOCKET, SO_OPENTYPE, (char*)&opt, sizeof(opt));
+ int opt = SO_SYNCHRONOUS_NONALERT;
+ setsockopt(INVALID_SOCKET, SOL_SOCKET, SO_OPENTYPE, (char *)&opt,
+ sizeof(opt));
#endif
- // Get address info
- struct addrinfo hints;
- struct addrinfo *result;
+ // Get address info
+ struct addrinfo hints;
+ struct addrinfo *result;
- 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;
+ 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;
- auto service = std::to_string(port);
+ auto service = std::to_string(port);
- if (getaddrinfo(host, service.c_str(), &hints, &result)) {
- return INVALID_SOCKET;
- }
+ if (getaddrinfo(host, service.c_str(), &hints, &result)) {
+ return INVALID_SOCKET;
+ }
- for (auto rp = result; rp; rp = rp->ai_next) {
- // Create a socket
- auto sock = socket(rp->ai_family, rp->ai_socktype, rp->ai_protocol);
- if (sock == INVALID_SOCKET) {
- continue;
- }
+ for (auto rp = result; rp; rp = rp->ai_next) {
+ // Create a socket
+#ifdef _WIN32
+ auto sock = WSASocketW(rp->ai_family, rp->ai_socktype, rp->ai_protocol,
+ nullptr, 0, WSA_FLAG_NO_HANDLE_INHERIT);
+#else
+ auto sock = socket(rp->ai_family, rp->ai_socktype, rp->ai_protocol);
+#endif
+ if (sock == INVALID_SOCKET) { continue; }
- // Make 'reuse address' option available
- int yes = 1;
- setsockopt(sock, SOL_SOCKET, SO_REUSEADDR, (char*)&yes, sizeof(yes));
+#ifndef _WIN32
+ if (fcntl(sock, F_SETFD, FD_CLOEXEC) == -1) { continue; }
+#endif
- // bind or connect
- if (fn(sock, *rp)) {
- freeaddrinfo(result);
- return sock;
- }
+ // Make 'reuse address' option available
+ int yes = 1;
+ setsockopt(sock, SOL_SOCKET, SO_REUSEADDR, reinterpret_cast<char*>(&yes), sizeof(yes));
+#ifdef SO_REUSEPORT
+ setsockopt(sock, SOL_SOCKET, SO_REUSEPORT, reinterpret_cast<char*>(&yes), sizeof(yes));
+#endif
- close_socket(sock);
+ // bind or connect
+ if (fn(sock, *rp)) {
+ freeaddrinfo(result);
+ return sock;
}
- freeaddrinfo(result);
- return INVALID_SOCKET;
+ close_socket(sock);
+ }
+
+ freeaddrinfo(result);
+ return INVALID_SOCKET;
}
-inline void set_nonblocking(socket_t sock, bool nonblocking)
-{
+inline void set_nonblocking(socket_t sock, bool nonblocking) {
#ifdef _WIN32
- auto flags = nonblocking ? 1UL : 0UL;
- ioctlsocket(sock, FIONBIO, &flags);
+ auto flags = nonblocking ? 1UL : 0UL;
+ ioctlsocket(sock, FIONBIO, &flags);
#else
- auto flags = fcntl(sock, F_GETFL, 0);
- fcntl(sock, F_SETFL, nonblocking ? (flags | O_NONBLOCK) : (flags & (~O_NONBLOCK)));
+ auto flags = fcntl(sock, F_GETFL, 0);
+ fcntl(sock, F_SETFL,
+ nonblocking ? (flags | O_NONBLOCK) : (flags & (~O_NONBLOCK)));
#endif
}
-inline bool is_connection_error()
-{
+inline bool is_connection_error() {
#ifdef _WIN32
- return WSAGetLastError() != WSAEWOULDBLOCK;
+ return WSAGetLastError() != WSAEWOULDBLOCK;
#else
- return errno != EINPROGRESS;
+ return errno != EINPROGRESS;
#endif
}
inline std::string get_remote_addr(socket_t sock) {
- struct sockaddr_storage addr;
- socklen_t len = sizeof(addr);
+ struct sockaddr_storage addr;
+ socklen_t len = sizeof(addr);
+
+ if (!getpeername(sock, reinterpret_cast<struct sockaddr *>(&addr), &len)) {
+ char ipstr[NI_MAXHOST];
+
+ if (!getnameinfo(reinterpret_cast<struct sockaddr *>(&addr), len, ipstr, sizeof(ipstr),
+ nullptr, 0, NI_NUMERICHOST)) {
+ return ipstr;
+ }
+ }
+
+ return std::string();
+}
+
+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";
+ case 206: return "Partial Content";
+ 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";
+ case 413: return "Payload Too Large";
+ case 414: return "Request-URI Too Long";
+ case 415: return "Unsupported Media Type";
+ case 416: return "Range Not Satisfiable";
+
+ default:
+ case 500: return "Internal Server Error";
+ }
+}
- if (!getpeername(sock, (struct sockaddr*)&addr, &len)) {
- char ipstr[NI_MAXHOST];
+#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";
+}
- if (!getnameinfo((struct sockaddr*)&addr, len,
- ipstr, sizeof(ipstr), nullptr, 0, NI_NUMERICHOST)) {
- return ipstr;
- }
- }
+inline bool compress(std::string &content) {
+ z_stream strm;
+ strm.zalloc = Z_NULL;
+ strm.zfree = Z_NULL;
+ strm.opaque = Z_NULL;
- return std::string();
-}
+ auto ret = deflateInit2(&strm, Z_DEFAULT_COMPRESSION, Z_DEFLATED, 31, 8,
+ Z_DEFAULT_STRATEGY);
+ if (ret != Z_OK) { return false; }
-inline bool is_file(const std::string& path)
-{
- struct stat st;
- return stat(path.c_str(), &st) >= 0 && S_ISREG(st.st_mode);
-}
+ strm.avail_in = content.size();
+ strm.next_in = const_cast<Bytef*>(reinterpret_cast<const Bytef*>(content.data()));
+
+ std::string compressed;
+
+ const auto bufsiz = 16384;
+ char buff[bufsiz];
+ do {
+ strm.avail_out = bufsiz;
+ strm.next_out = reinterpret_cast<Bytef*>(buff);
+ ret = deflate(&strm, Z_FINISH);
+ assert(ret != Z_STREAM_ERROR);
+ compressed.append(buff, bufsiz - strm.avail_out);
+ } while (strm.avail_out == 0);
+
+ assert(ret == Z_STREAM_END);
+ assert(strm.avail_in == 0);
-inline bool is_dir(const std::string& path)
-{
- struct stat st;
- return stat(path.c_str(), &st) >= 0 && S_ISDIR(st.st_mode);
+ content.swap(compressed);
+
+ deflateEnd(&strm);
+ return true;
}
-inline bool is_valid_path(const std::string& path) {
- size_t level = 0;
- size_t i = 0;
+class decompressor {
+public:
+ decompressor() {
+ strm.zalloc = Z_NULL;
+ strm.zfree = Z_NULL;
+ strm.opaque = Z_NULL;
- // Skip slash
- while (i < path.size() && path[i] == '/') {
- i++;
- }
+ // 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;
+ }
- while (i < path.size()) {
- // Read component
- auto beg = i;
- while (i < path.size() && path[i] != '/') {
- i++;
- }
+ ~decompressor() { inflateEnd(&strm); }
- auto len = i - beg;
- assert(len > 0);
+ bool is_valid() const { return is_valid_; }
- if (!path.compare(beg, len, ".")) {
- ;
- } else if (!path.compare(beg, len, "..")) {
- if (level == 0) {
- return false;
- }
- level--;
- } else {
- level++;
- }
+ template <typename T>
+ bool decompress(const char *data, size_t data_length, T callback) {
+ int ret = Z_OK;
- // Skip slash
- while (i < path.size() && path[i] == '/') {
- i++;
- }
- }
+ strm.avail_in = data_length;
+ strm.next_in = const_cast<Bytef*>(reinterpret_cast<const Bytef *>(data));
- return true;
-}
+ const auto bufsiz = 16384;
+ char buff[bufsiz];
+ do {
+ strm.avail_out = bufsiz;
+ strm.next_out = reinterpret_cast<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; }
+ } while (strm.avail_out == 0);
-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);
-}
+ return ret == Z_STREAM_END;
+ }
-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();
-}
-
-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";
- 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";
- case 415: return "Unsupported Media Type";
- default:
- case 500: return "Internal Server Error";
- }
+private:
+ bool is_valid_;
+ z_stream strm;
+};
+#endif
+
+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, const char* def)
-{
- auto it = headers.find(key);
- if (it != headers.end()) {
- return it->second.c_str();
- }
- return def;
+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 int get_header_value_int(const Headers& headers, const char* key, int def)
-{
- auto it = headers.find(key);
- if (it != headers.end()) {
- return std::stoi(it->second);
- }
- return def;
+inline uint64_t get_header_value_uint64(const Headers &headers, const char *key,
+ int def = 0) {
+ auto it = headers.find(key);
+ if (it != headers.end()) {
+ return std::strtoull(it->second.data(), nullptr, 10);
+ }
+ return def;
}
-inline bool read_headers(Stream& strm, Headers& headers)
-{
- static std::regex re(R"((.+?):\s*(.+?)\s*\r\n)");
+inline bool read_headers(Stream &strm, Headers &headers) {
+ static std::regex re(R"((.+?):\s*(.+?)\s*\r\n)");
- const auto bufsiz = 2048;
- char buf[bufsiz];
+ const auto bufsiz = 2048;
+ char buf[bufsiz];
- stream_line_reader reader(strm, 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);
- }
+ 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);
}
+ }
- return true;
+ return true;
}
-inline bool read_content_with_length(Stream& strm, std::string& out, size_t len, Progress progress)
-{
- out.assign(len, 0);
- size_t r = 0;
- while (r < len){
- auto n = strm.read(&out[r], len - r);
- if (n <= 0) {
- return false;
- }
+typedef std::function<bool(const char *data, size_t data_length)>
+ ContentReceiverCore;
- r += n;
+inline bool read_content_with_length(Stream &strm, uint64_t len,
+ Progress progress,
+ ContentReceiverCore out) {
+ char buf[CPPHTTPLIB_RECV_BUFSIZ];
- if (progress) {
- progress(r, len);
- }
- }
+ uint64_t r = 0;
+ while (r < len) {
+ auto read_len = static_cast<size_t>(len - r);
+ auto n = strm.read(buf, std::min(read_len, CPPHTTPLIB_RECV_BUFSIZ));
+ if (n <= 0) { return false; }
- return true;
-}
+ if (!out(buf, n)) { return false; }
-inline bool read_content_without_length(Stream& strm, std::string& out)
-{
- for (;;) {
- char byte;
- auto n = strm.read(&byte, 1);
- if (n < 0) {
- return false;
- } else if (n == 0) {
- return true;
- }
- out += byte;
+ r += n;
+
+ if (progress) {
+ if (!progress(r, len)) { return false; }
}
+ }
- return true;
+ return true;
}
-inline bool read_content_chunked(Stream& strm, std::string& out)
-{
- const auto bufsiz = 16;
- char buf[bufsiz];
-
- stream_line_reader reader(strm, buf, bufsiz);
+inline void skip_content_with_length(Stream &strm, uint64_t len) {
+ char buf[CPPHTTPLIB_RECV_BUFSIZ];
+ uint64_t r = 0;
+ while (r < len) {
+ auto read_len = static_cast<size_t>(len - r);
+ auto n = strm.read(buf, std::min(read_len, CPPHTTPLIB_RECV_BUFSIZ));
+ if (n <= 0) { return; }
+ r += n;
+ }
+}
- if (!reader.getline()) {
- return false;
+inline bool read_content_without_length(Stream &strm, ContentReceiverCore out) {
+ char buf[CPPHTTPLIB_RECV_BUFSIZ];
+ for (;;) {
+ auto n = strm.read(buf, CPPHTTPLIB_RECV_BUFSIZ);
+ if (n < 0) {
+ return false;
+ } else if (n == 0) {
+ return true;
}
+ if (!out(buf, n)) { return false; }
+ }
- auto chunk_len = std::stoi(reader.ptr(), 0, 16);
+ return true;
+}
- while (chunk_len > 0){
- std::string chunk;
- if (!read_content_with_length(strm, chunk, chunk_len, nullptr)) {
- return false;
- }
+inline bool read_content_chunked(Stream &strm, ContentReceiverCore out) {
+ const auto bufsiz = 16;
+ char buf[bufsiz];
- if (!reader.getline()) {
- return false;
- }
+ stream_line_reader reader(strm, buf, bufsiz);
- if (strcmp(reader.ptr(), "\r\n")) {
- break;
- }
+ if (!reader.getline()) { return false; }
- out += chunk;
+ auto chunk_len = std::stoi(reader.ptr(), 0, 16);
- if (!reader.getline()) {
- return false;
- }
-
- chunk_len = std::stoi(reader.ptr(), 0, 16);
+ while (chunk_len > 0) {
+ if (!read_content_with_length(strm, chunk_len, nullptr, out)) {
+ return false;
}
- if (chunk_len == 0) {
- // Reader terminator after chunks
- if (!reader.getline() || strcmp(reader.ptr(), "\r\n"))
- return false;
- }
+ if (!reader.getline()) { return false; }
- return true;
-}
+ if (strcmp(reader.ptr(), "\r\n")) { break; }
-template <typename T>
-bool read_content(Stream& strm, T& x, Progress progress = Progress())
-{
- auto len = get_header_value_int(x.headers, "Content-Length", 0);
+ if (!reader.getline()) { return false; }
- if (len) {
- return read_content_with_length(strm, x.body, len, progress);
- } else {
- const auto& encoding = get_header_value(x.headers, "Transfer-Encoding", "");
+ chunk_len = std::stoi(reader.ptr(), 0, 16);
+ }
- if (!strcasecmp(encoding, "chunked")) {
- return read_content_chunked(strm, x.body);
- } else {
- return read_content_without_length(strm, x.body);
- }
- }
+ if (chunk_len == 0) {
+ // Reader terminator after chunks
+ if (!reader.getline() || strcmp(reader.ptr(), "\r\n")) return false;
+ }
- return true;
+ return true;
+}
+
+inline bool is_chunked_transfer_encoding(const Headers &headers) {
+ return !strcasecmp(get_header_value(headers, "Transfer-Encoding", 0, ""),
+ "chunked");
}
template <typename T>
-inline void write_headers(Stream& strm, const T& info)
-{
- for (const auto& x: info.headers) {
- strm.write_format("%s: %s\r\n", x.first.c_str(), x.second.c_str());
- }
- strm.write("\r\n");
-}
-
-inline std::string encode_url(const std::string& s)
-{
- std::string result;
-
- for (auto i = 0; s[i]; i++) {
- switch (s[i]) {
- case ' ': result += "+"; break;
- case '\'': result += "%27"; break;
- case ',': result += "%2C"; break;
- case ':': result += "%3A"; break;
- case ';': result += "%3B"; break;
- default:
- if (s[i] < 0) {
- result += '%';
- char hex[4];
- size_t len = snprintf(hex, sizeof(hex) - 1, "%02X", (unsigned char)s[i]);
- assert(len == 2);
- result.append(hex, len);
- } else {
- result += s[i];
- }
- break;
- }
- }
+bool read_content(Stream &strm, T &x, size_t payload_max_length, int &status,
+ Progress progress, ContentReceiverCore receiver) {
- return result;
-}
+ ContentReceiverCore out = [&](const char *buf, size_t n) {
+ return receiver(buf, n);
+ };
-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;
- }
+#ifdef CPPHTTPLIB_ZLIB_SUPPORT
+ detail::decompressor decompressor;
+
+ if (!decompressor.is_valid()) {
+ status = 500;
return false;
-}
+ }
+
+ 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); });
+ };
+ }
+#else
+ if (x.get_header_value("Content-Encoding") == "gzip") {
+ status = 415;
+ return false;
+ }
+#endif
-inline bool from_hex_to_i(const std::string& s, size_t i, size_t cnt, int& val)
-{
- if (i >= s.size()) {
- return false;
- }
+ auto ret = true;
+ auto exceed_payload_max_length = false;
- 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;
- }
+ if (is_chunked_transfer_encoding(x.headers)) {
+ ret = read_content_chunked(strm, out);
+ } else if (!has_header(x.headers, "Content-Length")) {
+ ret = read_content_without_length(strm, out);
+ } else {
+ auto len = get_header_value_uint64(x.headers, "Content-Length", 0);
+ if (len > payload_max_length) {
+ exceed_payload_max_length = true;
+ skip_content_with_length(strm, len);
+ ret = false;
+ } else if (len > 0) {
+ ret = read_content_with_length(strm, len, progress, out);
}
- return true;
+ }
+
+ if (!ret) { status = exceed_payload_max_length ? 413 : 400; }
+
+ return ret;
}
-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;
- }
+template <typename T>
+inline int write_headers(Stream &strm, const T &info, const Headers &headers) {
+ auto write_len = 0;
+ for (const auto &x : info.headers) {
+ auto len =
+ strm.write_format("%s: %s\r\n", x.first.c_str(), x.second.c_str());
+ if (len < 0) { return len; }
+ write_len += len;
+ }
+ for (const auto &x : headers) {
+ auto len =
+ strm.write_format("%s: %s\r\n", x.first.c_str(), x.second.c_str());
+ if (len < 0) { return len; }
+ write_len += len;
+ }
+ auto len = strm.write("\r\n");
+ if (len < 0) { return len; }
+ write_len += len;
+ return write_len;
+}
+
+inline ssize_t write_content(Stream &strm, ContentProvider content_provider,
+ size_t offset, size_t length) {
+ size_t begin_offset = offset;
+ size_t end_offset = offset + length;
+ while (offset < end_offset) {
+ ssize_t written_length = 0;
+ content_provider(
+ offset, end_offset - offset,
+ [&](const char *d, size_t l) {
+ offset += l;
+ written_length = strm.write(d, l);
+ },
+ [&](void) { written_length = -1; });
+ if (written_length < 0) { return written_length; }
+ }
+ return static_cast<ssize_t>(offset - begin_offset);
+}
+
+inline ssize_t write_content_chunked(Stream &strm,
+ ContentProvider content_provider) {
+ size_t offset = 0;
+ auto data_available = true;
+ ssize_t total_written_length = 0;
+ while (data_available) {
+ ssize_t written_length = 0;
+ content_provider(
+ offset, 0,
+ [&](const char *d, size_t l) {
+ data_available = l > 0;
+ offset += l;
+
+ // 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");
+ });
- // NOTREACHED
- return 0;
+ if (written_length < 0) { return written_length; }
+ total_written_length += written_length;
+ }
+ return total_written_length;
}
-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];
- }
- } else {
- int val = 0;
- if (from_hex_to_i(s, i + 1, 2, val)) {
- // 2 digits hex codes
- result += val;
- i += 2; // '00'
- } else {
- result += s[i];
- }
- }
- } else if (s[i] == '+') {
- result += ' ';
+template <typename T>
+inline bool redirect(T &cli, const Request &req, Response &res,
+ const std::string &path) {
+ Request new_req;
+ new_req.method = req.method;
+ new_req.path = path;
+ new_req.headers = req.headers;
+ new_req.body = req.body;
+ new_req.redirect_count = req.redirect_count - 1;
+ new_req.response_handler = req.response_handler;
+ new_req.content_receiver = req.content_receiver;
+ new_req.progress = req.progress;
+
+ Response new_res;
+ auto ret = cli.send(new_req, new_res);
+ if (ret) { res = new_res; }
+ return ret;
+}
+
+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];
+ result += s[i];
}
+ } else {
+ int val = 0;
+ if (from_hex_to_i(s, i + 1, 2, val)) {
+ // 2 digits hex codes
+ result += static_cast<char>(val);
+ i += 2; // '00'
+ } else {
+ result += s[i];
+ }
+ }
+ } else if (s[i] == '+') {
+ result += ' ';
+ } else {
+ result += s[i];
}
+ }
- return result;
+ return result;
}
-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);
- }
- });
- params.emplace(key, decode_url(val));
+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);
+ }
});
+ params.emplace(key, decode_url(val));
+ });
}
-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;
- }
+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; }
- boundary = content_type.substr(pos + 9);
- return true;
+ boundary = content_type.substr(pos + 9);
+ return true;
}
-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";
+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";
- static std::regex re_content_type(
- "Content-Type: (.*?)", std::regex_constants::icase);
+ static std::regex re_content_type("Content-Type: (.*?)",
+ std::regex_constants::icase);
- static std::regex re_content_disposition(
- "Content-Disposition: form-data; name=\"(.*?)\"(?:; filename=\"(.*?)\")?",
- std::regex_constants::icase);
+ static std::regex re_content_disposition(
+ "Content-Disposition: form-data; name=\"(.*?)\"(?:; filename=\"(.*?)\")?",
+ std::regex_constants::icase);
- auto dash_boundary = dash + boundary;
+ auto dash_boundary = dash + boundary;
- auto pos = body.find(dash_boundary);
- if (pos != 0) {
- return false;
- }
+ auto pos = body.find(dash_boundary);
+ if (pos != 0) { return false; }
- pos += dash_boundary.size();
+ pos += dash_boundary.size();
- auto next_pos = body.find(crlf, pos);
- if (next_pos == std::string::npos) {
- return false;
- }
+ auto next_pos = body.find(crlf, pos);
+ if (next_pos == std::string::npos) { return false; }
- pos = next_pos + crlf.size();
+ pos = next_pos + crlf.size();
- while (pos < body.size()) {
- next_pos = body.find(crlf, pos);
- if (next_pos == std::string::npos) {
- return false;
- }
+ while (pos < body.size()) {
+ next_pos = body.find(crlf, pos);
+ if (next_pos == std::string::npos) { return false; }
- std::string name;
- MultipartFile file;
+ std::string name;
+ MultipartFile file;
- auto header = body.substr(pos, (next_pos - pos));
+ auto header = body.substr(pos, (next_pos - pos));
- 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];
- }
+ 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];
+ }
- pos = next_pos + crlf.size();
+ pos = next_pos + crlf.size();
- next_pos = body.find(crlf, pos);
- if (next_pos == std::string::npos) {
- return false;
- }
+ next_pos = body.find(crlf, pos);
+ if (next_pos == std::string::npos) { return false; }
- header = body.substr(pos, (next_pos - pos));
- }
+ header = body.substr(pos, (next_pos - pos));
+ }
- pos = next_pos + crlf.size();
+ pos = next_pos + crlf.size();
- next_pos = body.find(crlf + dash_boundary, pos);
+ next_pos = body.find(crlf + dash_boundary, pos);
- if (next_pos == std::string::npos) {
- return false;
- }
+ if (next_pos == std::string::npos) { return false; }
- file.offset = pos;
- file.length = next_pos - pos;
+ file.offset = pos;
+ file.length = next_pos - pos;
- pos = next_pos + crlf.size() + dash_boundary.size();
+ pos = next_pos + crlf.size() + dash_boundary.size();
- next_pos = body.find(crlf, pos);
- if (next_pos == std::string::npos) {
- return false;
- }
+ next_pos = body.find(crlf, pos);
+ if (next_pos == std::string::npos) { return false; }
- files.emplace(name, file);
+ files.emplace(name, file);
- pos = next_pos + crlf.size();
- }
+ pos = next_pos + crlf.size();
+ }
- return true;
+ return true;
}
-inline std::string to_lower(const char* beg, const char* end)
-{
- std::string out;
- auto it = beg;
- while (it != end) {
- out += ::tolower(*it);
- it++;
+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)) {
+ ssize_t first = -1;
+ if (!m.str(1).empty()) {
+ first = static_cast<ssize_t>(std::stoll(m.str(1)));
+ }
+
+ ssize_t last = -1;
+ if (!m.str(2).empty()) {
+ last = static_cast<ssize_t>(std::stoll(m.str(2)));
+ }
+
+ if (first != -1 && last != -1 && first > last) {
+ throw std::runtime_error("invalid range error");
+ }
+ ranges.emplace_back(std::make_pair(first, last));
+ }
+ });
+ return true;
}
- return out;
+ return false;
+ } catch (...) { return false; }
+}
+
+inline std::string to_lower(const char *beg, const char *end) {
+ std::string out;
+ auto it = beg;
+ while (it != end) {
+ out += static_cast<char>(::tolower(*it));
+ it++;
+ }
+ return out;
}
-inline void make_range_header_core(std::string&) {}
+inline std::string make_multipart_data_boundary() {
+ static const char data[] =
+ "0123456789ABCDEFGHIJKLMNOPQRSTUVWXYZabcdefghijklmnopqrstuvwxyz";
-template<typename uint64_t>
-inline void make_range_header_core(std::string& field, uint64_t value)
-{
- if (!field.empty()) {
- field += ", ";
- }
- field += std::to_string(value) + "-";
+ std::random_device seed_gen;
+ std::mt19937 engine(seed_gen());
+
+ std::string result = "--cpp-httplib-multipart-data-";
+
+ for (auto i = 0; i < 16; i++) {
+ result += data[engine() % (sizeof(data) - 1)];
+ }
+
+ return result;
}
-template<typename uint64_t, typename... Args>
-inline void make_range_header_core(std::string& field, uint64_t value1, uint64_t value2, Args... args)
-{
- if (!field.empty()) {
- field += ", ";
- }
- field += std::to_string(value1) + "-" + std::to_string(value2);
- make_range_header_core(field, args...);
+inline std::pair<size_t, size_t>
+get_range_offset_and_length(const Request &req, size_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);
}
-#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 void compress(std::string& content)
-{
- z_stream strm;
- strm.zalloc = Z_NULL;
- strm.zfree = Z_NULL;
- strm.opaque = Z_NULL;
+inline std::string make_content_range_header_field(size_t offset, size_t length,
+ size_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;
+}
- auto ret = deflateInit2(&strm, Z_DEFAULT_COMPRESSION, Z_DEFLATED, 31, 8, Z_DEFAULT_STRATEGY);
- if (ret != Z_OK) {
- return;
+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");
}
- strm.avail_in = content.size();
- strm.next_in = (Bytef *)content.data();
+ auto offsets = detail::get_range_offset_and_length(req, res.body.size(), i);
+ auto offset = offsets.first;
+ auto length = offsets.second;
- std::string compressed;
+ 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");
+ }
- const auto bufsiz = 16384;
- char buff[bufsiz];
- do {
- strm.avail_out = bufsiz;
- strm.next_out = (Bytef *)buff;
- deflate(&strm, Z_FINISH);
- compressed.append(buff, bufsiz - strm.avail_out);
- } while (strm.avail_out == 0);
+ ctoken("--");
+ stoken(boundary);
+ ctoken("--\r\n");
+
+ return true;
+}
- content.swap(compressed);
+inline std::string make_multipart_ranges_data(const Request &req, Response &res,
+ const std::string &boundary,
+ const std::string &content_type) {
+ std::string data;
- deflateEnd(&strm);
+ process_multipart_ranges_data(
+ req, res, boundary, content_type,
+ [&](const std::string &token) { data += token; },
+ [&](const char *token) { data += token; },
+ [&](size_t offset, size_t length) {
+ data += res.body.substr(offset, length);
+ return true;
+ });
+
+ return data;
}
-inline void decompress(std::string& content)
-{
- z_stream strm;
- strm.zalloc = Z_NULL;
- strm.zfree = Z_NULL;
- strm.opaque = Z_NULL;
+inline size_t
+get_multipart_ranges_data_length(const Request &req, Response &res,
+ const std::string &boundary,
+ const std::string &content_type) {
+ size_t data_length = 0;
- // 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.
- auto ret = inflateInit2(&strm, 16 + 15);
- if (ret != Z_OK) {
- return;
- }
+ process_multipart_ranges_data(
+ req, res, boundary, content_type,
+ [&](const std::string &token) { data_length += token.size(); },
+ [&](const char *token) { data_length += strlen(token); },
+ [&](size_t /*offset*/, size_t length) {
+ data_length += length;
+ return true;
+ });
- strm.avail_in = content.size();
- strm.next_in = (Bytef *)content.data();
+ return data_length;
+}
- std::string decompressed;
+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); },
+ [&](size_t offset, size_t length) {
+ return detail::write_content(strm, res.content_provider, offset,
+ length) >= 0;
+ });
+}
- const auto bufsiz = 16384;
- char buff[bufsiz];
- do {
- strm.avail_out = bufsiz;
- strm.next_out = (Bytef *)buff;
- inflate(&strm, Z_NO_FLUSH);
- decompressed.append(buff, bufsiz - strm.avail_out);
- } while (strm.avail_out == 0);
+inline std::pair<size_t, size_t>
+get_range_offset_and_length(const Request &req, const Response &res,
+ size_t index) {
+ auto r = req.ranges[index];
- content.swap(decompressed);
+ if (r.second == -1) { r.second = res.content_provider_resource_length - 1; }
- inflateEnd(&strm);
+ return std::make_pair(r.first, r.second - r.first + 1);
}
-#endif
#ifdef _WIN32
class WSInit {
public:
- WSInit() {
- WSADATA wsaData;
- WSAStartup(0x0002, &wsaData);
- }
+ WSInit() {
+ WSADATA wsaData;
+ WSAStartup(0x0002, &wsaData);
+ }
- ~WSInit() {
- WSACleanup();
- }
+ ~WSInit() { WSACleanup(); }
};
static WSInit wsinit_;
@@ -1275,876 +2010,1273 @@ static WSInit wsinit_;
} // namespace detail
// Header utilities
-template<typename uint64_t, typename... Args>
-inline std::pair<std::string, std::string> make_range_header(uint64_t value, Args... args)
-{
- std::string field;
- detail::make_range_header_core(field, value, args...);
- field.insert(0, "bytes=");
- return std::make_pair("Range", field);
+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++;
+ }
+ return std::make_pair("Range", field);
+}
+
+inline std::pair<std::string, std::string>
+make_basic_authentication_header(const std::string &username,
+ const std::string &password) {
+ auto field = "Basic " + detail::base64_encode(username + ":" + password);
+ return std::make_pair("Authorization", field);
}
// Request implementation
-inline bool Request::has_header(const char* key) const
-{
- return headers.find(key) != headers.end();
+inline bool Request::has_header(const char *key) const {
+ return detail::has_header(headers, key);
}
-inline std::string Request::get_header_value(const char* key) const
-{
- return detail::get_header_value(headers, key, "");
+inline std::string Request::get_header_value(const char *key, size_t id) const {
+ return detail::get_header_value(headers, key, id, "");
}
-inline void Request::set_header(const char* key, const char* val)
-{
- headers.emplace(key, val);
+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);
}
-inline bool Request::has_param(const char* key) const
-{
- return params.find(key) != params.end();
+inline void Request::set_header(const char *key, const char *val) {
+ headers.emplace(key, val);
}
-inline std::string Request::get_param_value(const char* key) const
-{
- auto it = params.find(key);
- if (it != params.end()) {
- return it->second;
- }
- return std::string();
+inline void Request::set_header(const char *key, const std::string &val) {
+ headers.emplace(key, val);
}
-inline bool Request::has_file(const char* key) const
-{
- return files.find(key) != files.end();
+inline bool Request::has_param(const char *key) const {
+ return params.find(key) != params.end();
}
-inline MultipartFile Request::get_file_value(const char* key) const
-{
- auto it = files.find(key);
- if (it != files.end()) {
- return it->second;
- }
- return MultipartFile();
+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();
+}
+
+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);
+}
+
+inline bool Request::has_file(const char *key) const {
+ return files.find(key) != files.end();
+}
+
+inline MultipartFile Request::get_file_value(const char *key) const {
+ auto it = files.find(key);
+ if (it != files.end()) { return it->second; }
+ return MultipartFile();
}
// Response implementation
-inline bool Response::has_header(const char* key) const
-{
- return headers.find(key) != headers.end();
+inline bool Response::has_header(const char *key) const {
+ return headers.find(key) != headers.end();
+}
+
+inline std::string Response::get_header_value(const char *key,
+ size_t id) const {
+ return detail::get_header_value(headers, key, id, "");
+}
+
+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);
}
-inline std::string Response::get_header_value(const char* key) const
-{
- return detail::get_header_value(headers, key, "");
+inline void Response::set_header(const char *key, const char *val) {
+ headers.emplace(key, val);
}
-inline void Response::set_header(const char* key, const char* val)
-{
- headers.emplace(key, val);
+inline void Response::set_header(const char *key, const std::string &val) {
+ headers.emplace(key, val);
}
-inline void Response::set_redirect(const char* url)
-{
- set_header("Location", url);
- status = 302;
+inline void Response::set_redirect(const char *url) {
+ set_header("Location", url);
+ status = 302;
}
-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);
+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);
}
-inline void Response::set_content(const std::string& s, const char* content_type)
-{
- body = s;
- set_header("Content-Type", content_type);
+inline void Response::set_content(const std::string &s,
+ const char *content_type) {
+ body = s;
+ set_header("Content-Type", content_type);
+}
+
+inline void Response::set_content_provider(
+ size_t length,
+ std::function<void(size_t offset, size_t length, DataSink sink)> provider,
+ std::function<void()> resource_releaser) {
+ assert(length > 0);
+ content_provider_resource_length = length;
+ content_provider = [provider](size_t offset, size_t length, DataSink sink,
+ Done) { provider(offset, length, sink); };
+ content_provider_resource_releaser = resource_releaser;
+}
+
+inline void Response::set_chunked_content_provider(
+ std::function<void(size_t offset, DataSink sink, Done done)> provider,
+ std::function<void()> resource_releaser) {
+ content_provider_resource_length = 0;
+ content_provider = [provider](size_t offset, size_t, DataSink sink,
+ Done done) { provider(offset, sink, done); };
+ content_provider_resource_releaser = resource_releaser;
}
// Rstream implementation
-template <typename ...Args>
-inline void Stream::write_format(const char* fmt, const Args& ...args)
-{
- const auto bufsiz = 2048;
- char buf[bufsiz];
+template <typename... Args>
+inline int Stream::write_format(const char *fmt, const Args &... args) {
+ const auto bufsiz = 2048;
+ char buf[bufsiz];
#if defined(_MSC_VER) && _MSC_VER < 1900
- auto n = _snprintf_s(buf, bufsiz, bufsiz - 1, fmt, args...);
+ auto n = _snprintf_s(buf, bufsiz, bufsiz - 1, fmt, args...);
#else
- auto n = snprintf(buf, bufsiz - 1, fmt, args...);
+ auto n = snprintf(buf, bufsiz - 1, fmt, args...);
#endif
- if (n > 0) {
- if (n >= bufsiz - 1) {
- std::vector<char> glowable_buf(bufsiz);
+ if (n <= 0) { return n; }
+
+ 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);
+ while (n >= static_cast<int>(glowable_buf.size() - 1)) {
+ glowable_buf.resize(glowable_buf.size() * 2);
#if defined(_MSC_VER) && _MSC_VER < 1900
- n = _snprintf_s(&glowable_buf[0], glowable_buf.size(), glowable_buf.size() - 1, fmt, args...);
+ n = _snprintf_s(&glowable_buf[0], glowable_buf.size(),
+ glowable_buf.size() - 1, fmt, args...);
#else
- n = snprintf(&glowable_buf[0], glowable_buf.size() - 1, fmt, args...);
+ n = snprintf(&glowable_buf[0], glowable_buf.size() - 1, fmt, args...);
#endif
- }
- write(&glowable_buf[0], n);
- } else {
- write(buf, n);
- }
}
+ return write(&glowable_buf[0], n);
+ } else {
+ return write(buf, n);
+ }
}
// Socket stream implementation
-inline SocketStream::SocketStream(socket_t sock): sock_(sock)
-{
+inline SocketStream::SocketStream(socket_t sock) : sock_(sock) {}
+
+inline SocketStream::~SocketStream() {}
+
+inline int SocketStream::read(char *ptr, size_t size) {
+ 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;
+}
+
+inline int SocketStream::write(const char *ptr, size_t size) {
+ return send(sock_, ptr, static_cast<int>(size), 0);
}
-inline SocketStream::~SocketStream()
-{
+inline int SocketStream::write(const char *ptr) {
+ return write(ptr, strlen(ptr));
}
-inline int SocketStream::read(char* ptr, size_t size)
-{
- return recv(sock_, ptr, size, 0);
+inline int SocketStream::write(const std::string &s) {
+ return write(s.data(), s.size());
}
-inline int SocketStream::write(const char* ptr, size_t size)
-{
- return send(sock_, ptr, size, 0);
+inline std::string SocketStream::get_remote_addr() const {
+ return detail::get_remote_addr(sock_);
}
-inline int SocketStream::write(const char* ptr)
-{
- return write(ptr, strlen(ptr));
+// Buffer stream implementation
+inline int BufferStream::read(char *ptr, size_t size) {
+#if defined(_MSC_VER) && _MSC_VER < 1900
+ return static_cast<int>(buffer._Copy_s(ptr, size, size));
+#else
+ return static_cast<int>(buffer.copy(ptr, size));
+#endif
}
-inline std::string SocketStream::get_remote_addr() {
- return detail::get_remote_addr(sock_);
+inline int BufferStream::write(const char *ptr, size_t size) {
+ buffer.append(ptr, size);
+ return static_cast<int>(size);
}
+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());
+}
+
+inline std::string BufferStream::get_remote_addr() const { return ""; }
+
+inline const std::string &BufferStream::get_buffer() const { return buffer; }
+
// HTTP server implementation
inline Server::Server()
- : keep_alive_max_count_(5)
- , is_running_(false)
- , svr_sock_(INVALID_SOCKET)
- , running_threads_(0)
-{
+ : keep_alive_max_count_(CPPHTTPLIB_KEEPALIVE_MAX_COUNT),
+ payload_max_length_(CPPHTTPLIB_PAYLOAD_MAX_LENGTH), is_running_(false),
+ svr_sock_(INVALID_SOCKET) {
#ifndef _WIN32
- signal(SIGPIPE, SIG_IGN);
+ signal(SIGPIPE, SIG_IGN);
#endif
+ new_task_queue = [] {
+#if CPPHTTPLIB_THREAD_POOL_COUNT > 0
+ return new ThreadPool(CPPHTTPLIB_THREAD_POOL_COUNT);
+#else
+ return new Threads();
+#endif
+ };
}
-inline Server::~Server()
-{
-}
+inline Server::~Server() {}
-inline Server& Server::Get(const char* pattern, Handler handler)
-{
- get_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
- return *this;
+inline Server &Server::Get(const char *pattern, Handler handler) {
+ get_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
+ return *this;
}
-inline Server& Server::Post(const char* pattern, Handler handler)
-{
- post_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
- return *this;
+inline Server &Server::Post(const char *pattern, Handler handler) {
+ post_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
+ return *this;
}
-inline Server& Server::Put(const char* pattern, Handler handler)
-{
- put_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
- return *this;
+inline Server &Server::Put(const char *pattern, Handler handler) {
+ put_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
+ return *this;
}
-inline Server& Server::Delete(const char* pattern, Handler handler)
-{
- delete_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
- return *this;
+inline Server &Server::Patch(const char *pattern, Handler handler) {
+ patch_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
+ return *this;
}
-inline Server& Server::Options(const char* pattern, Handler handler)
-{
- options_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
- return *this;
+inline Server &Server::Delete(const char *pattern, Handler handler) {
+ delete_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
+ return *this;
}
-inline bool Server::set_base_dir(const char* path)
-{
- if (detail::is_dir(path)) {
- base_dir_ = path;
- return true;
- }
- return false;
+inline Server &Server::Options(const char *pattern, Handler handler) {
+ options_handlers_.push_back(std::make_pair(std::regex(pattern), handler));
+ return *this;
}
-inline void Server::set_error_handler(Handler handler)
-{
- error_handler_ = handler;
+inline bool Server::set_base_dir(const char *path) {
+ if (detail::is_dir(path)) {
+ base_dir_ = path;
+ return true;
+ }
+ return false;
}
-inline void Server::set_logger(Logger logger)
-{
- logger_ = logger;
+inline void Server::set_file_request_handler(Handler handler) {
+ file_request_handler_ = handler;
}
-inline void Server::set_keep_alive_max_count(size_t count)
-{
- keep_alive_max_count_ = count;
+inline void Server::set_error_handler(Handler handler) {
+ error_handler_ = handler;
}
-inline int Server::bind_to_any_port(const char* host, int socket_flags)
-{
- return bind_internal(host, 0, socket_flags);
+inline void Server::set_logger(Logger logger) { logger_ = logger; }
+
+inline void Server::set_keep_alive_max_count(size_t count) {
+ keep_alive_max_count_ = count;
}
-inline bool Server::listen_after_bind() {
- return listen_internal();
+inline void Server::set_payload_max_length(size_t length) {
+ payload_max_length_ = length;
}
-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();
+inline int Server::bind_to_any_port(const char *host, int socket_flags) {
+ return bind_internal(host, 0, socket_flags);
}
-inline bool Server::is_running() const
-{
- return is_running_;
+inline bool Server::listen_after_bind() { return listen_internal(); }
+
+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();
}
-inline void Server::stop()
-{
- if (is_running_) {
- assert(svr_sock_ != INVALID_SOCKET);
- detail::shutdown_socket(svr_sock_);
- detail::close_socket(svr_sock_);
- svr_sock_ = INVALID_SOCKET;
- }
+inline bool Server::is_running() const { return is_running_; }
+
+inline void Server::stop() {
+ if (is_running_) {
+ assert(svr_sock_ != INVALID_SOCKET);
+ std::atomic<socket_t> sock(svr_sock_.exchange(INVALID_SOCKET));
+ detail::shutdown_socket(sock);
+ detail::close_socket(sock);
+ }
}
-inline bool Server::parse_request_line(const char* s, Request& req)
-{
- static std::regex re("(GET|HEAD|POST|PUT|DELETE|OPTIONS) (([^?]+)(?:\\?(.+?))?) (HTTP/1\\.[01])\r\n");
+inline bool Server::parse_request_line(const char *s, Request &req) {
+ static std::regex re("(GET|HEAD|POST|PUT|DELETE|CONNECT|OPTIONS|TRACE|PATCH|PRI) "
+ "(([^?]+)(?:\\?(.+?))?) (HTTP/1\\.[01])\r\n");
- std::cmatch m;
- if (std::regex_match(s, m, re)) {
- req.version = std::string(m[4]);
- req.method = std::string(m[1]);
- req.target = std::string(m[2]);
- req.path = detail::decode_url(m[3]);
-
- // Parse query text
- auto len = std::distance(m[4].first, m[4].second);
- if (len > 0) {
- detail::parse_query_text(m[4], req.params);
- }
+ 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]);
- return true;
- }
+ // Parse query text
+ auto len = std::distance(m[4].first, m[4].second);
+ if (len > 0) { detail::parse_query_text(m[4], req.params); }
- return false;
-}
+ return true;
+ }
-inline void Server::write_response(Stream& strm, bool last_connection, const Request& req, Response& res)
-{
- assert(res.status != -1);
+ return false;
+}
- if (400 <= res.status && error_handler_) {
- error_handler_(req, res);
- }
+inline bool Server::write_response(Stream &strm, bool last_connection,
+ const Request &req, Response &res) {
+ assert(res.status != -1);
- // Response line
- strm.write_format("HTTP/1.1 %d %s\r\n",
- res.status,
- detail::status_message(res.status));
+ if (400 <= res.status && error_handler_) { error_handler_(req, res); }
- // Headers
- if (last_connection ||
- req.version == "HTTP/1.0" ||
- req.get_header_value("Connection") == "close") {
- res.set_header("Connection", "close");
+ // Response line
+ if (!strm.write_format("HTTP/1.1 %d %s\r\n", res.status,
+ detail::status_message(res.status))) {
+ return false;
+ }
+
+ // Headers
+ if (last_connection || req.get_header_value("Connection") == "close") {
+ res.set_header("Connection", "close");
+ }
+
+ 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);
+ }
+
+ if (res.body.empty()) {
+ if (res.content_provider_resource_length > 0) {
+ size_t length = 0;
+ if (req.ranges.empty()) {
+ length = res.content_provider_resource_length;
+ } else if (req.ranges.size() == 1) {
+ 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) {
+ 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);
}
- if (!res.body.empty()) {
#ifdef CPPHTTPLIB_ZLIB_SUPPORT
- // 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"))) {
- detail::compress(res.body);
- res.set_header("Content-Encoding", "gzip");
- }
+ // 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");
+ }
+ }
#endif
- if (!res.has_header("Content-Type")) {
- res.set_header("Content-Type", "text/plain");
- }
+ auto length = std::to_string(res.body.size());
+ res.set_header("Content-Length", length);
+ }
+
+ if (!detail::write_headers(strm, res, Headers())) { return false; }
- auto length = std::to_string(res.body.size());
- res.set_header("Content-Length", length.c_str());
+ // 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;
+ }
}
+ }
- detail::write_headers(strm, res);
+ // Log
+ if (logger_) { logger_(req, res); }
- // Body
- if (!res.body.empty() && req.method != "HEAD") {
- strm.write(res.body.c_str(), res.body.size());
- }
+ return true;
+}
- // Log
- if (logger_) {
- logger_(req, res);
+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) {
+ 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;
}
-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;
+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;
- if (!path.empty() && path.back() == '/') {
- path += "index.html";
- }
+ if (!path.empty() && path.back() == '/') { path += "index.html"; }
- 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;
- return true;
- }
+ 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;
+ if (file_request_handler_) { file_request_handler_(req, res); }
+ return true;
}
+ }
- return false;
+ return false;
}
-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, ai.ai_addrlen)) {
- return false;
- }
- if (::listen(sock, 5)) { // Listen through 5 channels
- return false;
- }
- return true;
- }, socket_flags);
-}
-
-inline int Server::bind_internal(const char* host, int port, int socket_flags)
-{
- if (!is_valid()) {
- return -1;
- }
-
- svr_sock_ = create_server_socket(host, port, socket_flags);
- if (svr_sock_ == INVALID_SOCKET) {
- return -1;
- }
-
- 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;
+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;
}
- 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;
+ if (::listen(sock, 5)) { // Listen through 5 channels
+ return false;
}
+ return true;
+ },
+ socket_flags);
+}
+
+inline int Server::bind_internal(const char *host, int port, int socket_flags) {
+ if (!is_valid()) { return -1; }
+
+ svr_sock_ = create_server_socket(host, port, socket_flags);
+ if (svr_sock_ == INVALID_SOCKET) { return -1; }
+
+ 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 port;
+ return -1;
}
+ } else {
+ return port;
+ }
}
-inline bool Server::listen_internal()
-{
- auto ret = true;
+inline bool Server::listen_internal() {
+ auto ret = true;
+ is_running_ = true;
- is_running_ = true;
+ {
+ std::unique_ptr<TaskQueue> task_queue(new_task_queue());
for (;;) {
- auto val = detail::select_read(svr_sock_, 0, 100000);
+ if (svr_sock_ == INVALID_SOCKET) {
+ // The server socket was closed by 'stop' method.
+ break;
+ }
- if (val == 0) { // Timeout
- if (svr_sock_ == INVALID_SOCKET) {
- // The server socket was closed by 'stop' method.
- break;
- }
- continue;
- }
+ auto val = detail::select_read(svr_sock_, 0, 100000);
- socket_t sock = accept(svr_sock_, NULL, NULL);
+ if (val == 0) { // Timeout
+ continue;
+ }
- 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;
+ socket_t sock = accept(svr_sock_, nullptr, nullptr);
+
+ if (sock == INVALID_SOCKET) {
+ if (errno == EMFILE) {
+ // The per-process limit of open file descriptors has been reached.
+ // Try to accept new connections after a short sleep.
+ std::this_thread::sleep_for(std::chrono::milliseconds(1));
+ continue;
+ }
+ if (svr_sock_ != INVALID_SOCKET) {
+ detail::close_socket(svr_sock_);
+ ret = false;
+ } else {
+ ; // The server socket was closed by user.
}
+ break;
+ }
- // TODO: Use thread pool...
- std::thread([=]() {
- {
- std::lock_guard<std::mutex> guard(running_threads_mutex_);
- running_threads_++;
- }
+ task_queue->enqueue([=]() { process_and_close_socket(sock); });
+ }
- read_and_close_socket(sock);
+ task_queue->shutdown();
+ }
- {
- std::lock_guard<std::mutex> guard(running_threads_mutex_);
- running_threads_--;
- }
- }).detach();
+ is_running_ = false;
+ return ret;
+}
+
+inline bool Server::routing(Request &req, Response &res) {
+ if (req.method == "GET" && handle_file_request(req, res)) { return true; }
+
+ 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 == "DELETE") {
+ return dispatch_request(req, res, delete_handlers_);
+ } else if (req.method == "OPTIONS") {
+ return dispatch_request(req, res, options_handlers_);
+ } else if (req.method == "PATCH") {
+ return dispatch_request(req, res, patch_handlers_);
+ }
+
+ res.status = 400;
+ return false;
+}
+
+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;
+
+ if (std::regex_match(req.path, req.matches, pattern)) {
+ handler(req, res);
+ return true;
+ }
+ }
+ return false;
+}
+
+inline bool
+Server::process_request(Stream &strm, bool last_connection,
+ bool &connection_close,
+ std::function<void(Request &)> setup_request) {
+ const auto bufsiz = 2048;
+ char buf[bufsiz];
+
+ detail::stream_line_reader reader(strm, buf, bufsiz);
+
+ // Connection has been closed on client
+ if (!reader.getline()) { return false; }
+
+ Request req;
+ Response res;
+
+ res.version = "HTTP/1.1";
+
+ // Check if the request URI doesn't exceed the limit
+ if (reader.size() > CPPHTTPLIB_REQUEST_URI_MAX_LENGTH) {
+ Headers dummy;
+ detail::read_headers(strm, dummy);
+ res.status = 414;
+ return write_response(strm, last_connection, req, res);
+ }
+
+ // Request line and headers
+ if (!parse_request_line(reader.ptr(), req) ||
+ !detail::read_headers(strm, req.headers)) {
+ res.status = 400;
+ return write_response(strm, last_connection, req, res);
+ }
+
+ if (req.get_header_value("Connection") == "close") {
+ connection_close = true;
+ }
+
+ 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());
+
+ // Body
+ if (req.method == "POST" || req.method == "PUT" || req.method == "PATCH" || req.method == "PRI") {
+ if (!detail::read_content(strm, req, payload_max_length_, res.status,
+ Progress(), [&](const char *buf, size_t n) {
+ if (req.body.size() + n > req.body.max_size()) {
+ return false;
+ }
+ req.body.append(buf, n);
+ return true;
+ })) {
+ return write_response(strm, last_connection, req, res);
}
- // TODO: Use thread pool...
- for (;;) {
- std::this_thread::sleep_for(std::chrono::milliseconds(10));
- std::lock_guard<std::mutex> guard(running_threads_mutex_);
- if (!running_threads_) {
- break;
- }
+ const auto &content_type = req.get_header_value("Content-Type");
+
+ 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;
+ return write_response(strm, last_connection, req, res);
+ }
+ }
+ }
+
+ 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
}
+ }
- is_running_ = false;
+ if (setup_request) { setup_request(req); }
- return ret;
+ if (routing(req, res)) {
+ if (res.status == -1) { res.status = req.ranges.empty() ? 200 : 206; }
+ } else {
+ if (res.status == -1) { res.status = 404; }
+ }
+
+ return write_response(strm, last_connection, req, res);
}
-inline bool Server::routing(Request& req, Response& res)
-{
- if (req.method == "GET" && handle_file_request(req, res)) {
- return true;
- }
+inline bool Server::is_valid() const { return true; }
- 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 == "DELETE") {
- return dispatch_request(req, res, delete_handlers_);
- } else if (req.method == "OPTIONS") {
- return dispatch_request(req, res, options_handlers_);
- }
- return false;
+inline bool Server::process_and_close_socket(socket_t sock) {
+ return detail::process_and_close_socket(
+ false, sock, keep_alive_max_count_,
+ [this](Stream &strm, bool last_connection, bool &connection_close) {
+ return process_request(strm, last_connection, connection_close,
+ nullptr);
+ });
}
-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;
-
- if (std::regex_match(req.path, req.matches, pattern)) {
- handler(req, res);
- return true;
+// HTTP client implementation
+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_)),
+ keep_alive_max_count_(CPPHTTPLIB_KEEPALIVE_MAX_COUNT),
+ follow_location_(false) {}
+
+inline Client::~Client() {}
+
+inline bool Client::is_valid() const { return true; }
+
+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);
+
+ 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;
+ }
}
- }
- return false;
-}
-inline bool Server::process_request(Stream& strm, bool last_connection, bool& connection_close)
-{
- const auto bufsiz = 2048;
- char buf[bufsiz];
+ detail::set_nonblocking(sock, false);
+ return true;
+ });
+}
- detail::stream_line_reader reader(strm, buf, bufsiz);
+inline bool Client::read_response_line(Stream &strm, Response &res) {
+ const auto bufsiz = 2048;
+ char buf[bufsiz];
- // Connection has been closed on client
- if (!reader.getline()) {
- return false;
- }
+ detail::stream_line_reader reader(strm, buf, bufsiz);
- Request req;
- Response res;
+ if (!reader.getline()) { return false; }
- res.version = "HTTP/1.1";
+ const static std::regex re("(HTTP/1\\.[01]) (\\d+?) .*\r\n");
- // Request line and headers
- if (!parse_request_line(reader.ptr(), req) || !detail::read_headers(strm, req.headers)) {
- res.status = 400;
- write_response(strm, last_connection, req, res);
- return true;
- }
+ 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]));
+ }
- auto ret = true;
- if (req.get_header_value("Connection") == "close") {
- // ret = false;
- connection_close = true;
- }
+ return true;
+}
- req.set_header("REMOTE_ADDR", strm.get_remote_addr().c_str());
+inline bool Client::send(const Request &req, Response &res) {
+ if (req.path.empty()) { return false; }
- // Body
- if (req.method == "POST" || req.method == "PUT") {
- if (!detail::read_content(strm, req)) {
- res.status = 400;
- write_response(strm, last_connection, req, res);
- return ret;
- }
+ auto sock = create_client_socket();
+ if (sock == INVALID_SOCKET) { return false; }
- const auto& content_type = req.get_header_value("Content-Type");
+ auto ret = process_and_close_socket(
+ sock, 1, [&](Stream &strm, bool last_connection, bool &connection_close) {
+ return process_request(strm, req, res, last_connection,
+ connection_close);
+ });
- if (req.get_header_value("Content-Encoding") == "gzip") {
-#ifdef CPPHTTPLIB_ZLIB_SUPPORT
- detail::decompress(req.body);
-#else
- res.status = 415;
- write_response(strm, last_connection, req, res);
- return ret;
-#endif
- }
+ if (ret && follow_location_ && (300 < res.status && res.status < 400)) {
+ ret = redirect(req, res);
+ }
- 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;
- write_response(strm, last_connection, req, res);
- return ret;
- }
- }
- }
+ return ret;
+}
- if (routing(req, res)) {
- if (res.status == -1) {
- res.status = 200;
- }
- } else {
- res.status = 404;
- }
+inline bool Client::send(const std::vector<Request> &requests,
+ std::vector<Response> &responses) {
+ size_t i = 0;
+ while (i < requests.size()) {
+ auto sock = create_client_socket();
+ if (sock == INVALID_SOCKET) { return false; }
- write_response(strm, last_connection, req, res);
- return ret;
-}
+ if (!process_and_close_socket(
+ sock, requests.size() - i,
+ [&](Stream &strm, bool last_connection, bool &connection_close) -> bool {
+ auto &req = requests[i];
+ auto res = Response();
+ i++;
-inline bool Server::is_valid() const
-{
- return true;
-}
+ if (req.path.empty()) { return false; }
+ auto ret = process_request(strm, req, res, last_connection,
+ connection_close);
-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);
- });
-}
+ if (ret && follow_location_ &&
+ (300 < res.status && res.status < 400)) {
+ ret = redirect(req, res);
+ }
-// HTTP client implementation
-inline Client::Client(
- const char* host, int port, size_t timeout_sec)
- : host_(host)
- , port_(port)
- , timeout_sec_(timeout_sec)
- , host_and_port_(host_ + ":" + std::to_string(port_))
-{
-}
+ if (ret) { responses.emplace_back(std::move(res)); }
-inline Client::~Client()
-{
-}
+ return ret;
+ })) {
+ return false;
+ }
+ }
-inline bool Client::is_valid() const
-{
- return true;
+ return true;
}
-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);
+inline bool Client::redirect(const Request &req, Response &res) {
+ if (req.redirect_count == 0) { return false; }
- auto ret = connect(sock, ai.ai_addr, 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;
- }
- }
+ auto location = res.get_header_value("location");
+ if (location.empty()) { return false; }
- detail::set_nonblocking(sock, false);
- return true;
- });
-}
+ std::regex re(
+ R"(^(?:([^:/?#]+):)?(?://([^/?#]*))?([^?#]*(?:\?[^#]*)?)(?:#.*)?)");
-inline bool Client::read_response_line(Stream& strm, Response& res)
-{
- const auto bufsiz = 2048;
- char buf[bufsiz];
+ auto scheme = is_ssl() ? "https" : "http";
- detail::stream_line_reader reader(strm, buf, bufsiz);
+ std::smatch m;
+ if (regex_match(location, m, re)) {
+ auto next_scheme = m[1].str();
+ auto next_host = m[2].str();
+ auto next_path = m[3].str();
+ if (next_host.empty()) { next_host = host_; }
+ if (next_path.empty()) { next_path = "/"; }
- if (!reader.getline()) {
+ if (next_scheme == scheme && next_host == host_) {
+ return detail::redirect(*this, req, res, next_path);
+ } else {
+ if (next_scheme == "https") {
+#ifdef CPPHTTPLIB_OPENSSL_SUPPORT
+ SSLClient cli(next_host.c_str());
+ cli.follow_location(true);
+ return detail::redirect(cli, req, res, next_path);
+#else
return false;
+#endif
+ } else {
+ Client cli(next_host.c_str());
+ cli.follow_location(true);
+ return detail::redirect(cli, req, res, next_path);
+ }
}
+ }
+ return false;
+}
- const static std::regex re("(HTTP/1\\.[01]) (\\d+?) .+\r\n");
+inline void Client::write_request(Stream &strm, const Request &req,
+ bool last_connection) {
+ BufferStream bstrm;
- 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]));
+ // Request line
+ auto path = detail::encode_url(req.path);
+
+ bstrm.write_format("%s %s HTTP/1.1\r\n", req.method.c_str(), path.c_str());
+
+ // Additonal headers
+ Headers headers;
+ if (last_connection) { headers.emplace("Connection", "close"); }
+
+ if (!req.has_header("Host")) {
+ if (is_ssl()) {
+ if (port_ == 443) {
+ headers.emplace("Host", host_);
+ } else {
+ headers.emplace("Host", host_and_port_);
+ }
+ } else {
+ if (port_ == 80) {
+ headers.emplace("Host", host_);
+ } else {
+ headers.emplace("Host", host_and_port_);
+ }
}
+ }
- return true;
-}
+ if (!req.has_header("Accept")) { headers.emplace("Accept", "*/*"); }
-inline bool Client::send(Request& req, Response& res)
-{
- if (req.path.empty()) {
- return false;
+ if (!req.has_header("User-Agent")) {
+ headers.emplace("User-Agent", "cpp-httplib/0.2");
+ }
+
+ if (req.body.empty()) {
+ if (req.method == "POST" || req.method == "PUT" || req.method == "PATCH") {
+ headers.emplace("Content-Length", "0");
+ }
+ } else {
+ if (!req.has_header("Content-Type")) {
+ headers.emplace("Content-Type", "text/plain");
}
- auto sock = create_client_socket();
- if (sock == INVALID_SOCKET) {
- return false;
+ if (!req.has_header("Content-Length")) {
+ auto length = std::to_string(req.body.size());
+ headers.emplace("Content-Length", length);
}
+ }
- return read_and_close_socket(sock, req, res);
+ detail::write_headers(bstrm, req, headers);
+
+ // Body
+ if (!req.body.empty()) { bstrm.write(req.body); }
+
+ // Flush buffer
+ auto &data = bstrm.get_buffer();
+ strm.write(data.data(), data.size());
}
-inline void Client::write_request(Stream& strm, Request& req)
-{
- auto path = detail::encode_url(req.path);
+inline bool Client::process_request(Stream &strm, const Request &req,
+ Response &res, bool last_connection,
+ bool &connection_close) {
+ // Send request
+ write_request(strm, req, last_connection);
+
+ // Receive response and headers
+ if (!read_response_line(strm, res) ||
+ !detail::read_headers(strm, res.headers)) {
+ return false;
+ }
- // Request line
- strm.write_format("%s %s HTTP/1.1\r\n",
- req.method.c_str(),
- path.c_str());
+ if (res.get_header_value("Connection") == "close" ||
+ res.version == "HTTP/1.0") {
+ connection_close = true;
+ }
- // Headers
- req.set_header("Host", host_and_port_.c_str());
+ if (req.response_handler) {
+ if (!req.response_handler(res)) { return false; }
+ }
- if (!req.has_header("Accept")) {
- req.set_header("Accept", "*/*");
- }
+ // Body
+ if (req.method != "HEAD") {
+ detail::ContentReceiverCore out = [&](const char *buf, size_t n) {
+ if (res.body.size() + n > res.body.max_size()) { return false; }
+ res.body.append(buf, n);
+ return true;
+ };
- if (!req.has_header("User-Agent")) {
- req.set_header("User-Agent", "cpp-httplib/0.2");
+ if (req.content_receiver) {
+ auto offset = std::make_shared<size_t>();
+ auto length = get_header_value_uint64(res.headers, "Content-Length", 0);
+ auto receiver = req.content_receiver;
+ out = [offset, length, receiver](const char *buf, size_t n) {
+ auto ret = receiver(buf, n, *offset, length);
+ (*offset) += n;
+ return ret;
+ };
}
- // TODO: Support KeepAlive connection
- // if (!req.has_header("Connection")) {
- req.set_header("Connection", "close");
- // }
+ int dummy_status;
+ if (!detail::read_content(strm, res, std::numeric_limits<size_t>::max(),
+ dummy_status, req.progress, out)) {
+ return false;
+ }
+ }
- if (!req.body.empty()) {
- if (!req.has_header("Content-Type")) {
- req.set_header("Content-Type", "text/plain");
- }
+ return true;
+}
- auto length = std::to_string(req.body.size());
- req.set_header("Content-Length", length.c_str());
- }
+inline bool Client::process_and_close_socket(
+ socket_t sock, size_t request_count,
+ std::function<bool(Stream &strm, bool last_connection,
+ bool &connection_close)>
+ callback) {
+ request_count = std::min(request_count, keep_alive_max_count_);
+ return detail::process_and_close_socket(true, sock, request_count, callback);
+}
- detail::write_headers(strm, req);
+inline bool Client::is_ssl() const { return false; }
- // Body
- if (!req.body.empty()) {
- if (req.get_header_value("Content-Type") == "application/x-www-form-urlencoded") {
- auto str = detail::encode_url(req.body);
- strm.write(str.c_str(), str.size());
- } else {
- strm.write(req.body.c_str(), req.body.size());
- }
- }
+inline std::shared_ptr<Response> Client::Get(const char *path) {
+ Progress dummy;
+ return Get(path, Headers(), dummy);
}
-inline bool Client::process_request(Stream& strm, Request& req, Response& res, bool& connection_close)
-{
- // Send request
- write_request(strm, req);
+inline std::shared_ptr<Response> Client::Get(const char *path,
+ Progress progress) {
+ return Get(path, Headers(), progress);
+}
- // Receive response and headers
- if (!read_response_line(strm, res) || !detail::read_headers(strm, res.headers)) {
- return false;
- }
+inline std::shared_ptr<Response> Client::Get(const char *path,
+ const Headers &headers) {
+ Progress dummy;
+ return Get(path, headers, dummy);
+}
- if (res.get_header_value("Connection") == "close" || res.version == "HTTP/1.0") {
- connection_close = true;
- }
+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;
+ req.progress = progress;
- // Body
- if (req.method != "HEAD") {
- if (!detail::read_content(strm, res, req.progress)) {
- return false;
- }
+ auto res = std::make_shared<Response>();
+ return send(req, *res) ? res : nullptr;
+}
- if (res.get_header_value("Content-Encoding") == "gzip") {
-#ifdef CPPHTTPLIB_ZLIB_SUPPORT
- detail::decompress(res.body);
-#else
- return false;
-#endif
- }
- }
+inline std::shared_ptr<Response> Client::Get(const char *path,
+ ContentReceiver content_receiver) {
+ Progress dummy;
+ return Get(path, Headers(), nullptr, content_receiver, dummy);
+}
- return true;
+inline std::shared_ptr<Response> Client::Get(const char *path,
+ ContentReceiver content_receiver,
+ Progress progress) {
+ return Get(path, Headers(), nullptr, content_receiver, progress);
}
-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);
- });
+inline std::shared_ptr<Response> Client::Get(const char *path,
+ const Headers &headers,
+ ContentReceiver content_receiver) {
+ Progress dummy;
+ return Get(path, headers, nullptr, content_receiver, dummy);
}
-inline std::shared_ptr<Response> Client::Get(const char* path, Progress progress)
-{
- return Get(path, Headers(), progress);
+inline std::shared_ptr<Response> Client::Get(const char *path,
+ const Headers &headers,
+ ContentReceiver content_receiver,
+ Progress progress) {
+ return Get(path, headers, nullptr, content_receiver, progress);
}
-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;
- req.progress = progress;
+inline std::shared_ptr<Response> Client::Get(const char *path,
+ const Headers &headers,
+ ResponseHandler response_handler,
+ ContentReceiver content_receiver) {
+ Progress dummy;
+ return Get(path, headers, response_handler, content_receiver, dummy);
+}
- auto res = std::make_shared<Response>();
+inline std::shared_ptr<Response> Client::Get(const char *path,
+ const Headers &headers,
+ ResponseHandler response_handler,
+ ContentReceiver content_receiver,
+ Progress progress) {
+ Request req;
+ req.method = "GET";
+ req.path = path;
+ req.headers = headers;
+ req.response_handler = response_handler;
+ req.content_receiver = content_receiver;
+ req.progress = progress;
- return send(req, *res) ? res : nullptr;
+ auto res = std::make_shared<Response>();
+ return send(req, *res) ? res : nullptr;
}
-inline std::shared_ptr<Response> Client::Head(const char* path)
-{
- return Head(path, Headers());
+inline std::shared_ptr<Response> Client::Head(const char *path) {
+ return Head(path, Headers());
}
-inline std::shared_ptr<Response> Client::Head(const char* path, const Headers& headers)
-{
- Request req;
- req.method = "HEAD";
- req.headers = headers;
- req.path = path;
+inline std::shared_ptr<Response> Client::Head(const char *path,
+ const Headers &headers) {
+ Request req;
+ req.method = "HEAD";
+ req.headers = headers;
+ req.path = path;
- auto res = std::make_shared<Response>();
+ auto res = std::make_shared<Response>();
- return send(req, *res) ? res : nullptr;
+ return send(req, *res) ? res : nullptr;
}
-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);
+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);
}
-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;
+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;
- req.headers.emplace("Content-Type", content_type);
- req.body = body;
+ req.headers.emplace("Content-Type", content_type);
+ req.body = body;
- auto res = std::make_shared<Response>();
+ auto res = std::make_shared<Response>();
- return send(req, *res) ? res : nullptr;
+ return send(req, *res) ? res : nullptr;
}
-inline std::shared_ptr<Response> Client::Post(const char* path, const Params& params)
-{
- return Post(path, Headers(), params);
+inline std::shared_ptr<Response> Client::Post(const char *path,
+ const Params &params) {
+ return Post(path, Headers(), params);
}
-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 += it->second;
+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);
+ }
+
+ return Post(path, headers, query, "application/x-www-form-urlencoded");
+}
+
+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;
+}
+
+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);
+}
+
+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;
+
+ req.headers.emplace("Content-Type", content_type);
+ req.body = body;
+
+ auto res = std::make_shared<Response>();
- return Post(path, headers, query, "application/x-www-form-urlencoded");
+ return send(req, *res) ? res : nullptr;
}
-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);
+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);
}
-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;
+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;
- req.headers.emplace("Content-Type", content_type);
- req.body = body;
+ req.headers.emplace("Content-Type", content_type);
+ req.body = body;
- auto res = std::make_shared<Response>();
+ auto res = std::make_shared<Response>();
- return send(req, *res) ? res : nullptr;
+ return send(req, *res) ? res : nullptr;
}
-inline std::shared_ptr<Response> Client::Delete(const char* path)
-{
- return Delete(path, Headers());
+inline std::shared_ptr<Response> Client::Delete(const char *path) {
+ return Delete(path, Headers(), std::string(), nullptr);
}
-inline std::shared_ptr<Response> Client::Delete(const char* path, const Headers& headers)
-{
- Request req;
- req.method = "DELETE";
- req.path = path;
- req.headers = headers;
+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);
+}
+
+inline std::shared_ptr<Response> Client::Delete(const char *path,
+ const Headers &headers) {
+ return Delete(path, headers, std::string(), nullptr);
+}
- auto res = std::make_shared<Response>();
+inline std::shared_ptr<Response> Client::Delete(const char *path,
+ const Headers &headers,
+ const std::string &body,
+ const char *content_type) {
+ Request req;
+ req.method = "DELETE";
+ req.headers = headers;
+ req.path = path;
- return send(req, *res) ? res : nullptr;
+ if (content_type) { req.headers.emplace("Content-Type", content_type); }
+ req.body = body;
+
+ auto res = std::make_shared<Response>();
+
+ return send(req, *res) ? res : nullptr;
}
-inline std::shared_ptr<Response> Client::Options(const char* path)
-{
- return Options(path, Headers());
+inline std::shared_ptr<Response> Client::Options(const char *path) {
+ return Options(path, Headers());
}
-inline std::shared_ptr<Response> Client::Options(const char* path, const Headers& headers)
-{
- Request req;
- req.method = "OPTIONS";
- req.path = path;
- req.headers = headers;
+inline std::shared_ptr<Response> Client::Options(const char *path,
+ const Headers &headers) {
+ Request req;
+ req.method = "OPTIONS";
+ req.path = path;
+ req.headers = headers;
+
+ auto res = std::make_shared<Response>();
- auto res = std::make_shared<Response>();
+ return send(req, *res) ? res : nullptr;
+}
- return send(req, *res) ? res : nullptr;
+inline void Client::set_keep_alive_max_count(size_t count) {
+ keep_alive_max_count_ = count;
}
+inline void Client::follow_location(bool on) { follow_location_ = on; }
+
/*
* SSL Implementation
*/
@@ -2152,74 +3284,114 @@ inline std::shared_ptr<Response> Client::Options(const char* path, const Headers
namespace detail {
template <typename U, typename V, typename T>
-inline bool read_and_close_socket_ssl(
- socket_t sock, size_t keep_alive_max_count,
- // TODO: OpenSSL 1.0.2 occasionally crashes...
- // The upcoming 1.1.0 is going to be thread safe.
- SSL_CTX* ctx, std::mutex& ctx_mutex,
- U SSL_connect_or_accept, V setup,
- T callback)
-{
- SSL* ssl = nullptr;
- {
- std::lock_guard<std::mutex> guard(ctx_mutex);
-
- ssl = SSL_new(ctx);
- if (!ssl) {
- return false;
- }
- }
+inline bool process_and_close_socket_ssl(bool is_client_request, socket_t sock,
+ size_t keep_alive_max_count,
+ SSL_CTX *ctx, std::mutex &ctx_mutex,
+ U SSL_connect_or_accept, V setup,
+ T callback) {
+ assert(keep_alive_max_count > 0);
+
+ SSL *ssl = nullptr;
+ {
+ std::lock_guard<std::mutex> guard(ctx_mutex);
+ ssl = SSL_new(ctx);
+ }
+
+ if (!ssl) {
+ close_socket(sock);
+ return false;
+ }
- auto bio = BIO_new_socket(sock, BIO_NOCLOSE);
- SSL_set_bio(ssl, bio, bio);
+ auto bio = BIO_new_socket(static_cast<int>(sock), BIO_NOCLOSE);
+ SSL_set_bio(ssl, bio, bio);
- setup(ssl);
+ if (!setup(ssl)) {
+ SSL_shutdown(ssl);
+ {
+ std::lock_guard<std::mutex> guard(ctx_mutex);
+ SSL_free(ssl);
+ }
- SSL_connect_or_accept(ssl);
+ close_socket(sock);
+ return false;
+ }
- bool ret = false;
+ 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) {
- SSLSocketStream strm(sock, ssl);
- auto last_connection = count == 1;
- auto connection_close = false;
+ if (SSL_connect_or_accept(ssl) == 1) {
+ if (keep_alive_max_count > 1) {
+ auto count = keep_alive_max_count;
+ while (count > 0 &&
+ (is_client_request ||
+ 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;
- ret = callback(strm, last_connection, connection_close);
- if (!ret || connection_close) {
- break;
- }
+ ret = callback(ssl, strm, last_connection, connection_close);
+ if (!ret || connection_close) { break; }
- count--;
- }
+ count--;
+ }
} else {
- SSLSocketStream strm(sock, ssl);
- auto dummy_connection_close = false;
- ret = callback(strm, true, dummy_connection_close);
+ SSLSocketStream strm(sock, ssl);
+ auto dummy_connection_close = false;
+ ret = callback(ssl, strm, true, dummy_connection_close);
}
+ }
- SSL_shutdown(ssl);
+ SSL_shutdown(ssl);
+ {
+ std::lock_guard<std::mutex> guard(ctx_mutex);
+ SSL_free(ssl);
+ }
- {
- std::lock_guard<std::mutex> guard(ctx_mutex);
- SSL_free(ssl);
- }
-
- close_socket(sock);
+ close_socket(sock);
- return ret;
+ return ret;
}
-class SSLInit {
+#if OPENSSL_VERSION_NUMBER < 0x10100000L
+static std::shared_ptr<std::vector<std::mutex>> openSSL_locks_;
+
+class SSLThreadLocks {
public:
- SSLInit() {
- SSL_load_error_strings();
- SSL_library_init();
+ SSLThreadLocks() {
+ openSSL_locks_ =
+ std::make_shared<std::vector<std::mutex>>(CRYPTO_num_locks());
+ CRYPTO_set_locking_callback(locking_callback);
+ }
+
+ ~SSLThreadLocks() { CRYPTO_set_locking_callback(nullptr); }
+
+private:
+ static void locking_callback(int mode, int type, const char * /*file*/,
+ int /*line*/) {
+ auto &locks = *openSSL_locks_;
+ if (mode & CRYPTO_LOCK) {
+ locks[type].lock();
+ } else {
+ locks[type].unlock();
}
+ }
+};
+
+#endif
+
+class SSLInit {
+public:
+ SSLInit() {
+ SSL_load_error_strings();
+ SSL_library_init();
+ }
+
+ ~SSLInit() { ERR_free_strings(); }
+
+private:
+#if OPENSSL_VERSION_NUMBER < 0x10100000L
+ SSLThreadLocks thread_init_;
+#endif
};
static SSLInit sslinit_;
@@ -2227,118 +3399,319 @@ static SSLInit sslinit_;
} // namespace detail
// SSL socket stream implementation
-inline SSLSocketStream::SSLSocketStream(socket_t sock, SSL* ssl)
- : sock_(sock), ssl_(ssl)
-{
-}
+inline SSLSocketStream::SSLSocketStream(socket_t sock, SSL *ssl)
+ : sock_(sock), ssl_(ssl) {}
-inline SSLSocketStream::~SSLSocketStream()
-{
+inline SSLSocketStream::~SSLSocketStream() {}
+
+inline int SSLSocketStream::read(char *ptr, size_t size) {
+ if (SSL_pending(ssl_) > 0 ||
+ detail::select_read(sock_, CPPHTTPLIB_READ_TIMEOUT_SECOND,
+ CPPHTTPLIB_READ_TIMEOUT_USECOND) > 0) {
+ return SSL_read(ssl_, ptr, static_cast<int>(size));
+ }
+ return -1;
}
-inline int SSLSocketStream::read(char* ptr, size_t size)
-{
- return SSL_read(ssl_, ptr, size);
+inline int SSLSocketStream::write(const char *ptr, size_t size) {
+ return SSL_write(ssl_, ptr, static_cast<int>(size));
}
-inline int SSLSocketStream::write(const char* ptr, size_t size)
-{
- return SSL_write(ssl_, ptr, size);
+inline int SSLSocketStream::write(const char *ptr) {
+ return write(ptr, strlen(ptr));
}
-inline int SSLSocketStream::write(const char* ptr)
-{
- return write(ptr, strlen(ptr));
+inline int SSLSocketStream::write(const std::string &s) {
+ return write(s.data(), s.size());
}
-inline std::string SSLSocketStream::get_remote_addr() {
- return detail::get_remote_addr(sock_);
+inline std::string SSLSocketStream::get_remote_addr() const {
+ return detail::get_remote_addr(sock_);
}
// SSL HTTP server implementation
-inline SSLServer::SSLServer(const char* cert_path, const char* private_key_path)
-{
- ctx_ = SSL_CTX_new(SSLv23_server_method());
-
- if (ctx_) {
- SSL_CTX_set_options(ctx_,
- SSL_OP_ALL | SSL_OP_NO_SSLv2 | SSL_OP_NO_SSLv3 |
+inline SSLServer::SSLServer(const char *cert_path, const char *private_key_path,
+ const char *client_ca_cert_file_path,
+ const char *client_ca_cert_dir_path) {
+ ctx_ = SSL_CTX_new(SSLv23_server_method());
+
+ if (ctx_) {
+ SSL_CTX_set_options(ctx_,
+ SSL_OP_ALL | SSL_OP_NO_SSLv2 | SSL_OP_NO_SSLv3 |
SSL_OP_NO_COMPRESSION |
SSL_OP_NO_SESSION_RESUMPTION_ON_RENEGOTIATION);
- // auto ecdh = EC_KEY_new_by_curve_name(NID_X9_62_prime256v1);
- // SSL_CTX_set_tmp_ecdh(ctx_, ecdh);
- // EC_KEY_free(ecdh);
+ // auto ecdh = EC_KEY_new_by_curve_name(NID_X9_62_prime256v1);
+ // SSL_CTX_set_tmp_ecdh(ctx_, ecdh);
+ // EC_KEY_free(ecdh);
- if (SSL_CTX_use_certificate_file(ctx_, cert_path, SSL_FILETYPE_PEM) != 1 ||
- SSL_CTX_use_PrivateKey_file(ctx_, private_key_path, SSL_FILETYPE_PEM) != 1) {
- SSL_CTX_free(ctx_);
- ctx_ = nullptr;
- }
+ 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;
+ } 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);
+
+ SSL_CTX_set_verify(
+ ctx_,
+ SSL_VERIFY_PEER |
+ SSL_VERIFY_FAIL_IF_NO_PEER_CERT, // SSL_VERIFY_CLIENT_ONCE,
+ nullptr);
}
+ }
+}
+
+inline SSLServer::~SSLServer() {
+ if (ctx_) { SSL_CTX_free(ctx_); }
+}
+
+inline bool SSLServer::is_valid() const { return ctx_; }
+
+inline bool SSLServer::process_and_close_socket(socket_t sock) {
+ return detail::process_and_close_socket_ssl(
+ false, sock, keep_alive_max_count_, ctx_, ctx_mutex_, SSL_accept,
+ [](SSL * /*ssl*/) { return true; },
+ [this](SSL *ssl, Stream &strm, bool last_connection,
+ bool &connection_close) {
+ return process_request(strm, last_connection, connection_close,
+ [&](Request &req) { req.ssl = ssl; });
+ });
}
-inline SSLServer::~SSLServer()
-{
- if (ctx_) {
- SSL_CTX_free(ctx_);
+// SSL HTTP client implementation
+inline SSLClient::SSLClient(const char *host, int port, time_t timeout_sec,
+ const char *client_cert_path,
+ const char *client_key_path)
+ : 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));
+ });
+ 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;
}
+ }
}
-inline bool SSLServer::is_valid() const
-{
- return ctx_;
+inline SSLClient::~SSLClient() {
+ if (ctx_) { SSL_CTX_free(ctx_); }
}
-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,
- [](SSL* /*ssl*/) {},
- [this](Stream& strm, bool last_connection, bool& connection_close) {
- return process_request(strm, last_connection, connection_close);
- });
+inline bool SSLClient::is_valid() const { return ctx_; }
+
+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; }
}
-// SSL HTTP client implementation
-inline SSLClient::SSLClient(const char* host, int port, size_t timeout_sec)
- : Client(host, port, timeout_sec)
-{
- ctx_ = SSL_CTX_new(SSLv23_client_method());
+inline void SSLClient::enable_server_certificate_verification(bool enabled) {
+ server_certificate_verification_ = enabled;
}
-inline SSLClient::~SSLClient()
-{
- if (ctx_) {
- SSL_CTX_free(ctx_);
- }
+inline long SSLClient::get_openssl_verify_result() const {
+ return verify_result_;
}
-inline bool SSLClient::is_valid() const
-{
- return ctx_;
+inline SSL_CTX* SSLClient::ssl_context() const noexcept {
+ return ctx_;
}
-inline bool SSLClient::read_and_close_socket(socket_t sock, Request& req, Response& res)
-{
- return is_valid() && detail::read_and_close_socket_ssl(
- sock, 0,
- ctx_, ctx_mutex_,
- SSL_connect,
- [&](SSL* ssl) {
- SSL_set_tlsext_host_name(ssl, host_.c_str());
- },
- [&](Stream& strm, bool /*last_connection*/, bool& connection_close) {
- return process_request(strm, req, res, connection_close);
- });
+inline bool SSLClient::process_and_close_socket(
+ socket_t sock, size_t request_count,
+ std::function<bool(Stream &strm, bool last_connection,
+ bool &connection_close)>
+ callback) {
+
+ request_count = std::min(request_count, keep_alive_max_count_);
+
+ return is_valid() &&
+ detail::process_and_close_socket_ssl(
+ true, sock, request_count, ctx_, ctx_mutex_,
+ [&](SSL *ssl) {
+ if (ca_cert_file_path_.empty()) {
+ SSL_CTX_set_verify(ctx_, SSL_VERIFY_NONE, nullptr);
+ } else {
+ if (!SSL_CTX_load_verify_locations(
+ ctx_, ca_cert_file_path_.c_str(), nullptr)) {
+ return false;
+ }
+ SSL_CTX_set_verify(ctx_, SSL_VERIFY_PEER, nullptr);
+ }
+
+ if (SSL_connect(ssl) != 1) { return false; }
+
+ if (server_certificate_verification_) {
+ 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; }
+
+ if (!verify_host(server_cert)) {
+ X509_free(server_cert);
+ return false;
+ }
+ X509_free(server_cert);
+ }
+
+ return true;
+ },
+ [&](SSL *ssl) {
+ SSL_set_tlsext_host_name(ssl, host_.c_str());
+ return true;
+ },
+ [&](SSL * /*ssl*/, Stream &strm, bool last_connection,
+ bool &connection_close) {
+ return callback(strm, last_connection, connection_close);
+ });
+}
+
+inline bool SSLClient::is_ssl() const { return true; }
+
+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);
}
+
+inline bool
+SSLClient::verify_host_with_subject_alt_name(X509 *server_cert) const {
+ auto ret = false;
+
+ auto type = GEN_DNS;
+
+ struct in6_addr addr6;
+ struct in_addr addr;
+ size_t addr_len = 0;
+
+#ifndef __MINGW32__
+ if (inet_pton(AF_INET6, host_.c_str(), &addr6)) {
+ type = GEN_IPADD;
+ addr_len = sizeof(struct in6_addr);
+ } else if (inet_pton(AF_INET, host_.c_str(), &addr)) {
+ type = GEN_IPADD;
+ addr_len = sizeof(struct in_addr);
+ }
#endif
-} // namespace httplib
+ auto alt_names = static_cast<const struct stack_st_GENERAL_NAME *>(
+ X509_get_ext_d2i(server_cert, NID_subject_alt_name, nullptr, nullptr));
+
+ if (alt_names) {
+ auto dsn_matched = false;
+ auto ip_mached = false;
+
+ auto count = sk_GENERAL_NAME_num(alt_names);
+
+ for (auto i = 0; i < count && !dsn_matched; i++) {
+ auto val = sk_GENERAL_NAME_value(alt_names, i);
+ if (val->type == type) {
+ auto name = (const char *)ASN1_STRING_get0_data(val->d.ia5);
+ auto name_len = (size_t)ASN1_STRING_length(val->d.ia5);
+ if (strlen(name) == name_len) {
+ switch (type) {
+ case GEN_DNS: dsn_matched = check_host_name(name, name_len); break;
+
+ case GEN_IPADD:
+ if (!memcmp(&addr6, name, addr_len) ||
+ !memcmp(&addr, name, addr_len)) {
+ 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 {
+ 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); }
+ }
+
+ return false;
+}
+
+inline bool SSLClient::check_host_name(const char *pattern,
+ size_t pattern_len) const {
+ if (host_.size() == pattern_len && host_ == pattern) { return true; }
+
+ // 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;
+ }
+
+ return true;
+}
#endif
-// vim: et ts=4 sw=4 cin cino={1s ff=unix
+} // namespace httplib
+
+#endif // CPPHTTPLIB_HTTPLIB_H
diff --git a/src/core/CMakeLists.txt b/src/core/CMakeLists.txt
index 4f6a87b0a..f2e774a6b 100644
--- a/src/core/CMakeLists.txt
+++ b/src/core/CMakeLists.txt
@@ -522,6 +522,23 @@ add_library(core STATIC
tools/freezer.h
)
+if (MSVC)
+ target_compile_options(core PRIVATE
+ # 'expression' : signed/unsigned mismatch
+ /we4018
+ # 'argument' : conversion from 'type1' to 'type2', possible loss of data (floating-point)
+ /we4244
+ # 'conversion' : conversion from 'type1' to 'type2', signed/unsigned mismatch
+ /we4245
+ # 'operator': conversion from 'type1:field_bits' to 'type2:field_bits', possible loss of data
+ /we4254
+ # 'var' : conversion from 'size_t' to 'type', possible loss of data
+ /we4267
+ # 'context' : truncation from 'type1' to 'type2'
+ /we4305
+ )
+endif()
+
create_target_directory_groups(core)
target_link_libraries(core PUBLIC common PRIVATE audio_core video_core)
diff --git a/src/core/arm/dynarmic/arm_dynarmic.cpp b/src/core/arm/dynarmic/arm_dynarmic.cpp
index 700c4afff..a0705b2b8 100644
--- a/src/core/arm/dynarmic/arm_dynarmic.cpp
+++ b/src/core/arm/dynarmic/arm_dynarmic.cpp
@@ -67,7 +67,7 @@ public:
ARM_Interface::ThreadContext ctx;
parent.SaveContext(ctx);
parent.inner_unicorn.LoadContext(ctx);
- parent.inner_unicorn.ExecuteInstructions(static_cast<int>(num_instructions));
+ parent.inner_unicorn.ExecuteInstructions(num_instructions);
parent.inner_unicorn.SaveContext(ctx);
parent.LoadContext(ctx);
num_interpreted_instructions += num_instructions;
diff --git a/src/core/arm/unicorn/arm_unicorn.cpp b/src/core/arm/unicorn/arm_unicorn.cpp
index d4f41bfc1..9698172db 100644
--- a/src/core/arm/unicorn/arm_unicorn.cpp
+++ b/src/core/arm/unicorn/arm_unicorn.cpp
@@ -67,10 +67,11 @@ ARM_Unicorn::ARM_Unicorn(System& system) : system{system} {
CHECKED(uc_reg_write(uc, UC_ARM64_REG_CPACR_EL1, &fpv));
uc_hook hook{};
- CHECKED(uc_hook_add(uc, &hook, UC_HOOK_INTR, (void*)InterruptHook, this, 0, -1));
- CHECKED(uc_hook_add(uc, &hook, UC_HOOK_MEM_INVALID, (void*)UnmappedMemoryHook, &system, 0, -1));
+ CHECKED(uc_hook_add(uc, &hook, UC_HOOK_INTR, (void*)InterruptHook, this, 0, UINT64_MAX));
+ CHECKED(uc_hook_add(uc, &hook, UC_HOOK_MEM_INVALID, (void*)UnmappedMemoryHook, &system, 0,
+ UINT64_MAX));
if (GDBStub::IsServerEnabled()) {
- CHECKED(uc_hook_add(uc, &hook, UC_HOOK_CODE, (void*)CodeHook, this, 0, -1));
+ CHECKED(uc_hook_add(uc, &hook, UC_HOOK_CODE, (void*)CodeHook, this, 0, UINT64_MAX));
last_bkpt_hit = false;
}
}
@@ -154,9 +155,10 @@ void ARM_Unicorn::SetTPIDR_EL0(u64 value) {
void ARM_Unicorn::Run() {
if (GDBStub::IsServerEnabled()) {
- ExecuteInstructions(std::max(4000000, 0));
+ ExecuteInstructions(std::max(4000000U, 0U));
} else {
- ExecuteInstructions(std::max(system.CoreTiming().GetDowncount(), s64{0}));
+ ExecuteInstructions(
+ std::max(std::size_t(system.CoreTiming().GetDowncount()), std::size_t{0}));
}
}
@@ -166,7 +168,7 @@ void ARM_Unicorn::Step() {
MICROPROFILE_DEFINE(ARM_Jit_Unicorn, "ARM JIT", "Unicorn", MP_RGB(255, 64, 64));
-void ARM_Unicorn::ExecuteInstructions(int num_instructions) {
+void ARM_Unicorn::ExecuteInstructions(std::size_t num_instructions) {
MICROPROFILE_SCOPE(ARM_Jit_Unicorn);
CHECKED(uc_emu_start(uc, GetPC(), 1ULL << 63, 0, num_instructions));
system.CoreTiming().AddTicks(num_instructions);
diff --git a/src/core/arm/unicorn/arm_unicorn.h b/src/core/arm/unicorn/arm_unicorn.h
index fe2ffd70c..b39426ea0 100644
--- a/src/core/arm/unicorn/arm_unicorn.h
+++ b/src/core/arm/unicorn/arm_unicorn.h
@@ -34,7 +34,7 @@ public:
void LoadContext(const ThreadContext& ctx) override;
void PrepareReschedule() override;
void ClearExclusiveState() override;
- void ExecuteInstructions(int num_instructions);
+ void ExecuteInstructions(std::size_t num_instructions);
void Run() override;
void Step() override;
void ClearInstructionCache() override;
diff --git a/src/core/crypto/key_manager.cpp b/src/core/crypto/key_manager.cpp
index 487b57053..87e6a1fd3 100644
--- a/src/core/crypto/key_manager.cpp
+++ b/src/core/crypto/key_manager.cpp
@@ -22,6 +22,7 @@
#include "common/file_util.h"
#include "common/hex_util.h"
#include "common/logging/log.h"
+#include "common/string_util.h"
#include "core/core.h"
#include "core/crypto/aes_util.h"
#include "core/crypto/key_manager.h"
@@ -378,8 +379,9 @@ std::vector<Ticket> GetTicketblob(const FileUtil::IOFile& ticket_save) {
template <size_t size>
static std::array<u8, size> operator^(const std::array<u8, size>& lhs,
const std::array<u8, size>& rhs) {
- std::array<u8, size> out{};
- std::transform(lhs.begin(), lhs.end(), rhs.begin(), out.begin(), std::bit_xor<>());
+ std::array<u8, size> out;
+ std::transform(lhs.begin(), lhs.end(), rhs.begin(), out.begin(),
+ [](u8 lhs, u8 rhs) { return u8(lhs ^ rhs); });
return out;
}
@@ -538,7 +540,7 @@ void KeyManager::LoadFromFile(const std::string& filename, bool is_title_keys) {
Key128 key = Common::HexStringToArray<16>(out[1]);
s128_keys[{S128KeyType::Titlekey, rights_id[1], rights_id[0]}] = key;
} else {
- std::transform(out[0].begin(), out[0].end(), out[0].begin(), ::tolower);
+ out[0] = Common::ToLower(out[0]);
if (s128_file_id.find(out[0]) != s128_file_id.end()) {
const auto index = s128_file_id.at(out[0]);
Key128 key = Common::HexStringToArray<16>(out[1]);
@@ -948,12 +950,10 @@ void KeyManager::DeriveETicket(PartitionDataManager& data) {
return;
}
- Key128 rsa_oaep_kek{};
- std::transform(seed3.begin(), seed3.end(), mask0.begin(), rsa_oaep_kek.begin(),
- std::bit_xor<>());
-
- if (rsa_oaep_kek == Key128{})
+ const Key128 rsa_oaep_kek = seed3 ^ mask0;
+ if (rsa_oaep_kek == Key128{}) {
return;
+ }
SetKey(S128KeyType::Source, rsa_oaep_kek,
static_cast<u64>(SourceKeyType::RSAOaepKekGeneration));
diff --git a/src/core/crypto/partition_data_manager.cpp b/src/core/crypto/partition_data_manager.cpp
index a4b09fd12..d64302f2e 100644
--- a/src/core/crypto/partition_data_manager.cpp
+++ b/src/core/crypto/partition_data_manager.cpp
@@ -204,11 +204,12 @@ static std::array<Key128, 0x20> FindEncryptedMasterKeyFromHex(const std::vector<
FileSys::VirtualFile FindFileInDirWithNames(const FileSys::VirtualDir& dir,
const std::string& name) {
- auto upper = name;
- std::transform(upper.begin(), upper.end(), upper.begin(), [](u8 c) { return std::toupper(c); });
+ const auto upper = Common::ToUpper(name);
+
for (const auto& fname : {name, name + ".bin", upper, upper + ".BIN"}) {
- if (dir->GetFile(fname) != nullptr)
+ if (dir->GetFile(fname) != nullptr) {
return dir->GetFile(fname);
+ }
}
return nullptr;
diff --git a/src/core/file_sys/kernel_executable.cpp b/src/core/file_sys/kernel_executable.cpp
index 371300684..76313679d 100644
--- a/src/core/file_sys/kernel_executable.cpp
+++ b/src/core/file_sys/kernel_executable.cpp
@@ -147,7 +147,7 @@ std::vector<u32> KIP::GetKernelCapabilities() const {
}
s32 KIP::GetMainThreadPriority() const {
- return header.main_thread_priority;
+ return static_cast<s32>(header.main_thread_priority);
}
u32 KIP::GetMainThreadStackSize() const {
diff --git a/src/core/file_sys/program_metadata.cpp b/src/core/file_sys/program_metadata.cpp
index 7310b3602..1d6c30962 100644
--- a/src/core/file_sys/program_metadata.cpp
+++ b/src/core/file_sys/program_metadata.cpp
@@ -52,14 +52,14 @@ Loader::ResultStatus ProgramMetadata::Load(VirtualFile file) {
}
void ProgramMetadata::LoadManual(bool is_64_bit, ProgramAddressSpaceType address_space,
- u8 main_thread_prio, u8 main_thread_core,
+ s32 main_thread_prio, u32 main_thread_core,
u32 main_thread_stack_size, u64 title_id,
u64 filesystem_permissions,
KernelCapabilityDescriptors capabilities) {
npdm_header.has_64_bit_instructions.Assign(is_64_bit);
npdm_header.address_space_type.Assign(address_space);
- npdm_header.main_thread_priority = main_thread_prio;
- npdm_header.main_thread_cpu = main_thread_core;
+ npdm_header.main_thread_priority = static_cast<u8>(main_thread_prio);
+ npdm_header.main_thread_cpu = static_cast<u8>(main_thread_core);
npdm_header.main_stack_size = main_thread_stack_size;
aci_header.title_id = title_id;
aci_file_access.permissions = filesystem_permissions;
diff --git a/src/core/file_sys/program_metadata.h b/src/core/file_sys/program_metadata.h
index 88ec97d85..f8759a396 100644
--- a/src/core/file_sys/program_metadata.h
+++ b/src/core/file_sys/program_metadata.h
@@ -47,8 +47,8 @@ public:
Loader::ResultStatus Load(VirtualFile file);
// Load from parameters instead of NPDM file, used for KIP
- void LoadManual(bool is_64_bit, ProgramAddressSpaceType address_space, u8 main_thread_prio,
- u8 main_thread_core, u32 main_thread_stack_size, u64 title_id,
+ void LoadManual(bool is_64_bit, ProgramAddressSpaceType address_space, s32 main_thread_prio,
+ u32 main_thread_core, u32 main_thread_stack_size, u64 title_id,
u64 filesystem_permissions, KernelCapabilityDescriptors capabilities);
bool Is64BitProgram() const;
diff --git a/src/core/file_sys/romfs_factory.cpp b/src/core/file_sys/romfs_factory.cpp
index 4bd2e6183..418a39a7e 100644
--- a/src/core/file_sys/romfs_factory.cpp
+++ b/src/core/file_sys/romfs_factory.cpp
@@ -71,12 +71,12 @@ ResultVal<VirtualFile> RomFSFactory::Open(u64 title_id, StorageId storage,
if (res == nullptr) {
// TODO(DarkLordZach): Find the right error code to use here
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
const auto romfs = res->GetRomFS();
if (romfs == nullptr) {
// TODO(DarkLordZach): Find the right error code to use here
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return MakeResult<VirtualFile>(romfs);
}
diff --git a/src/core/file_sys/savedata_factory.cpp b/src/core/file_sys/savedata_factory.cpp
index e2a7eaf7b..f3def93ab 100644
--- a/src/core/file_sys/savedata_factory.cpp
+++ b/src/core/file_sys/savedata_factory.cpp
@@ -90,7 +90,7 @@ ResultVal<VirtualDir> SaveDataFactory::Create(SaveDataSpaceId space,
// Return an error if the save data doesn't actually exist.
if (out == nullptr) {
// TODO(DarkLordZach): Find out correct error code.
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return MakeResult<VirtualDir>(std::move(out));
@@ -111,7 +111,7 @@ ResultVal<VirtualDir> SaveDataFactory::Open(SaveDataSpaceId space,
// Return an error if the save data doesn't actually exist.
if (out == nullptr) {
// TODO(Subv): Find out correct error code.
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return MakeResult<VirtualDir>(std::move(out));
diff --git a/src/core/file_sys/vfs_libzip.cpp b/src/core/file_sys/vfs_libzip.cpp
index 8bdaa7e4a..11d1978ea 100644
--- a/src/core/file_sys/vfs_libzip.cpp
+++ b/src/core/file_sys/vfs_libzip.cpp
@@ -27,7 +27,7 @@ VirtualDir ExtractZIP(VirtualFile file) {
std::shared_ptr<VectorVfsDirectory> out = std::make_shared<VectorVfsDirectory>();
- const auto num_entries = zip_get_num_entries(zip.get(), 0);
+ const auto num_entries = static_cast<std::size_t>(zip_get_num_entries(zip.get(), 0));
zip_stat_t stat{};
zip_stat_init(&stat);
diff --git a/src/core/file_sys/xts_archive.cpp b/src/core/file_sys/xts_archive.cpp
index 7ca375791..86e06ccb9 100644
--- a/src/core/file_sys/xts_archive.cpp
+++ b/src/core/file_sys/xts_archive.cpp
@@ -7,12 +7,13 @@
#include <cstring>
#include <regex>
#include <string>
+
#include <mbedtls/md.h>
#include <mbedtls/sha256.h>
-#include "common/assert.h"
+
#include "common/file_util.h"
#include "common/hex_util.h"
-#include "common/logging/log.h"
+#include "common/string_util.h"
#include "core/crypto/aes_util.h"
#include "core/crypto/xts_encryption_layer.h"
#include "core/file_sys/partition_filesystem.h"
@@ -53,11 +54,8 @@ NAX::NAX(VirtualFile file_) : header(std::make_unique<NAXHeader>()), file(std::m
return;
}
- std::string two_dir = match[1];
- std::string nca_id = match[2];
- std::transform(two_dir.begin(), two_dir.end(), two_dir.begin(), ::toupper);
- std::transform(nca_id.begin(), nca_id.end(), nca_id.begin(), ::tolower);
-
+ const std::string two_dir = Common::ToUpper(match[1]);
+ const std::string nca_id = Common::ToLower(match[2]);
status = Parse(fmt::format("/registered/{}/{}.nca", two_dir, nca_id));
}
diff --git a/src/core/gdbstub/gdbstub.cpp b/src/core/gdbstub/gdbstub.cpp
index 20bb50868..54ed680db 100644
--- a/src/core/gdbstub/gdbstub.cpp
+++ b/src/core/gdbstub/gdbstub.cpp
@@ -468,7 +468,8 @@ static u8 ReadByte() {
/// Calculate the checksum of the current command buffer.
static u8 CalculateChecksum(const u8* buffer, std::size_t length) {
- return static_cast<u8>(std::accumulate(buffer, buffer + length, 0, std::plus<u8>()));
+ return static_cast<u8>(std::accumulate(buffer, buffer + length, u8{0},
+ [](u8 lhs, u8 rhs) { return u8(lhs + rhs); }));
}
/**
diff --git a/src/core/hle/kernel/scheduler.cpp b/src/core/hle/kernel/scheduler.cpp
index 0e2dbf13e..16e95381b 100644
--- a/src/core/hle/kernel/scheduler.cpp
+++ b/src/core/hle/kernel/scheduler.cpp
@@ -35,12 +35,12 @@ void GlobalScheduler::RemoveThread(const Thread* thread) {
thread_list.end());
}
-void GlobalScheduler::UnloadThread(s32 core) {
+void GlobalScheduler::UnloadThread(std::size_t core) {
Scheduler& sched = system.Scheduler(core);
sched.UnloadThread();
}
-void GlobalScheduler::SelectThread(u32 core) {
+void GlobalScheduler::SelectThread(std::size_t core) {
const auto update_thread = [](Thread* thread, Scheduler& sched) {
if (thread != sched.selected_thread) {
if (thread == nullptr) {
@@ -77,9 +77,9 @@ void GlobalScheduler::SelectThread(u32 core) {
// if we got a suggested thread, select it, else do a second pass.
if (winner && winner->GetPriority() > 2) {
if (winner->IsRunning()) {
- UnloadThread(winner->GetProcessorID());
+ UnloadThread(static_cast<u32>(winner->GetProcessorID()));
}
- TransferToCore(winner->GetPriority(), core, winner);
+ TransferToCore(winner->GetPriority(), static_cast<s32>(core), winner);
update_thread(winner, sched);
return;
}
@@ -91,9 +91,9 @@ void GlobalScheduler::SelectThread(u32 core) {
Thread* thread_on_core = scheduled_queue[src_core].front();
Thread* to_change = *it;
if (thread_on_core->IsRunning() || to_change->IsRunning()) {
- UnloadThread(src_core);
+ UnloadThread(static_cast<u32>(src_core));
}
- TransferToCore(thread_on_core->GetPriority(), core, thread_on_core);
+ TransferToCore(thread_on_core->GetPriority(), static_cast<s32>(core), thread_on_core);
current_thread = thread_on_core;
break;
}
@@ -154,9 +154,9 @@ bool GlobalScheduler::YieldThreadAndBalanceLoad(Thread* yielding_thread) {
if (winner != nullptr) {
if (winner != yielding_thread) {
if (winner->IsRunning()) {
- UnloadThread(winner->GetProcessorID());
+ UnloadThread(static_cast<u32>(winner->GetProcessorID()));
}
- TransferToCore(winner->GetPriority(), core_id, winner);
+ TransferToCore(winner->GetPriority(), s32(core_id), winner);
}
} else {
winner = next_thread;
@@ -196,9 +196,9 @@ bool GlobalScheduler::YieldThreadAndWaitForLoadBalancing(Thread* yielding_thread
if (winner != nullptr) {
if (winner != yielding_thread) {
if (winner->IsRunning()) {
- UnloadThread(winner->GetProcessorID());
+ UnloadThread(static_cast<u32>(winner->GetProcessorID()));
}
- TransferToCore(winner->GetPriority(), core_id, winner);
+ TransferToCore(winner->GetPriority(), static_cast<s32>(core_id), winner);
}
} else {
winner = yielding_thread;
@@ -248,7 +248,7 @@ void GlobalScheduler::PreemptThreads() {
if (winner != nullptr) {
if (winner->IsRunning()) {
- UnloadThread(winner->GetProcessorID());
+ UnloadThread(static_cast<u32>(winner->GetProcessorID()));
}
TransferToCore(winner->GetPriority(), s32(core_id), winner);
current_thread =
@@ -281,7 +281,7 @@ void GlobalScheduler::PreemptThreads() {
if (winner != nullptr) {
if (winner->IsRunning()) {
- UnloadThread(winner->GetProcessorID());
+ UnloadThread(static_cast<u32>(winner->GetProcessorID()));
}
TransferToCore(winner->GetPriority(), s32(core_id), winner);
current_thread = winner;
@@ -292,30 +292,30 @@ void GlobalScheduler::PreemptThreads() {
}
}
-void GlobalScheduler::Suggest(u32 priority, u32 core, Thread* thread) {
+void GlobalScheduler::Suggest(u32 priority, std::size_t core, Thread* thread) {
suggested_queue[core].add(thread, priority);
}
-void GlobalScheduler::Unsuggest(u32 priority, u32 core, Thread* thread) {
+void GlobalScheduler::Unsuggest(u32 priority, std::size_t core, Thread* thread) {
suggested_queue[core].remove(thread, priority);
}
-void GlobalScheduler::Schedule(u32 priority, u32 core, Thread* thread) {
+void GlobalScheduler::Schedule(u32 priority, std::size_t core, Thread* thread) {
ASSERT_MSG(thread->GetProcessorID() == s32(core), "Thread must be assigned to this core.");
scheduled_queue[core].add(thread, priority);
}
-void GlobalScheduler::SchedulePrepend(u32 priority, u32 core, Thread* thread) {
+void GlobalScheduler::SchedulePrepend(u32 priority, std::size_t core, Thread* thread) {
ASSERT_MSG(thread->GetProcessorID() == s32(core), "Thread must be assigned to this core.");
scheduled_queue[core].add(thread, priority, false);
}
-void GlobalScheduler::Reschedule(u32 priority, u32 core, Thread* thread) {
+void GlobalScheduler::Reschedule(u32 priority, std::size_t core, Thread* thread) {
scheduled_queue[core].remove(thread, priority);
scheduled_queue[core].add(thread, priority);
}
-void GlobalScheduler::Unschedule(u32 priority, u32 core, Thread* thread) {
+void GlobalScheduler::Unschedule(u32 priority, std::size_t core, Thread* thread) {
scheduled_queue[core].remove(thread, priority);
}
@@ -327,14 +327,14 @@ void GlobalScheduler::TransferToCore(u32 priority, s32 destination_core, Thread*
}
thread->SetProcessorID(destination_core);
if (source_core >= 0) {
- Unschedule(priority, source_core, thread);
+ Unschedule(priority, static_cast<u32>(source_core), thread);
}
if (destination_core >= 0) {
- Unsuggest(priority, destination_core, thread);
- Schedule(priority, destination_core, thread);
+ Unsuggest(priority, static_cast<u32>(destination_core), thread);
+ Schedule(priority, static_cast<u32>(destination_core), thread);
}
if (source_core >= 0) {
- Suggest(priority, source_core, thread);
+ Suggest(priority, static_cast<u32>(source_core), thread);
}
}
@@ -357,7 +357,7 @@ void GlobalScheduler::Shutdown() {
thread_list.clear();
}
-Scheduler::Scheduler(Core::System& system, Core::ARM_Interface& cpu_core, u32 core_id)
+Scheduler::Scheduler(Core::System& system, Core::ARM_Interface& cpu_core, std::size_t core_id)
: system(system), cpu_core(cpu_core), core_id(core_id) {}
Scheduler::~Scheduler() = default;
diff --git a/src/core/hle/kernel/scheduler.h b/src/core/hle/kernel/scheduler.h
index f2d6311b8..311849dfb 100644
--- a/src/core/hle/kernel/scheduler.h
+++ b/src/core/hle/kernel/scheduler.h
@@ -42,41 +42,34 @@ public:
* Add a thread to the suggested queue of a cpu core. Suggested threads may be
* picked if no thread is scheduled to run on the core.
*/
- void Suggest(u32 priority, u32 core, Thread* thread);
+ void Suggest(u32 priority, std::size_t core, Thread* thread);
/**
* Remove a thread to the suggested queue of a cpu core. Suggested threads may be
* picked if no thread is scheduled to run on the core.
*/
- void Unsuggest(u32 priority, u32 core, Thread* thread);
+ void Unsuggest(u32 priority, std::size_t core, Thread* thread);
/**
* Add a thread to the scheduling queue of a cpu core. The thread is added at the
* back the queue in its priority level.
*/
- void Schedule(u32 priority, u32 core, Thread* thread);
+ void Schedule(u32 priority, std::size_t core, Thread* thread);
/**
* Add a thread to the scheduling queue of a cpu core. The thread is added at the
* front the queue in its priority level.
*/
- void SchedulePrepend(u32 priority, u32 core, Thread* thread);
+ void SchedulePrepend(u32 priority, std::size_t core, Thread* thread);
/// Reschedule an already scheduled thread based on a new priority
- void Reschedule(u32 priority, u32 core, Thread* thread);
+ void Reschedule(u32 priority, std::size_t core, Thread* thread);
/// Unschedules a thread.
- void Unschedule(u32 priority, u32 core, Thread* thread);
-
- /**
- * Transfers a thread into an specific core. If the destination_core is -1
- * it will be unscheduled from its source code and added into its suggested
- * queue.
- */
- void TransferToCore(u32 priority, s32 destination_core, Thread* thread);
+ void Unschedule(u32 priority, std::size_t core, Thread* thread);
/// Selects a core and forces it to unload its current thread's context
- void UnloadThread(s32 core);
+ void UnloadThread(std::size_t core);
/**
* Takes care of selecting the new scheduled thread in three steps:
@@ -90,9 +83,9 @@ public:
* 3. Third is no suggested thread is found, we do a second pass and pick a running
* thread in another core and swap it with its current thread.
*/
- void SelectThread(u32 core);
+ void SelectThread(std::size_t core);
- bool HaveReadyThreads(u32 core_id) const {
+ bool HaveReadyThreads(std::size_t core_id) const {
return !scheduled_queue[core_id].empty();
}
@@ -145,6 +138,13 @@ public:
void Shutdown();
private:
+ /**
+ * Transfers a thread into an specific core. If the destination_core is -1
+ * it will be unscheduled from its source code and added into its suggested
+ * queue.
+ */
+ void TransferToCore(u32 priority, s32 destination_core, Thread* thread);
+
bool AskForReselectionOrMarkRedundant(Thread* current_thread, const Thread* winner);
static constexpr u32 min_regular_priority = 2;
@@ -163,7 +163,7 @@ private:
class Scheduler final {
public:
- explicit Scheduler(Core::System& system, Core::ARM_Interface& cpu_core, u32 core_id);
+ explicit Scheduler(Core::System& system, Core::ARM_Interface& cpu_core, std::size_t core_id);
~Scheduler();
/// Returns whether there are any threads that are ready to run.
@@ -220,7 +220,7 @@ private:
Core::ARM_Interface& cpu_core;
u64 last_context_switch_time = 0;
u64 idle_selection_count = 0;
- const u32 core_id;
+ const std::size_t core_id;
bool is_context_switch_pending = false;
};
diff --git a/src/core/hle/kernel/thread.cpp b/src/core/hle/kernel/thread.cpp
index 962530d2d..ee7531f2d 100644
--- a/src/core/hle/kernel/thread.cpp
+++ b/src/core/hle/kernel/thread.cpp
@@ -77,18 +77,6 @@ void Thread::CancelWakeupTimer() {
callback_handle);
}
-static std::optional<s32> GetNextProcessorId(u64 mask) {
- for (s32 index = 0; index < Core::NUM_CPU_CORES; ++index) {
- if (mask & (1ULL << index)) {
- if (!Core::System::GetInstance().Scheduler(index).GetCurrentThread()) {
- // Core is enabled and not running any threads, use this one
- return index;
- }
- }
- }
- return {};
-}
-
void Thread::ResumeFromWait() {
ASSERT_MSG(wait_objects.empty(), "Thread is waking up while waiting for objects");
@@ -173,7 +161,7 @@ ResultVal<SharedPtr<Thread>> Thread::Create(KernelCore& kernel, std::string name
if (!Memory::IsValidVirtualAddress(owner_process, entry_point)) {
LOG_ERROR(Kernel_SVC, "(name={}): invalid entry {:016X}", name, entry_point);
// TODO (bunnei): Find the correct error code to use here
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
auto& system = Core::System::GetInstance();
@@ -401,7 +389,7 @@ void Thread::SetCurrentPriority(u32 new_priority) {
ResultCode Thread::SetCoreAndAffinityMask(s32 new_core, u64 new_affinity_mask) {
const auto HighestSetCore = [](u64 mask, u32 max_cores) {
- for (s32 core = max_cores - 1; core >= 0; core--) {
+ for (s32 core = static_cast<s32>(max_cores - 1); core >= 0; core--) {
if (((mask >> core) & 1) != 0) {
return core;
}
@@ -425,7 +413,7 @@ ResultCode Thread::SetCoreAndAffinityMask(s32 new_core, u64 new_affinity_mask) {
if (old_affinity_mask != new_affinity_mask) {
const s32 old_core = processor_id;
if (processor_id >= 0 && ((affinity_mask >> processor_id) & 1) == 0) {
- if (ideal_core < 0) {
+ if (static_cast<s32>(ideal_core) < 0) {
processor_id = HighestSetCore(affinity_mask, GlobalScheduler::NUM_CPU_CORES);
} else {
processor_id = ideal_core;
@@ -447,23 +435,23 @@ void Thread::AdjustSchedulingOnStatus(u32 old_flags) {
ThreadSchedStatus::Runnable) {
// In this case the thread was running, now it's pausing/exitting
if (processor_id >= 0) {
- scheduler.Unschedule(current_priority, processor_id, this);
+ scheduler.Unschedule(current_priority, static_cast<u32>(processor_id), this);
}
- for (s32 core = 0; core < GlobalScheduler::NUM_CPU_CORES; core++) {
- if (core != processor_id && ((affinity_mask >> core) & 1) != 0) {
- scheduler.Unsuggest(current_priority, static_cast<u32>(core), this);
+ for (u32 core = 0; core < GlobalScheduler::NUM_CPU_CORES; core++) {
+ if (core != static_cast<u32>(processor_id) && ((affinity_mask >> core) & 1) != 0) {
+ scheduler.Unsuggest(current_priority, core, this);
}
}
} else if (GetSchedulingStatus() == ThreadSchedStatus::Runnable) {
// The thread is now set to running from being stopped
if (processor_id >= 0) {
- scheduler.Schedule(current_priority, processor_id, this);
+ scheduler.Schedule(current_priority, static_cast<u32>(processor_id), this);
}
- for (s32 core = 0; core < GlobalScheduler::NUM_CPU_CORES; core++) {
- if (core != processor_id && ((affinity_mask >> core) & 1) != 0) {
- scheduler.Suggest(current_priority, static_cast<u32>(core), this);
+ for (u32 core = 0; core < GlobalScheduler::NUM_CPU_CORES; core++) {
+ if (core != static_cast<u32>(processor_id) && ((affinity_mask >> core) & 1) != 0) {
+ scheduler.Suggest(current_priority, core, this);
}
}
}
@@ -477,11 +465,11 @@ void Thread::AdjustSchedulingOnPriority(u32 old_priority) {
}
auto& scheduler = Core::System::GetInstance().GlobalScheduler();
if (processor_id >= 0) {
- scheduler.Unschedule(old_priority, processor_id, this);
+ scheduler.Unschedule(old_priority, static_cast<u32>(processor_id), this);
}
for (u32 core = 0; core < GlobalScheduler::NUM_CPU_CORES; core++) {
- if (core != processor_id && ((affinity_mask >> core) & 1) != 0) {
+ if (core != static_cast<u32>(processor_id) && ((affinity_mask >> core) & 1) != 0) {
scheduler.Unsuggest(old_priority, core, this);
}
}
@@ -491,14 +479,14 @@ void Thread::AdjustSchedulingOnPriority(u32 old_priority) {
if (processor_id >= 0) {
if (current_thread == this) {
- scheduler.SchedulePrepend(current_priority, processor_id, this);
+ scheduler.SchedulePrepend(current_priority, static_cast<u32>(processor_id), this);
} else {
- scheduler.Schedule(current_priority, processor_id, this);
+ scheduler.Schedule(current_priority, static_cast<u32>(processor_id), this);
}
}
for (u32 core = 0; core < GlobalScheduler::NUM_CPU_CORES; core++) {
- if (core != processor_id && ((affinity_mask >> core) & 1) != 0) {
+ if (core != static_cast<u32>(processor_id) && ((affinity_mask >> core) & 1) != 0) {
scheduler.Suggest(current_priority, core, this);
}
}
@@ -515,7 +503,7 @@ void Thread::AdjustSchedulingOnAffinity(u64 old_affinity_mask, s32 old_core) {
for (u32 core = 0; core < GlobalScheduler::NUM_CPU_CORES; core++) {
if (((old_affinity_mask >> core) & 1) != 0) {
- if (core == old_core) {
+ if (core == static_cast<u32>(old_core)) {
scheduler.Unschedule(current_priority, core, this);
} else {
scheduler.Unsuggest(current_priority, core, this);
@@ -525,7 +513,7 @@ void Thread::AdjustSchedulingOnAffinity(u64 old_affinity_mask, s32 old_core) {
for (u32 core = 0; core < GlobalScheduler::NUM_CPU_CORES; core++) {
if (((affinity_mask >> core) & 1) != 0) {
- if (core == processor_id) {
+ if (core == static_cast<u32>(processor_id)) {
scheduler.Schedule(current_priority, core, this);
} else {
scheduler.Suggest(current_priority, core, this);
diff --git a/src/core/hle/kernel/vm_manager.cpp b/src/core/hle/kernel/vm_manager.cpp
index c7af87073..e6eee09d7 100644
--- a/src/core/hle/kernel/vm_manager.cpp
+++ b/src/core/hle/kernel/vm_manager.cpp
@@ -167,7 +167,7 @@ ResultVal<VAddr> VMManager::FindFreeRegion(VAddr begin, VAddr end, u64 size) con
if (vma_handle == vma_map.cend()) {
// TODO(Subv): Find the correct error code here.
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
const VAddr target = std::max(begin, vma_handle->second.base);
diff --git a/src/core/hle/result.h b/src/core/hle/result.h
index 8a3701151..450f61fea 100644
--- a/src/core/hle/result.h
+++ b/src/core/hle/result.h
@@ -147,6 +147,14 @@ constexpr bool operator!=(const ResultCode& a, const ResultCode& b) {
constexpr ResultCode RESULT_SUCCESS(0);
/**
+ * Placeholder result code used for unknown error codes.
+ *
+ * @note This should only be used when a particular error code
+ * is not known yet.
+ */
+constexpr ResultCode RESULT_UNKNOWN(UINT32_MAX);
+
+/**
* This is an optional value type. It holds a `ResultCode` and, if that code is a success code,
* also holds a result of type `T`. If the code is an error code then trying to access the inner
* value fails, thus ensuring that the ResultCode of functions is always checked properly before
@@ -183,7 +191,7 @@ class ResultVal {
public:
/// Constructs an empty `ResultVal` with the given error code. The code must not be a success
/// code.
- ResultVal(ResultCode error_code = ResultCode(-1)) : result_code(error_code) {
+ ResultVal(ResultCode error_code = RESULT_UNKNOWN) : result_code(error_code) {
ASSERT(error_code.IsError());
}
diff --git a/src/core/hle/service/acc/acc.cpp b/src/core/hle/service/acc/acc.cpp
index 0c0f7ed6e..7e3e311fb 100644
--- a/src/core/hle/service/acc/acc.cpp
+++ b/src/core/hle/service/acc/acc.cpp
@@ -84,7 +84,7 @@ protected:
LOG_ERROR(Service_ACC, "Failed to get profile base and data for user={}",
user_id.Format());
IPC::ResponseBuilder rb{ctx, 2};
- rb.Push(ResultCode(-1)); // TODO(ogniK): Get actual error code
+ rb.Push(RESULT_UNKNOWN); // TODO(ogniK): Get actual error code
}
}
@@ -98,7 +98,7 @@ protected:
} else {
LOG_ERROR(Service_ACC, "Failed to get profile base for user={}", user_id.Format());
IPC::ResponseBuilder rb{ctx, 2};
- rb.Push(ResultCode(-1)); // TODO(ogniK): Get actual error code
+ rb.Push(RESULT_UNKNOWN); // TODO(ogniK): Get actual error code
}
}
@@ -442,7 +442,7 @@ void Module::Interface::TrySelectUserWithoutInteraction(Kernel::HLERequestContex
const auto user_list = profile_manager->GetAllUsers();
if (std::all_of(user_list.begin(), user_list.end(),
[](const auto& user) { return user.uuid == Common::INVALID_UUID; })) {
- rb.Push(ResultCode(-1)); // TODO(ogniK): Find the correct error code
+ rb.Push(RESULT_UNKNOWN); // TODO(ogniK): Find the correct error code
rb.PushRaw<u128>(Common::INVALID_UUID);
return;
}
diff --git a/src/core/hle/service/acc/profile_manager.cpp b/src/core/hle/service/acc/profile_manager.cpp
index 8f9986326..3e756e59e 100644
--- a/src/core/hle/service/acc/profile_manager.cpp
+++ b/src/core/hle/service/acc/profile_manager.cpp
@@ -31,8 +31,8 @@ struct ProfileDataRaw {
static_assert(sizeof(ProfileDataRaw) == 0x650, "ProfileDataRaw has incorrect size.");
// TODO(ogniK): Get actual error codes
-constexpr ResultCode ERROR_TOO_MANY_USERS(ErrorModule::Account, -1);
-constexpr ResultCode ERROR_USER_ALREADY_EXISTS(ErrorModule::Account, -2);
+constexpr ResultCode ERROR_TOO_MANY_USERS(ErrorModule::Account, u32(-1));
+constexpr ResultCode ERROR_USER_ALREADY_EXISTS(ErrorModule::Account, u32(-2));
constexpr ResultCode ERROR_ARGUMENT_IS_NULL(ErrorModule::Account, 20);
constexpr char ACC_SAVE_AVATORS_BASE_PATH[] = "/system/save/8000000000000010/su/avators/";
diff --git a/src/core/hle/service/am/am.cpp b/src/core/hle/service/am/am.cpp
index d52ec4387..a5702e1ab 100644
--- a/src/core/hle/service/am/am.cpp
+++ b/src/core/hle/service/am/am.cpp
@@ -991,7 +991,7 @@ void ILibraryAppletCreator::CreateLibraryApplet(Kernel::HLERequestContext& ctx)
LOG_ERROR(Service_AM, "Applet doesn't exist! applet_id={}", static_cast<u32>(applet_id));
IPC::ResponseBuilder rb{ctx, 2};
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
return;
}
@@ -1027,7 +1027,7 @@ void ILibraryAppletCreator::CreateTransferMemoryStorage(Kernel::HLERequestContex
if (transfer_mem == nullptr) {
LOG_ERROR(Service_AM, "shared_mem is a nullpr for handle={:08X}", handle);
IPC::ResponseBuilder rb{ctx, 2};
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
return;
}
diff --git a/src/core/hle/service/am/applets/web_browser.cpp b/src/core/hle/service/am/applets/web_browser.cpp
index 32283e819..5546ef6e8 100644
--- a/src/core/hle/service/am/applets/web_browser.cpp
+++ b/src/core/hle/service/am/applets/web_browser.cpp
@@ -337,7 +337,7 @@ void WebBrowser::ExecuteInternal() {
void WebBrowser::InitializeShop() {
if (frontend_e_commerce == nullptr) {
LOG_ERROR(Service_AM, "Missing ECommerce Applet frontend!");
- status = ResultCode(-1);
+ status = RESULT_UNKNOWN;
return;
}
@@ -353,7 +353,7 @@ void WebBrowser::InitializeShop() {
if (url == args.end()) {
LOG_ERROR(Service_AM, "Missing EShop Arguments URL for initialization!");
- status = ResultCode(-1);
+ status = RESULT_UNKNOWN;
return;
}
@@ -366,7 +366,7 @@ void WebBrowser::InitializeShop() {
// Less is missing info, More is malformed
if (split_query.size() != 2) {
LOG_ERROR(Service_AM, "EShop Arguments has more than one question mark, malformed");
- status = ResultCode(-1);
+ status = RESULT_UNKNOWN;
return;
}
@@ -390,7 +390,7 @@ void WebBrowser::InitializeShop() {
if (scene == shop_query.end()) {
LOG_ERROR(Service_AM, "No scene parameter was passed via shop query!");
- status = ResultCode(-1);
+ status = RESULT_UNKNOWN;
return;
}
@@ -406,7 +406,7 @@ void WebBrowser::InitializeShop() {
const auto target = target_map.find(scene->second);
if (target == target_map.end()) {
LOG_ERROR(Service_AM, "Scene for shop query is invalid! (scene={})", scene->second);
- status = ResultCode(-1);
+ status = RESULT_UNKNOWN;
return;
}
@@ -427,7 +427,7 @@ void WebBrowser::InitializeOffline() {
if (args.find(WebArgTLVType::DocumentPath) == args.end() ||
args.find(WebArgTLVType::DocumentKind) == args.end() ||
args.find(WebArgTLVType::ApplicationID) == args.end()) {
- status = ResultCode(-1);
+ status = RESULT_UNKNOWN;
LOG_ERROR(Service_AM, "Missing necessary parameters for initialization!");
}
@@ -476,7 +476,7 @@ void WebBrowser::InitializeOffline() {
offline_romfs = GetApplicationRomFS(system, title_id, type);
if (offline_romfs == nullptr) {
- status = ResultCode(-1);
+ status = RESULT_UNKNOWN;
LOG_ERROR(Service_AM, "Failed to find offline data for request!");
}
@@ -496,7 +496,7 @@ void WebBrowser::ExecuteShop() {
const auto check_optional_parameter = [this](const auto& p) {
if (!p.has_value()) {
LOG_ERROR(Service_AM, "Missing one or more necessary parameters for execution!");
- status = ResultCode(-1);
+ status = RESULT_UNKNOWN;
return false;
}
diff --git a/src/core/hle/service/aoc/aoc_u.cpp b/src/core/hle/service/aoc/aoc_u.cpp
index f36ccbc49..30076a53e 100644
--- a/src/core/hle/service/aoc/aoc_u.cpp
+++ b/src/core/hle/service/aoc/aoc_u.cpp
@@ -131,7 +131,7 @@ void AOC_U::ListAddOnContent(Kernel::HLERequestContext& ctx) {
if (out.size() < offset) {
IPC::ResponseBuilder rb{ctx, 2};
// TODO(DarkLordZach): Find the correct error code.
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
return;
}
diff --git a/src/core/hle/service/audio/hwopus.cpp b/src/core/hle/service/audio/hwopus.cpp
index cb4a1160d..cb839e4a2 100644
--- a/src/core/hle/service/audio/hwopus.cpp
+++ b/src/core/hle/service/audio/hwopus.cpp
@@ -80,7 +80,7 @@ private:
LOG_ERROR(Audio, "Failed to decode opus data");
IPC::ResponseBuilder rb{ctx, 2};
// TODO(ogniK): Use correct error code
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
return;
}
@@ -278,7 +278,7 @@ void HwOpus::OpenOpusDecoder(Kernel::HLERequestContext& ctx) {
LOG_ERROR(Audio, "Failed to create Opus decoder (error={}).", error);
IPC::ResponseBuilder rb{ctx, 2};
// TODO(ogniK): Use correct error code
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
return;
}
diff --git a/src/core/hle/service/bcat/backend/boxcat.cpp b/src/core/hle/service/bcat/backend/boxcat.cpp
index 1411a646f..67e39a5c4 100644
--- a/src/core/hle/service/bcat/backend/boxcat.cpp
+++ b/src/core/hle/service/bcat/backend/boxcat.cpp
@@ -114,7 +114,7 @@ void HandleDownloadDisplayResult(const AM::Applets::AppletManager& applet_manage
const auto& frontend{applet_manager.GetAppletFrontendSet()};
frontend.error->ShowCustomErrorText(
- ResultCode(-1), "There was an error while attempting to use Boxcat.",
+ RESULT_UNKNOWN, "There was an error while attempting to use Boxcat.",
DOWNLOAD_RESULT_LOG_MESSAGES[static_cast<std::size_t>(res)], [] {});
}
diff --git a/src/core/hle/service/filesystem/filesystem.cpp b/src/core/hle/service/filesystem/filesystem.cpp
index 11e5c56b7..102017d73 100644
--- a/src/core/hle/service/filesystem/filesystem.cpp
+++ b/src/core/hle/service/filesystem/filesystem.cpp
@@ -58,11 +58,11 @@ ResultCode VfsDirectoryServiceWrapper::CreateFile(const std::string& path_, u64
auto file = dir->CreateFile(FileUtil::GetFilename(path));
if (file == nullptr) {
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
if (!file->Resize(size)) {
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return RESULT_SUCCESS;
}
@@ -80,7 +80,7 @@ ResultCode VfsDirectoryServiceWrapper::DeleteFile(const std::string& path_) cons
}
if (!dir->DeleteFile(FileUtil::GetFilename(path))) {
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return RESULT_SUCCESS;
@@ -94,7 +94,7 @@ ResultCode VfsDirectoryServiceWrapper::CreateDirectory(const std::string& path_)
auto new_dir = dir->CreateSubdirectory(FileUtil::GetFilename(path));
if (new_dir == nullptr) {
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return RESULT_SUCCESS;
}
@@ -104,7 +104,7 @@ ResultCode VfsDirectoryServiceWrapper::DeleteDirectory(const std::string& path_)
auto dir = GetDirectoryRelativeWrapped(backing, FileUtil::GetParentPath(path));
if (!dir->DeleteSubdirectory(FileUtil::GetFilename(path))) {
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return RESULT_SUCCESS;
}
@@ -114,7 +114,7 @@ ResultCode VfsDirectoryServiceWrapper::DeleteDirectoryRecursively(const std::str
auto dir = GetDirectoryRelativeWrapped(backing, FileUtil::GetParentPath(path));
if (!dir->DeleteSubdirectoryRecursive(FileUtil::GetFilename(path))) {
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return RESULT_SUCCESS;
}
@@ -125,7 +125,7 @@ ResultCode VfsDirectoryServiceWrapper::CleanDirectoryRecursively(const std::stri
if (!dir->CleanSubdirectoryRecursive(FileUtil::GetFilename(sanitized_path))) {
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return RESULT_SUCCESS;
@@ -142,7 +142,7 @@ ResultCode VfsDirectoryServiceWrapper::RenameFile(const std::string& src_path_,
return FileSys::ERROR_PATH_NOT_FOUND;
if (!src->Rename(FileUtil::GetFilename(dest_path))) {
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return RESULT_SUCCESS;
}
@@ -160,7 +160,7 @@ ResultCode VfsDirectoryServiceWrapper::RenameFile(const std::string& src_path_,
if (!src->GetContainingDirectory()->DeleteFile(FileUtil::GetFilename(src_path))) {
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return RESULT_SUCCESS;
@@ -177,7 +177,7 @@ ResultCode VfsDirectoryServiceWrapper::RenameDirectory(const std::string& src_pa
return FileSys::ERROR_PATH_NOT_FOUND;
if (!src->Rename(FileUtil::GetFilename(dest_path))) {
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return RESULT_SUCCESS;
}
@@ -189,7 +189,7 @@ ResultCode VfsDirectoryServiceWrapper::RenameDirectory(const std::string& src_pa
src_path, dest_path);
// TODO(DarkLordZach): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
ResultVal<FileSys::VirtualFile> VfsDirectoryServiceWrapper::OpenFile(const std::string& path_,
@@ -287,7 +287,7 @@ ResultVal<FileSys::VirtualFile> FileSystemController::OpenRomFSCurrentProcess()
if (romfs_factory == nullptr) {
// TODO(bunnei): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return romfs_factory->OpenCurrentProcess(system.CurrentProcess()->GetTitleID());
@@ -300,7 +300,7 @@ ResultVal<FileSys::VirtualFile> FileSystemController::OpenRomFS(
if (romfs_factory == nullptr) {
// TODO(bunnei): Find a better error code for this
- return ResultCode(-1);
+ return RESULT_UNKNOWN;
}
return romfs_factory->Open(title_id, storage_id, type);
diff --git a/src/core/hle/service/filesystem/fsp_srv.cpp b/src/core/hle/service/filesystem/fsp_srv.cpp
index cbd5466c1..92162d3e1 100644
--- a/src/core/hle/service/filesystem/fsp_srv.cpp
+++ b/src/core/hle/service/filesystem/fsp_srv.cpp
@@ -785,7 +785,7 @@ void FSP_SRV::OpenFileSystemWithPatch(Kernel::HLERequestContext& ctx) {
static_cast<u8>(type), title_id);
IPC::ResponseBuilder rb{ctx, 2, 0, 0};
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
}
void FSP_SRV::OpenSdCardFileSystem(Kernel::HLERequestContext& ctx) {
@@ -891,7 +891,7 @@ void FSP_SRV::OpenDataStorageByCurrentProcess(Kernel::HLERequestContext& ctx) {
// TODO (bunnei): Find the right error code to use here
LOG_CRITICAL(Service_FS, "no file system interface available!");
IPC::ResponseBuilder rb{ctx, 2};
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
return;
}
@@ -928,7 +928,7 @@ void FSP_SRV::OpenDataStorageByDataId(Kernel::HLERequestContext& ctx) {
"could not open data storage with title_id={:016X}, storage_id={:02X}", title_id,
static_cast<u8>(storage_id));
IPC::ResponseBuilder rb{ctx, 2};
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
return;
}
diff --git a/src/core/hle/service/mii/mii.cpp b/src/core/hle/service/mii/mii.cpp
index 0b3923ad9..0ffc5009e 100644
--- a/src/core/hle/service/mii/mii.cpp
+++ b/src/core/hle/service/mii/mii.cpp
@@ -242,7 +242,7 @@ private:
const auto index = db.IndexOf(uuid);
if (index > MAX_MIIS) {
// TODO(DarkLordZach): Find a better error code
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
rb.Push(index);
} else {
rb.Push(RESULT_SUCCESS);
@@ -268,7 +268,7 @@ private:
IPC::ResponseBuilder rb{ctx, 2};
// TODO(DarkLordZach): Find a better error code
- rb.Push(success ? RESULT_SUCCESS : ResultCode(-1));
+ rb.Push(success ? RESULT_SUCCESS : RESULT_UNKNOWN);
}
void AddOrReplace(Kernel::HLERequestContext& ctx) {
@@ -282,7 +282,7 @@ private:
IPC::ResponseBuilder rb{ctx, 2};
// TODO(DarkLordZach): Find a better error code
- rb.Push(success ? RESULT_SUCCESS : ResultCode(-1));
+ rb.Push(success ? RESULT_SUCCESS : RESULT_UNKNOWN);
}
void Delete(Kernel::HLERequestContext& ctx) {
diff --git a/src/core/hle/service/nfp/nfp.cpp b/src/core/hle/service/nfp/nfp.cpp
index 795d7b716..3bf753dee 100644
--- a/src/core/hle/service/nfp/nfp.cpp
+++ b/src/core/hle/service/nfp/nfp.cpp
@@ -16,10 +16,7 @@
#include "core/hle/service/nfp/nfp_user.h"
namespace Service::NFP {
-
namespace ErrCodes {
-[[maybe_unused]] constexpr ResultCode ERR_TAG_FAILED(ErrorModule::NFP,
- -1); // TODO(ogniK): Find the actual error code
constexpr ResultCode ERR_NO_APPLICATION_AREA(ErrorModule::NFP, 152);
} // namespace ErrCodes
diff --git a/src/core/hle/service/ns/ns.cpp b/src/core/hle/service/ns/ns.cpp
index 15c156ce1..eeba0aa19 100644
--- a/src/core/hle/service/ns/ns.cpp
+++ b/src/core/hle/service/ns/ns.cpp
@@ -271,7 +271,7 @@ void IApplicationManagerInterface::GetApplicationControlData(Kernel::HLERequestC
"output buffer is too small! (actual={:016X}, expected_min=0x4000)", size);
IPC::ResponseBuilder rb{ctx, 2};
// TODO(DarkLordZach): Find a better error code for this.
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
return;
}
@@ -291,7 +291,7 @@ void IApplicationManagerInterface::GetApplicationControlData(Kernel::HLERequestC
0x4000 + control.second->GetSize());
IPC::ResponseBuilder rb{ctx, 2};
// TODO(DarkLordZach): Find a better error code for this.
- rb.Push(ResultCode(-1));
+ rb.Push(RESULT_UNKNOWN);
return;
}
diff --git a/src/core/hle/service/ns/pl_u.cpp b/src/core/hle/service/ns/pl_u.cpp
index 23477315f..db433305f 100644
--- a/src/core/hle/service/ns/pl_u.cpp
+++ b/src/core/hle/service/ns/pl_u.cpp
@@ -97,7 +97,7 @@ void EncryptSharedFont(const std::vector<u32>& input, std::vector<u8>& output,
const auto key = Common::swap32(EXPECTED_RESULT ^ EXPECTED_MAGIC);
std::vector<u32> transformed_font(input.size() + 2);
transformed_font[0] = Common::swap32(EXPECTED_MAGIC);
- transformed_font[1] = Common::swap32(input.size() * sizeof(u32)) ^ key;
+ transformed_font[1] = Common::swap32(static_cast<u32>(input.size() * sizeof(u32))) ^ key;
std::transform(input.begin(), input.end(), transformed_font.begin() + 2,
[key](u32 in) { return in ^ key; });
std::memcpy(output.data() + offset, transformed_font.data(),
diff --git a/src/core/hle/service/time/time.cpp b/src/core/hle/service/time/time.cpp
index 1b9ab8401..62efe021e 100644
--- a/src/core/hle/service/time/time.cpp
+++ b/src/core/hle/service/time/time.cpp
@@ -34,12 +34,12 @@ static void PosixToCalendar(u64 posix_time, CalendarTime& calendar_time,
additional_info = {};
return;
}
- calendar_time.year = tm->tm_year + 1900;
- calendar_time.month = tm->tm_mon + 1;
- calendar_time.day = tm->tm_mday;
- calendar_time.hour = tm->tm_hour;
- calendar_time.minute = tm->tm_min;
- calendar_time.second = tm->tm_sec;
+ calendar_time.year = static_cast<u16_le>(tm->tm_year + 1900);
+ calendar_time.month = static_cast<u8>(tm->tm_mon + 1);
+ calendar_time.day = static_cast<u8>(tm->tm_mday);
+ calendar_time.hour = static_cast<u8>(tm->tm_hour);
+ calendar_time.minute = static_cast<u8>(tm->tm_min);
+ calendar_time.second = static_cast<u8>(tm->tm_sec);
additional_info.day_of_week = tm->tm_wday;
additional_info.day_of_year = tm->tm_yday;
@@ -322,7 +322,7 @@ void Module::Interface::GetClockSnapshot(Kernel::HLERequestContext& ctx) {
if (tm == nullptr) {
LOG_ERROR(Service_Time, "tm is a nullptr");
IPC::ResponseBuilder rb{ctx, 2};
- rb.Push(ResultCode(-1)); // TODO(ogniK): Find appropriate error code
+ rb.Push(RESULT_UNKNOWN); // TODO(ogniK): Find appropriate error code
return;
}
@@ -331,12 +331,12 @@ void Module::Interface::GetClockSnapshot(Kernel::HLERequestContext& ctx) {
const SteadyClockTimePoint steady_clock_time_point{static_cast<u64_le>(ms.count() / 1000), {}};
CalendarTime calendar_time{};
- calendar_time.year = tm->tm_year + 1900;
- calendar_time.month = tm->tm_mon + 1;
- calendar_time.day = tm->tm_mday;
- calendar_time.hour = tm->tm_hour;
- calendar_time.minute = tm->tm_min;
- calendar_time.second = tm->tm_sec;
+ calendar_time.year = static_cast<u16_le>(tm->tm_year + 1900);
+ calendar_time.month = static_cast<u8>(tm->tm_mon + 1);
+ calendar_time.day = static_cast<u8>(tm->tm_mday);
+ calendar_time.hour = static_cast<u8>(tm->tm_hour);
+ calendar_time.minute = static_cast<u8>(tm->tm_min);
+ calendar_time.second = static_cast<u8>(tm->tm_sec);
ClockSnapshot clock_snapshot{};
clock_snapshot.system_posix_time = time_since_epoch;
diff --git a/src/core/hle/service/vi/vi.cpp b/src/core/hle/service/vi/vi.cpp
index 611cecc20..abfc3a801 100644
--- a/src/core/hle/service/vi/vi.cpp
+++ b/src/core/hle/service/vi/vi.cpp
@@ -541,7 +541,7 @@ private:
} else {
// Wait the current thread until a buffer becomes available
ctx.SleepClientThread(
- "IHOSBinderDriver::DequeueBuffer", -1,
+ "IHOSBinderDriver::DequeueBuffer", UINT64_MAX,
[=](Kernel::SharedPtr<Kernel::Thread> thread, Kernel::HLERequestContext& ctx,
Kernel::ThreadWakeupReason reason) {
// Repeat TransactParcel DequeueBuffer when a buffer is available
diff --git a/src/core/perf_stats.cpp b/src/core/perf_stats.cpp
index d2c69d1a0..f1ae9d4df 100644
--- a/src/core/perf_stats.cpp
+++ b/src/core/perf_stats.cpp
@@ -81,7 +81,7 @@ double PerfStats::GetMeanFrametime() {
return 0;
}
const double sum = std::accumulate(perf_history.begin() + IgnoreFrames,
- perf_history.begin() + current_index, 0);
+ perf_history.begin() + current_index, 0.0);
return sum / (current_index - IgnoreFrames);
}