#include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #include #if(__FreeBSD__) || (__OpenBSD__) || (__NetBSD__) #include #endif namespace llarp { Context::Context() = default; Context::~Context() { m_scheduler->stop(); } bool Context::CallSafe(std::function< void(void) > f) { return logic && logic->queue_func(std::move(f)); } void Context::progress() { std::cout << "." << std::flush; } bool Context::Configure() { logic = std::make_shared< Logic >(); // llarp::LogInfo("loading config at ", configfile); if(configfile.size()) { if(!config->Load(configfile.c_str())) { config.release(); llarp::LogError("failed to load config file ", configfile); return false; } } // System config if(!config->system.pidfile.empty()) { SetPIDFile(config->system.pidfile); } auto threads = config->router.workerThreads(); if(threads <= 0) threads = 1; worker = std::make_shared< llarp::thread::ThreadPool >(threads, 1024, "llarp-worker"); nodedb_dir = config->netdb.nodedbDir(); if(!config->metrics.disableMetrics) { auto &metricsConfig = config->metrics; auto &tags = metricsConfig.metricTags; tags["netid"] = config->router.netId(); tags["nickname"] = config->router.nickname(); setupMetrics(metricsConfig); if(!config->metrics.disableMetricLogs) { m_metricsManager->instance()->addGlobalPublisher( std::make_shared< metrics::StreamPublisher >(std::cerr)); } } return true; } void Context::setupMetrics(const MetricsConfig &metricsConfig) { if(!m_scheduler) { m_scheduler = std::make_unique< thread::Scheduler >(); } if(!m_metricsManager) { m_metricsManager = std::make_unique< metrics::DefaultManagerGuard >(); } if(!m_metricsPublisher) { m_metricsPublisher = std::make_unique< metrics::PublisherScheduler >( *m_scheduler, m_metricsManager->instance()); } if(!metricsConfig.jsonMetricsPath.native().empty()) { m_metricsManager->instance()->addGlobalPublisher( std::make_shared< metrics::JsonPublisher >( std::bind(&metrics::JsonPublisher::directoryPublisher, std::placeholders::_1, metricsConfig.jsonMetricsPath))); } if(!metricsConfig.metricTankHost.empty()) { if(std::getenv("LOKINET_ENABLE_METRIC_TANK")) { static std::string WARNING = R"( __ ___ ____ _ _ ___ _ _ ____ \ \ / / \ | _ \| \ | |_ _| \ | |/ ___| \ \ /\ / / _ \ | |_) | \| || || \| | | _ \ V V / ___ \| _ <| |\ || || |\ | |_| | \_/\_/_/ \_\_| \_\_| \_|___|_| \_|\____| This Lokinet session is not private!! Sending connection metrics to metrictank!! __ ___ ____ _ _ ___ _ _ ____ \ \ / / \ | _ \| \ | |_ _| \ | |/ ___| \ \ /\ / / _ \ | |_) | \| || || \| | | _ \ V V / ___ \| _ <| |\ || || |\ | |_| | \_/\_/_/ \_\_| \_\_| \_|___|_| \_|\____| )"; std::cerr << WARNING << '\n'; std::pair< std::string, std::string > split = absl::StrSplit(metricsConfig.metricTankHost, ':'); m_metricsManager->instance()->addGlobalPublisher( std::make_shared< metrics::MetricTankPublisher >( metricsConfig.metricTags, split.first, stoi(split.second))); } else { std::cerr << "metrictank host specified, but " "LOKINET_ENABLE_METRIC_TANK not set, skipping\n"; } } m_metricsPublisher->setDefault(absl::Seconds(30)); m_scheduler->start(); } void Context::SetPIDFile(const std::string &fname) { pidfile = fname; } int Context::LoadDatabase() { if(!llarp_nodedb::ensure_dir(nodedb_dir.c_str())) { llarp::LogError("nodedb_dir is incorrect"); return 0; } // llarp::LogInfo("nodedb_dir [", nodedb_dir, "] configured!"); ssize_t loaded = nodedb->load_dir(nodedb_dir.c_str()); llarp::LogInfo("nodedb_dir loaded ", loaded, " RCs from [", nodedb_dir, "]"); if(loaded < 0) { // shouldn't be possible llarp::LogError("nodedb_dir directory doesn't exist"); return 0; } return 1; } int Context::Setup() { llarp::LogInfo(LLARP_VERSION, " ", LLARP_RELEASE_MOTTO); llarp::LogInfo("starting up"); mainloop = llarp_make_ev_loop(); crypto = std::make_unique< sodium::CryptoLibSodium >(); cryptoManager = std::make_unique< CryptoManager >(crypto.get()); router = std::make_unique< Router >(worker, mainloop, logic); nodedb = std::make_unique< llarp_nodedb >(router->diskworker()); if(!router->Configure(config.get(), nodedb.get())) { llarp::LogError("Failed to configure router"); return 1; } // must be done after router is made so we can use its disk io worker // must also be done after configure so that netid is properly set if it // is provided by config if(!this->LoadDatabase()) return 1; return 0; } int Context::Run(llarp_main_runtime_opts opts) { if(router == nullptr) { // we are not set up so we should die llarp::LogError("cannot run non configured context"); return 1; } if(!WritePIDFile()) return 1; // run if(!router->StartJsonRpc()) return 1; if(!opts.background) { if(!router->Run()) return 2; } // run net io thread llarp::LogInfo("running mainloop"); llarp_ev_loop_run_single_process(mainloop, logic); // waits for router graceful stop return 0; } bool Context::WritePIDFile() const { if(pidfile.size()) { std::ofstream f(pidfile); f << std::to_string(getpid()); return f.good(); } return true; } void Context::RemovePIDFile() const { if(pidfile.size()) { fs::path f = pidfile; std::error_code ex; if(fs::exists(f, ex)) { if(!ex) fs::remove(f); } } } void Context::HandleSignal(int sig) { if(sig == SIGINT || sig == SIGTERM) { SigINT(); } // TODO(despair): implement hot-reloading config on NT #ifndef _WIN32 if(sig == SIGHUP) { llarp::LogInfo("SIGHUP"); if(router) { router->hiddenServiceContext().ForEachService( [](const std::string &name, const llarp::service::Endpoint_ptr &ep) -> bool { ep->ResetInternalState(); llarp::LogInfo("Reset internal state for ", name); return true; }); router->PumpLL(); Config newconfig; if(!newconfig.Load(configfile.c_str())) { llarp::LogError("failed to load config file ", configfile); return; } // validate config if(!router->ValidateConfig(&newconfig)) { llarp::LogWarn("new configuration is invalid"); return; } // reconfigure if(!router->Reconfigure(&newconfig)) { llarp::LogError("Failed to reconfigure so we will stop."); router->Stop(); return; } llarp::LogInfo("router reconfigured"); } } #endif } void Context::SigINT() { if(router) { /// async stop router on sigint router->Stop(); } else { if(logic) logic->stop(); llarp_ev_loop_stop(mainloop); Close(); } } void Context::Close() { llarp::LogDebug("stop workers"); if(worker) worker->stop(); llarp::LogDebug("free config"); config.release(); llarp::LogDebug("free workers"); worker.reset(); llarp::LogDebug("free nodedb"); nodedb.release(); llarp::LogDebug("free router"); router.release(); llarp::LogDebug("free logic"); logic.reset(); RemovePIDFile(); } bool Context::LoadConfig(const std::string &fname) { config = std::make_unique< Config >(); configfile = fname; return Configure(); } } // namespace llarp struct llarp_main { llarp_main(llarp_config *conf); ~llarp_main() = default; std::unique_ptr< llarp::Context > ctx; }; struct llarp_config { llarp::Config impl; llarp_config() = default; llarp_config(const llarp_config *other) : impl(other->impl) { } }; extern "C" { size_t llarp_main_size() { return sizeof(llarp_main); } size_t llarp_config_size() { return sizeof(llarp_config); } struct llarp_config * llarp_default_config() { llarp_config *conf = new llarp_config(); #ifdef ANDROID // put andrid config overrides here #endif #ifdef IOS // put IOS config overrides here #endif return conf; } void llarp_config_free(struct llarp_config *conf) { if(conf) delete conf; } struct llarp_main * llarp_main_init_from_config(struct llarp_config *conf) { if(conf == nullptr) return nullptr; llarp_main *m = new llarp_main(conf); if(m->ctx->Configure()) return m; delete m; return nullptr; } bool llarp_config_load_file(const char *fname, struct llarp_config **conf) { llarp_config *c = new llarp_config(); if(c->impl.Load(fname)) { *conf = c; return true; } delete c; *conf = nullptr; return false; } void llarp_main_signal(struct llarp_main *ptr, int sig) { ptr->ctx->logic->queue_func( std::bind(&llarp::Context::HandleSignal, ptr->ctx.get(), sig)); } int llarp_main_setup(struct llarp_main *ptr) { return ptr->ctx->Setup(); } int llarp_main_run(struct llarp_main *ptr, struct llarp_main_runtime_opts opts) { return ptr->ctx->Run(opts); } const char * llarp_version() { return LLARP_VERSION; } ssize_t llarp_vpn_io_readpkt(struct llarp_vpn_pkt_reader *r, unsigned char *dst, size_t dstlen) { if(r == nullptr) return -1; if(not r->queue.enabled()) return -1; auto pkt = r->queue.popFront(); ManagedBuffer mbuf = pkt.ConstBuffer(); const llarp_buffer_t &buf = mbuf; if(buf.sz > dstlen || buf.sz == 0) return -1; std::copy_n(buf.base, buf.sz, dst); return buf.sz; } bool llarp_vpn_io_writepkt(struct llarp_vpn_pkt_writer *w, unsigned char *pktbuf, size_t pktlen) { if(pktlen == 0 || pktbuf == nullptr) return false; if(w == nullptr) return false; llarp_vpn_pkt_queue::Packet_t pkt; llarp_buffer_t buf(pktbuf, pktlen); if(not pkt.Load(buf)) return false; return w->queue.pushBack(std::move(pkt)) == llarp::thread::QueueReturn::Success; } bool llarp_main_inject_vpn_by_name(struct llarp_main *ptr, const char *name, struct llarp_vpn_io *io, struct llarp_vpn_ifaddr_info info) { if(name == nullptr || io == nullptr) return false; if(ptr == nullptr || ptr->ctx == nullptr || ptr->ctx->router == nullptr) return false; auto ep = ptr->ctx->router->hiddenServiceContext().GetEndpointByName(name); return ep && ep->InjectVPN(io, info); } void llarp_vpn_io_close_async(struct llarp_vpn_io *io) { if(io == nullptr || io->impl == nullptr) return; static_cast< llarp_vpn_io_impl * >(io->impl)->AsyncClose(); } bool llarp_vpn_io_init(struct llarp_main *ptr, struct llarp_vpn_io *io) { if(io == nullptr || ptr == nullptr) return false; llarp_vpn_io_impl *impl = new llarp_vpn_io_impl(ptr, io); io->impl = impl; return true; } struct llarp_vpn_pkt_writer * llarp_vpn_io_packet_writer(struct llarp_vpn_io *io) { if(io == nullptr || io->impl == nullptr) return nullptr; llarp_vpn_io_impl *vpn = static_cast< llarp_vpn_io_impl * >(io->impl); return &vpn->writer; } struct llarp_vpn_pkt_reader * llarp_vpn_io_packet_reader(struct llarp_vpn_io *io) { if(io == nullptr || io->impl == nullptr) return nullptr; llarp_vpn_io_impl *vpn = static_cast< llarp_vpn_io_impl * >(io->impl); return &vpn->reader; } void llarp_main_free(struct llarp_main *ptr) { delete ptr; } const char * llarp_main_get_default_endpoint_name(struct llarp_main *) { return "default"; } } llarp_main::llarp_main(llarp_config *conf) : ctx(new llarp::Context()) { ctx->config.reset(new llarp::Config(conf->impl)); } namespace llarp { Context * Context::Get(llarp_main *m) { if(m == nullptr || m->ctx == nullptr) return nullptr; return m->ctx.get(); } } // namespace llarp