a bunch of changes that actually make the game sort of try to talk to us

This commit is contained in:
Lily Tsuru 2024-03-16 06:42:32 -04:00
parent ee6446a624
commit b1d7490409
9 changed files with 234 additions and 52 deletions

View File

@ -10,6 +10,7 @@ add_executable(lobbyserver
# message implementations # message implementations
messages/PingMessage.cpp messages/PingMessage.cpp
messages/RdirMessage.cpp
) )
lobbyserver_target(lobbyserver) lobbyserver_target(lobbyserver)

View File

@ -2,90 +2,188 @@
#include <boost/asio/read.hpp> #include <boost/asio/read.hpp>
#include <boost/asio/write.hpp> #include <boost/asio/write.hpp>
#include <impl/asio_config.hpp>
#include "DirtySockServer.hpp" #include "DirtySockServer.hpp"
constexpr static auto MAX_PAYLOAD_SIZE = 4 * (1024 * 1024); constexpr static auto MAX_PAYLOAD_SIZE_IN_MB = 4;
constexpr static auto MAX_PAYLOAD_SIZE_IN_BYTES = MAX_PAYLOAD_SIZE_IN_MB * (1024 * 1024);
// All our Asio/network related ops set this expiry time before they call Asio ops
// so that Beast's stream timer stuff can work its magic and automatically timeout.
constexpr static auto EXPIRY_TIME = std::chrono::seconds(10);
namespace ls { namespace ls {
DirtySockClient::DirtySockClient(Stream stream, base::Ref<DirtySockServer> server) DirtySockClient::DirtySockClient(Stream stream, base::Ref<DirtySockServer> server)
: stream(std::move(stream)), server(server) { : stream(std::move(stream)), server(server), writerLock(stream.get_executor()) {
// Setup the cached IP address.
cachedAddress = this->stream.socket().remote_endpoint().address();
}
void DirtySockClient::Send(ConstMessagePtr message) {
BASE_ASSERT(message, "Message pointer MUST be valid.");
if(!message)
return;
// Give up.
if(messageWriteQueue.size() > MAX_MESSAGES_IN_QUEUE)
return Close();
// Add the message to the queue and notify the writer.
messageWriteQueue.push_back(message);
writerLock.NotifyOne();
} }
void DirtySockClient::Close() { void DirtySockClient::Close() {
stream.close(); if(state != State::Closed) {
state = State::Closed;
if(stream.socket().is_open())
stream.close();
}
} }
base::Ref<DirtySockServer> DirtySockClient::GetServer() { base::Ref<DirtySockServer> DirtySockClient::GetServer() {
return server; return server;
} }
base::Awaitable<DirtySockClient::MessagePtr> DirtySockClient::ReadMessage() { base::Awaitable<DirtySockClient::MessagePtr> DirtySockClient::Network_ReadMessage() {
proto::WireMessageHeader header; proto::WireMessageHeader header;
std::vector<u8> propertyBuffer; std::vector<u8> propertyBuffer;
try { try {
// Read the header first
stream.expires_after(EXPIRY_TIME);
co_await asio::async_read(stream, asio::buffer(&header, sizeof(header)), asio::deferred); co_await asio::async_read(stream, asio::buffer(&header, sizeof(header)), asio::deferred);
auto realPayloadSize = header.payloadSize - sizeof(header);
// Sanity check. I don't expect game payloads to ever reach this large, but who knows. // Sanity check. I don't expect game payloads to ever reach this large, but who knows.
if(header.payloadSize > MAX_PAYLOAD_SIZE) { if(realPayloadSize > MAX_PAYLOAD_SIZE_IN_BYTES) {
logger->error("WOAH! Message size {} MB larger than {}MB..", (static_cast<float>(header.payloadSize) / 1024 / 1024), (static_cast<float>(MAX_PAYLOAD_SIZE) / 1024 / 1024)); logger->error("{}: WOAH! Client sent a message with a payload size of {} MB (Max is {}MB).", GetAddress().to_string(), (static_cast<u32>(header.payloadSize) / 1024 / 1024), MAX_PAYLOAD_SIZE_IN_MB);
co_return nullptr; co_return nullptr;
} }
propertyBuffer.resize(header.payloadSize); // If the message type isn't in the server's allowed message list, give up.
// (we probably should throw instead...)
co_await asio::async_read(stream, asio::buffer(propertyBuffer), asio::deferred);
if(!server->allowedMessages.empty()) { if(!server->allowedMessages.empty()) {
if(!server->allowedMessages.contains(static_cast<base::FourCC32_t>(header.typeCode))) if(!server->allowedMessages.contains(static_cast<base::FourCC32_t>(header.typeCode)))
co_return nullptr; co_return nullptr;
} }
// this function may fail and also return nullptr. Maybe we should instead throw an exception here propertyBuffer.resize(realPayloadSize);
stream.expires_after(EXPIRY_TIME);
co_await asio::async_read(stream, asio::buffer(propertyBuffer), asio::deferred);
logger->info("read properties");
// this function may fail and also return nullptr. Maybe we should instead throw an exception there
// (that we leave to callers to catch) // (that we leave to callers to catch)
co_return MessageFactory::CreateAndParseMessage(header, propertyBuffer); co_return MessageFactory::CreateAndParseMessage(header, propertyBuffer);
} catch(bsys::system_error& ec) { } catch(bsys::system_error& ec) {
if(ec.code() != asio::error::operation_aborted) // Instead of bubbling up errors we DO care about, rethrow them to the higher level
logger->error("Error in DirtySockClient::WriteMessage(): {}", ec.what()); // calling us.
if(ec.code() == asio::error::eof)
throw;
if(ec.code() != asio::error::operation_aborted && ec.code() != beast::error::timeout)
logger->error("{}: Error in DirtySockClient::Network_ReadMessage(): {}", GetAddress().to_string(), ec.what());
co_return nullptr; co_return nullptr;
} }
} }
base::Awaitable<void> DirtySockClient::WriteMessage(ConstMessagePtr message) { base::Awaitable<void> DirtySockClient::Network_WriteMessage(ConstMessagePtr message) {
auto buf = std::vector<u8> {}; auto buf = std::vector<u8> {};
message->SerializeTo(buf); message->SerializeTo(buf);
try { try {
stream.expires_after(std::chrono::seconds(EXPIRY_TIME));
co_await asio::async_write(stream, asio::buffer(buf), asio::deferred); co_await asio::async_write(stream, asio::buffer(buf), asio::deferred);
} catch(bsys::system_error& ec) { } catch(bsys::system_error& ec) {
if(ec.code() != asio::error::operation_aborted) if(ec.code() != asio::error::operation_aborted || ec.code() != beast::error::timeout)
logger->error("Error in DirtySockClient::WriteMessage(): {}", ec.what()); logger->error("{}: Error in DirtySockClient::Network_WriteMessage(): {}", GetAddress().to_string(), ec.what());
} }
} }
base::Awaitable<void> DirtySockClient::Run() { base::Awaitable<void> DirtySockClient::Coro_WriterEnd() {
try { try {
while(true) { while(true) {
auto message = co_await ReadMessage(); if(messageWriteQueue.empty()) {
// Notify the reader that it can now start
writerLock.NotifyOne();
// Wait for the reader to notify us to restart
co_await writerLock.Wait([&]() {
return !messageWriteQueue.empty();
});
}
auto& front = messageWriteQueue.front();
co_await Network_WriteMessage(front);
messageWriteQueue.pop_front();
}
} catch(bsys::system_error& ec) {
if(ec.code() != asio::error::operation_aborted || ec.code() != beast::error::timeout)
logger->error("{}: Error in DirtySockClient::Coro_WriterEnd(): {}", GetAddress().to_string(), ec.what());
}
Close();
co_return;
}
base::Awaitable<void> DirtySockClient::Coro_ReaderEnd() {
try {
while(true) {
// Wait for the locker
co_await writerLock.Wait([&]() {
if(state == State::Closed)
return true;
return messageWriteQueue.empty();
});
if(state == State::Closed)
break;
auto message = co_await Network_ReadMessage();
if(message) { if(message) {
// is permitted to call WriteMessage
co_await message->Process(shared_from_this()); co_await message->Process(shared_from_this());
} else { } else {
// This will occur if parsing fails or etc. // This will occur if parsing fails or etc.
logger->error("Error parsing message, closing connection"); logger->error("{}: Error reading or parsing message, closing connection", GetAddress().to_string());
Close(); Close();
co_return; co_return;
} }
// Notify the writer that it can run now.
writerLock.NotifyOne();
} }
} catch(bsys::system_error& ec) { } catch(bsys::system_error& ec) {
if(ec.code() != asio::error::operation_aborted) if(ec.code() == asio::error::eof) {
logger->error("Error in DirtySockClient::Run(): {}", ec.what()); logger->info("{}: Connection closed", GetAddress().to_string());
} else if(ec.code() != asio::error::operation_aborted)
logger->error("{}: Error in DirtySockClient::Coro_ReaderEnd(): {}", GetAddress().to_string(), ec.what());
} }
Close();
co_return;
}
base::Awaitable<void> DirtySockClient::Run() {
logger->info("{}: Got connection", GetAddress().to_string());
asio::co_spawn(
stream.get_executor(), [self = shared_from_this()] {
return self->Coro_WriterEnd();
},
base::DefCoroCompletion("DirtySockClient writing end"));
// Run the reader in the coroutine we're (presumably) spawned on, to
// decrease complexity and callbacks or whatever
co_await Coro_ReaderEnd();
} }
} // namespace ls } // namespace ls

View File

@ -5,6 +5,7 @@
#include <deque> #include <deque>
#include <impl/asio_config.hpp> #include <impl/asio_config.hpp>
#include <base/async_condition_variable.hpp>
#include "IMessage.hpp" #include "IMessage.hpp"
namespace ls { namespace ls {
@ -19,23 +20,48 @@ namespace ls {
DirtySockClient(Stream stream, base::Ref<DirtySockServer> server); DirtySockClient(Stream stream, base::Ref<DirtySockServer> server);
asio::ip::address GetAddress() const {
return cachedAddress;
}
void Close(); void Close();
base::Ref<DirtySockServer> GetServer(); base::Ref<DirtySockServer> GetServer();
base::Awaitable<void> WriteMessage(ConstMessagePtr message); /// Enqueues a message to be sent on the next
void Send(ConstMessagePtr message);
private: private:
friend struct DirtySockServer; friend struct DirtySockServer;
// internal // internal read/write
base::Awaitable<MessagePtr> ReadMessage(); base::Awaitable<MessagePtr> Network_ReadMessage();
base::Awaitable<void> Network_WriteMessage(ConstMessagePtr message);
// coros
base::Awaitable<void> Coro_WriterEnd();
base::Awaitable<void> Coro_ReaderEnd();
/// Call this basically.
base::Awaitable<void> Run(); base::Awaitable<void> Run();
constexpr static u32 MAX_MESSAGES_IN_QUEUE = 8;
enum class State {
Closed,
Open
};
State state { State::Open };
asio::ip::address cachedAddress;
Stream stream; Stream stream;
base::Ref<DirtySockServer> server; base::Ref<DirtySockServer> server;
std::deque<ConstMessagePtr> messageWriteQueue;
base::AsyncConditionVariable writerLock;
base::Ref<spdlog::logger> logger = spdlog::get("ls_dsock_client"); base::Ref<spdlog::logger> logger = spdlog::get("ls_dsock_client");
}; };

View File

@ -1,6 +1,7 @@
#include "IMessage.hpp" #include "IMessage.hpp"
#include <spdlog/spdlog.h> #include <spdlog/spdlog.h>
#include <impl/asio_config.hpp> #include <impl/asio_config.hpp>
// So debug message can just reply // So debug message can just reply
@ -24,14 +25,15 @@ namespace ls {
usize inputIndex = 0; usize inputIndex = 0;
// TODO: Investigate rewriting this using ragel? // TODO: Investigate rewriting this using ragel or something, so it's not something that has to be
// heavily maintained or unit tested to avoid bugs.
enum class ReaderState : u32 { enum class ReaderState : u32 {
InKey, ///< The state machine is currently parsing a key. InKey, ///< The state machine is currently parsing a key.
InValue ///< The state machine is currently parsing a value. InValue ///< The state machine is currently parsing a value.
} state { ReaderState::InKey }; } state { ReaderState::InKey };
// Parse all properties, using a relatively simple state machine. // Parse all properties, using a fairly simple state machine to do so.
// //
// State transition mappings: // State transition mappings:
// = - from key to value state (if in key state) // = - from key to value state (if in key state)
@ -74,9 +76,7 @@ namespace ls {
break; break;
case ReaderState::InValue: case ReaderState::InValue:
// Skip past quotation marks. // Skip past quotation marks.
// I dunno if it's really needed. if(static_cast<char>(inputBuffer[inputIndex]) == '\"' || static_cast<char>(inputBuffer[inputIndex]) == '\'')
// (For reference: SSX3 Dirtysock does the same thing, even including ').
if(static_cast<char>(inputBuffer[inputIndex]) == '\"')
break; break;
val += static_cast<char>(inputBuffer[inputIndex]); val += static_cast<char>(inputBuffer[inputIndex]);
@ -116,7 +116,7 @@ namespace ls {
proto::WireMessageHeader header { proto::WireMessageHeader header {
.typeCode = static_cast<u32>(TypeCode()), .typeCode = static_cast<u32>(TypeCode()),
.typeCodeHi = 0, .typeCodeHi = 0,
.payloadSize = serializedProperties.length() - 1 .payloadSize = sizeof(proto::WireMessageHeader) + serializedProperties.length() - 1
}; };
auto fullLength = sizeof(proto::WireMessageHeader) + serializedProperties.length(); auto fullLength = sizeof(proto::WireMessageHeader) + serializedProperties.length();
@ -136,7 +136,7 @@ namespace ls {
return properties.at(key); return properties.at(key);
} }
void IMessage::SetKey(const std::string& key, const std::string& value) { void IMessage::SetOrAddProperty(const std::string& key, const std::string& value) {
properties[key] = value; properties[key] = value;
} }
@ -148,19 +148,28 @@ namespace ls {
: IMessage(header) { : IMessage(header) {
} }
base::FourCC32_t TypeCode() const override { return static_cast<base::FourCC32_t>(header.typeCode); }
base::Awaitable<void> Process(base::Ref<ls::DirtySockClient> client) override { base::Awaitable<void> Process(base::Ref<ls::DirtySockClient> client) override {
auto* fccbytes = std::bit_cast<u8*>(&header.typeCode); auto* fccbytes = std::bit_cast<u8*>(&header.typeCode);
spdlog::info("Debug Message FourCC lo: \"{:c}{:c}{:c}{:c}\"", fccbytes[0], fccbytes[1], fccbytes[2], fccbytes[3]); spdlog::info("Debug Message: FourCC lo: \"{:c}{:c}{:c}{:c}\"", fccbytes[0], fccbytes[1], fccbytes[2], fccbytes[3]);
spdlog::info("Debug Message Properties:"); spdlog::info("Debug Message Properties:");
for(auto [key, value] : properties) for(auto [key, value] : properties)
spdlog::info("{}: {}", key, value); spdlog::info("{}: {}", key, value);
// :( but it works to just replay the message. // a bit :( however it works to just replay the message.
co_await client->WriteMessage(std::make_shared<DebugMessage>(*this)); client->Send(std::make_shared<DebugMessage>(*this));
co_return;
}
};
struct MessageWithFourCC : IMessage {
explicit MessageWithFourCC(const proto::WireMessageHeader& header)
: IMessage(header) {
}
base::Awaitable<void> Process(base::Ref<ls::DirtySockClient> client) override {
// This class is only used for sending messages, not recieved ones.
co_return; co_return;
} }
}; };
@ -185,4 +194,14 @@ namespace ls {
return ret; return ret;
} }
base::Ref<IMessage> MessageFactory::CreateMessageWithFourCC(base::FourCC32_t fourCC) {
auto fakeHeader = proto::WireMessageHeader {
static_cast<u32>(fourCC),
0,
0
};
return std::make_shared<MessageWithFourCC>(fakeHeader);
}
} // namespace ls } // namespace ls

View File

@ -23,14 +23,14 @@ namespace ls {
/// Serializes to a output data buffer. /// Serializes to a output data buffer.
void SerializeTo(std::vector<u8>& dataBuffer) const; void SerializeTo(std::vector<u8>& dataBuffer) const;
virtual base::FourCC32_t TypeCode() const = 0; base::FourCC32_t TypeCode() const { return static_cast<base::FourCC32_t>(header.typeCode); }
/// Process a single message. /// Process a single message.
virtual base::Awaitable<void> Process(base::Ref<DirtySockClient> client) = 0; virtual base::Awaitable<void> Process(base::Ref<DirtySockClient> client) = 0;
const std::optional<std::string_view> MaybeGetKey(const std::string& key) const; const std::optional<std::string_view> MaybeGetKey(const std::string& key) const;
void SetKey(const std::string& key, const std::string& value); void SetOrAddProperty(const std::string& key, const std::string& value);
const proto::WireMessageHeader& GetHeader() const { return header; } const proto::WireMessageHeader& GetHeader() const { return header; }
@ -45,6 +45,9 @@ namespace ls {
/// Creates and parses the given implementation of IMessage. /// Creates and parses the given implementation of IMessage.
static base::Ref<IMessage> CreateAndParseMessage(const proto::WireMessageHeader& header, std::span<const u8> propertyDataBuffer); static base::Ref<IMessage> CreateAndParseMessage(const proto::WireMessageHeader& header, std::span<const u8> propertyDataBuffer);
/// Creates a message intended for sending to a client.
static base::Ref<IMessage> CreateMessageWithFourCC(base::FourCC32_t fourCC);
private: private:
template <base::FixedString fourcc, class Impl> template <base::FixedString fourcc, class Impl>
friend struct MessageMixin; friend struct MessageMixin;
@ -62,10 +65,6 @@ namespace ls {
static_cast<void>(registered); static_cast<void>(registered);
} }
base::FourCC32_t TypeCode() const override {
return TYPE_CODE;
}
private: private:
static bool Register() { static bool Register() {
MessageFactory::GetFactoryMap().insert({ TYPE_CODE, [](const proto::WireMessageHeader& header) -> base::Ref<IMessage> { MessageFactory::GetFactoryMap().insert({ TYPE_CODE, [](const proto::WireMessageHeader& header) -> base::Ref<IMessage> {
@ -79,9 +78,8 @@ namespace ls {
// :( Makes the boilerplate shorter and sweeter (and easier to change) though. // :( Makes the boilerplate shorter and sweeter (and easier to change) though.
#define LS_MESSAGE(T, fourCC) struct T : public ls::MessageMixin<fourCC, T> #define LS_MESSAGE(T, fourCC) struct T : public ls::MessageMixin<fourCC, T>
#define LS_MESSAGE_CTOR(T, fourCC) \ #define LS_MESSAGE_CTOR(T, fourCC) \
using Super = ls::MessageMixin<fourCC, T>; \
explicit T(const ls::proto::WireMessageHeader& header) \ explicit T(const ls::proto::WireMessageHeader& header) \
: Super(header) { \ : ls::MessageMixin<fourCC, T>(header) { \
} }
} // namespace ls } // namespace ls

View File

@ -26,6 +26,10 @@ namespace ls {
co_return; co_return;
} }
buddyServer = std::make_shared<DirtySockServer>(exec);
buddyServer->Start(config.buddyListenEndpoint);
// TODO: http server? there's apparently some stuff we can have that uses it // TODO: http server? there's apparently some stuff we can have that uses it
logger->info("SSX3LobbyServer started successfully!"); logger->info("SSX3LobbyServer started successfully!");

View File

@ -31,6 +31,7 @@ namespace ls {
bool stopping { false }; bool stopping { false };
base::Ref<DirtySockServer> lobbyServer; base::Ref<DirtySockServer> lobbyServer;
base::Ref<DirtySockServer> buddyServer;
Config config; Config config;

View File

@ -1,15 +1,14 @@
#include <spdlog/cfg/env.h>
#include <spdlog/sinks/stdout_color_sinks.h>
#include <spdlog/spdlog.h>
#include <base/assert.hpp> #include <base/assert.hpp>
#include <base/types.hpp> #include <base/types.hpp>
#include <boost/asio/signal_set.hpp> #include <boost/asio/signal_set.hpp>
#include <boost/asio/thread_pool.hpp> #include <boost/asio/thread_pool.hpp>
#include <thread>
#include <toml++/toml.hpp> #include <toml++/toml.hpp>
#include <spdlog/spdlog.h>
#include <spdlog/cfg/env.h>
#include "Server.hpp" #include "Server.hpp"
#include "spdlog/sinks/stdout_color_sinks.h"
asio::io_context ioc(1); asio::io_context ioc(1);
base::Unique<ls::Server> server; base::Unique<ls::Server> server;
@ -38,7 +37,6 @@ base::Awaitable<void> CoMain(const ls::Server::Config& config) {
} }
int main() { int main() {
// create spdlog loggers // create spdlog loggers
spdlog::create<spdlog::sinks::stdout_color_sink_mt>("ls_server"); spdlog::create<spdlog::sinks::stdout_color_sink_mt>("ls_server");
spdlog::create<spdlog::sinks::stdout_color_sink_mt>("ls_dsock_client"); spdlog::create<spdlog::sinks::stdout_color_sink_mt>("ls_dsock_client");

View File

@ -0,0 +1,37 @@
#include <impl/asio_config.hpp>
#include <spdlog/spdlog.h>
#include "../IMessage.hpp"
#include "../DirtySockClient.hpp"
// clang-format off
LS_MESSAGE(AtDirMessage, "@dir") {
LS_MESSAGE_CTOR(AtDirMessage, "@dir")
base::Awaitable<void> Process(base::Ref<ls::DirtySockClient> client) override {
spdlog::info("Got redir message!");
spdlog::info("@dir Properties:");
for(auto [key, value] : properties)
spdlog::info("{}: {}", key, value);
// create our @dir message we send BACK to the client.
auto rdirOut = ls::MessageFactory::CreateMessageWithFourCC(base::FourCC32<"@dir">());
// TODO: Use the server class to get at this..
rdirOut->SetOrAddProperty("ADDR", "192.168.1.149");
rdirOut->SetOrAddProperty("PORT", "10998");
// sample
rdirOut->SetOrAddProperty("SESS", "1072010288");
rdirOut->SetOrAddProperty("MASK", "0295f3f70ecb1757cd7001b9a7a5eac8");
// bleh
client->Send(rdirOut);
co_return;
}
};
// clang-format on