sigproxy: Modernize RPC calls (remote signals)
[quassel.git] / src / core / coresession.cpp
index 39bd69b..11a9530 100644 (file)
@@ -1,5 +1,5 @@
 /***************************************************************************
- *   Copyright (C) 2005-2016 by the Quassel Project                        *
+ *   Copyright (C) 2005-2018 by the Quassel Project                        *
  *   devel@quassel-irc.org                                                 *
  *                                                                         *
  *   This program is free software; you can redistribute it and/or modify  *
 #include <QtScript>
 
 #include "core.h"
-#include "coreuserinputhandler.h"
-#include "corebuffersyncer.h"
 #include "corebacklogmanager.h"
+#include "corebuffersyncer.h"
 #include "corebufferviewmanager.h"
 #include "coredccconfig.h"
 #include "coreeventmanager.h"
 #include "coreidentity.h"
 #include "coreignorelistmanager.h"
+#include "coreinfo.h"
 #include "coreirclisthelper.h"
 #include "corenetwork.h"
 #include "corenetworkconfig.h"
 #include "coresessioneventprocessor.h"
 #include "coretransfermanager.h"
+#include "coreuserinputhandler.h"
 #include "coreusersettings.h"
 #include "ctcpparser.h"
 #include "eventstringifier.h"
 #include "ircchannel.h"
 #include "ircparser.h"
 #include "ircuser.h"
-#include "logger.h"
 #include "messageevent.h"
 #include "remotepeer.h"
 #include "storage.h"
 #include "util.h"
 
-
 class ProcessMessagesEvent : public QEvent
 {
 public:
-    ProcessMessagesEvent() : QEvent(QEvent::User) {}
+    ProcessMessagesEvent()
+        : QEvent(QEvent::User)
+    {}
 };
 
-
-CoreSession::CoreSession(UserId uid, bool restoreState, QObject *parent)
-    : QObject(parent),
-    _user(uid),
-    _signalProxy(new SignalProxy(SignalProxy::Server, this)),
-    _aliasManager(this),
-    _bufferSyncer(new CoreBufferSyncer(this)),
-    _backlogManager(new CoreBacklogManager(this)),
-    _bufferViewManager(new CoreBufferViewManager(_signalProxy, this)),
-    _dccConfig(new CoreDccConfig(this)),
-    _ircListHelper(new CoreIrcListHelper(this)),
-    _networkConfig(new CoreNetworkConfig("GlobalNetworkConfig", this)),
-    _coreInfo(this),
-    _transferManager(new CoreTransferManager(this)),
-    _eventManager(new CoreEventManager(this)),
-    _eventStringifier(new EventStringifier(this)),
-    _sessionEventProcessor(new CoreSessionEventProcessor(this)),
-    _ctcpParser(new CtcpParser(this)),
-    _ircParser(new IrcParser(this)),
-    scriptEngine(new QScriptEngine(this)),
-    _processMessages(false),
-    _ignoreListManager(this)
-{
-    SignalProxy *p = signalProxy();
+CoreSession::CoreSession(UserId uid, bool restoreState, bool strictIdentEnabled, QObject* parent)
+    : QObject(parent)
+    , _user(uid)
+    , _strictIdentEnabled(strictIdentEnabled)
+    , _signalProxy(new SignalProxy(SignalProxy::Server, this))
+    , _aliasManager(this)
+    , _bufferSyncer(new CoreBufferSyncer(this))
+    , _backlogManager(new CoreBacklogManager(this))
+    , _bufferViewManager(new CoreBufferViewManager(_signalProxy, this))
+    , _dccConfig(new CoreDccConfig(this))
+    , _ircListHelper(new CoreIrcListHelper(this))
+    , _networkConfig(new CoreNetworkConfig("GlobalNetworkConfig", this))
+    , _coreInfo(new CoreInfo(this))
+    , _transferManager(new CoreTransferManager(this))
+    , _eventManager(new CoreEventManager(this))
+    , _eventStringifier(new EventStringifier(this))
+    , _sessionEventProcessor(new CoreSessionEventProcessor(this))
+    , _ctcpParser(new CtcpParser(this))
+    , _ircParser(new IrcParser(this))
+    , scriptEngine(new QScriptEngine(this))
+    , _processMessages(false)
+    , _ignoreListManager(this)
+    , _highlightRuleManager(this)
+{
+    SignalProxy* p = signalProxy();
     p->setHeartBeatInterval(30);
-    p->setMaxHeartBeatCount(60); // 30 mins until we throw a dead socket out
+    p->setMaxHeartBeatCount(60);  // 30 mins until we throw a dead socket out
+
+    connect(p, &SignalProxy::peerRemoved, this, &CoreSession::removeClient);
+
+    connect(p, &SignalProxy::connected, this, &CoreSession::clientsConnected);
+    connect(p, &SignalProxy::disconnected, this, &CoreSession::clientsDisconnected);
 
-    connect(p, SIGNAL(peerRemoved(Peer*)), SLOT(removeClient(Peer*)));
+    p->attachSlot(SIGNAL(sendInput(BufferInfo,QString)), this, &CoreSession::msgFromClient);
+    p->attachSignal(this, &CoreSession::displayMsg);
+    p->attachSignal(this, &CoreSession::displayStatusMsg);
 
-    connect(p, SIGNAL(connected()), SLOT(clientsConnected()));
-    connect(p, SIGNAL(disconnected()), SLOT(clientsDisconnected()));
+    p->attachSignal(this, &CoreSession::identityCreated);
+    p->attachSignal(this, &CoreSession::identityRemoved);
+    p->attachSlot(SIGNAL(createIdentity(Identity,QVariantMap)), this, selectOverload<const Identity&, const QVariantMap&>(&CoreSession::createIdentity));
+    p->attachSlot(SIGNAL(removeIdentity(IdentityId)), this, &CoreSession::removeIdentity);
 
-    p->attachSlot(SIGNAL(sendInput(BufferInfo, QString)), this, SLOT(msgFromClient(BufferInfo, QString)));
-    p->attachSignal(this, SIGNAL(displayMsg(Message)));
-    p->attachSignal(this, SIGNAL(displayStatusMsg(QString, QString)));
+    p->attachSignal(this, &CoreSession::networkCreated);
+    p->attachSignal(this, &CoreSession::networkRemoved);
+    p->attachSlot(SIGNAL(createNetwork(NetworkInfo,QStringList)), this,&CoreSession::createNetwork);
+    p->attachSlot(SIGNAL(removeNetwork(NetworkId)), this, &CoreSession::removeNetwork);
 
-    p->attachSignal(this, SIGNAL(identityCreated(const Identity &)));
-    p->attachSignal(this, SIGNAL(identityRemoved(IdentityId)));
-    p->attachSlot(SIGNAL(createIdentity(const Identity &, const QVariantMap &)), this, SLOT(createIdentity(const Identity &, const QVariantMap &)));
-    p->attachSlot(SIGNAL(removeIdentity(IdentityId)), this, SLOT(removeIdentity(IdentityId)));
+    p->attachSlot(SIGNAL(changePassword(PeerPtr,QString,QString,QString)), this, &CoreSession::changePassword);
+    p->attachSignal(this, &CoreSession::passwordChanged);
 
-    p->attachSignal(this, SIGNAL(networkCreated(NetworkId)));
-    p->attachSignal(this, SIGNAL(networkRemoved(NetworkId)));
-    p->attachSlot(SIGNAL(createNetwork(const NetworkInfo &, const QStringList &)), this, SLOT(createNetwork(const NetworkInfo &, const QStringList &)));
-    p->attachSlot(SIGNAL(removeNetwork(NetworkId)), this, SLOT(removeNetwork(NetworkId)));
+    p->attachSlot(SIGNAL(kickClient(int)), this, &CoreSession::kickClient);
+    p->attachSignal(this, &CoreSession::disconnectFromCore);
 
-    p->attachSlot(SIGNAL(changePassword(PeerPtr,QString,QString,QString)), this, SLOT(changePassword(PeerPtr,QString,QString,QString)));
-    p->attachSignal(this, SIGNAL(passwordChanged(PeerPtr,bool)));
+    QVariantMap data;
+    data["quasselVersion"] = Quassel::buildInfo().fancyVersionString;
+    data["quasselBuildDate"] = Quassel::buildInfo().commitDate;  // "BuildDate" for compatibility
+    data["startTime"] = Core::instance()->startTime();
+    data["sessionConnectedClients"] = 0;
+    _coreInfo->setCoreData(data);
 
     loadSettings();
     initScriptEngine();
 
     eventManager()->registerObject(ircParser(), EventManager::NormalPriority);
-    eventManager()->registerObject(sessionEventProcessor(), EventManager::HighPriority); // needs to process events *before* the stringifier!
+    eventManager()->registerObject(sessionEventProcessor(), EventManager::HighPriority);  // needs to process events *before* the stringifier!
     eventManager()->registerObject(ctcpParser(), EventManager::NormalPriority);
     eventManager()->registerObject(eventStringifier(), EventManager::NormalPriority);
-    eventManager()->registerObject(this, EventManager::LowPriority); // for sending MessageEvents to the client
+    eventManager()->registerObject(this, EventManager::LowPriority);  // for sending MessageEvents to the client
     // some events need to be handled after msg generation
     eventManager()->registerObject(sessionEventProcessor(), EventManager::LowPriority, "lateProcess");
     eventManager()->registerObject(ctcpParser(), EventManager::LowPriority, "send");
 
     // periodically save our session state
-    connect(&(Core::instance()->syncTimer()), SIGNAL(timeout()), this, SLOT(saveSessionState()));
+    connect(Core::instance()->syncTimer(), &QTimer::timeout, this, &CoreSession::saveSessionState);
 
     p->synchronize(_bufferSyncer);
     p->synchronize(&aliasManager());
@@ -126,8 +138,11 @@ CoreSession::CoreSession(UserId uid, bool restoreState, QObject *parent)
     p->synchronize(dccConfig());
     p->synchronize(ircListHelper());
     p->synchronize(networkConfig());
-    p->synchronize(&_coreInfo);
+    p->synchronize(_coreInfo);
     p->synchronize(&_ignoreListManager);
+    p->synchronize(&_highlightRuleManager);
+    // Listen to network removed events
+    connect(this, &CoreSession::networkRemoved, &_highlightRuleManager, &HighlightRuleManager::networkRemoved);
     p->synchronize(transferManager());
     // Restore session state
     if (restoreState)
@@ -136,69 +151,48 @@ CoreSession::CoreSession(UserId uid, bool restoreState, QObject *parent)
     emit initialized();
 }
 
-
-CoreSession::~CoreSession()
+void CoreSession::shutdown()
 {
     saveSessionState();
 
-    /* Why partially duplicate CoreNetwork destructor?  When each CoreNetwork quits in the
-     * destructor, disconnections are processed in sequence for each object.  For many IRC servers
-     * on a slow network, this could significantly delay core shutdown [msecs wait * network count].
-     *
-     * Here, CoreSession first calls disconnect on all networks, letting them all start
-     * disconnecting before beginning to sequentially wait for each network.  Ideally, after the
-     * first network is disconnected, the other networks will have already closed.  Worst-case may
-     * still wait [msecs wait time * num. of networks], but the risk should be much lower.
-     *
-     * CoreNetwork should still do cleanup in its own destructor in case a network is deleted
-     * outside of deleting the whole CoreSession.
-     *
-     * If this proves to be problematic in the future, there's an alternative Qt signal-based system
-     * implemented in another pull request that guarentees a maximum amount of time to disconnect,
-     * but at the cost of more complex code.
-     *
-     * See https://github.com/quassel/quassel/pull/203
-     */
-
-    foreach(CoreNetwork *net, _networks.values()) {
-        // Request each network properly disconnect, but don't count as user-requested disconnect
-        if (net->socketConnected()) {
-            // Only try if the socket's fully connected (not initializing or disconnecting).
-            // Force an immediate disconnect, jumping the command queue.  Ensures the proper QUIT is
-            // shown even if other messages are queued.
-            net->disconnectFromIrc(false, QString(), false, true);
+    // Request disconnect from all connected networks in parallel, and wait until every network
+    // has emitted the disconnected() signal before deleting the session itself
+    for (CoreNetwork* net : _networks.values()) {
+        if (net->socketState() != QAbstractSocket::UnconnectedState) {
+            _networksPendingDisconnect.insert(net->networkId());
+            connect(net, &CoreNetwork::disconnected, this, &CoreSession::onNetworkDisconnected);
+            net->shutdown();
         }
     }
 
-    // Process the putCmd events that trigger the quit.  Without this, shutting down the core
-    // results in abrubtly closing the socket rather than sending the QUIT as expected.
-    QCoreApplication::processEvents();
-
-    foreach(CoreNetwork *net, _networks.values()) {
-        // Wait briefly for each network to disconnect.  Sometimes it takes a little while to send.
-        if (!net->forceDisconnect()) {
-            qWarning() << "Timed out quitting network" << net->networkName() <<
-                          "(user ID " << net->userId() << ")";
-        }
-        // Delete the network now that it's closed
-        delete net;
+    if (_networksPendingDisconnect.isEmpty()) {
+        // Nothing to do, suicide so the core can shut down
+        deleteLater();
     }
 }
 
-
-CoreNetwork *CoreSession::network(NetworkId id) const
+void CoreSession::onNetworkDisconnected(NetworkId networkId)
 {
-    if (_networks.contains(id)) return _networks[id];
-    return 0;
+    _networksPendingDisconnect.remove(networkId);
+    if (_networksPendingDisconnect.isEmpty()) {
+        // We're done, suicide so the core can shut down
+        deleteLater();
+    }
 }
 
-
-CoreIdentity *CoreSession::identity(IdentityId id) const
+CoreNetwork* CoreSession::network(NetworkId id) const
 {
-    if (_identities.contains(id)) return _identities[id];
-    return 0;
+    if (_networks.contains(id))
+        return _networks[id];
+    return nullptr;
 }
 
+CoreIdentity* CoreSession::identity(IdentityId id) const
+{
+    if (_identities.contains(id))
+        return _identities[id];
+    return nullptr;
+}
 
 void CoreSession::loadSettings()
 {
@@ -207,7 +201,7 @@ void CoreSession::loadSettings()
     // migrate to db
     QList<IdentityId> ids = s.identityIds();
     QList<NetworkInfo> networkInfos = Core::networks(user());
-    foreach(IdentityId id, ids) {
+    foreach (IdentityId id, ids) {
         CoreIdentity identity(s.identity(id));
         IdentityId newId = Core::createIdentity(user(), identity);
         QList<NetworkInfo>::iterator networkIter = networkInfos.begin();
@@ -225,16 +219,15 @@ void CoreSession::loadSettings()
     }
     // end of migration
 
-    foreach(CoreIdentity identity, Core::identities(user())) {
+    foreach (CoreIdentity identity, Core::identities(user())) {
         createIdentity(identity);
     }
 
-    foreach(NetworkInfo info, Core::networks(user())) {
+    foreach (NetworkInfo info, Core::networks(user())) {
         createNetwork(info);
     }
 }
 
-
 void CoreSession::saveSessionState() const
 {
     _bufferSyncer->storeDirtyIds();
@@ -242,51 +235,61 @@ void CoreSession::saveSessionState() const
     _networkConfig->save();
 }
 
-
 void CoreSession::restoreSessionState()
 {
     QList<NetworkId> nets = Core::connectedNetworks(user());
-    CoreNetwork *net = 0;
-    foreach(NetworkId id, nets) {
+    CoreNetwork* net = nullptr;
+    foreach (NetworkId id, nets) {
         net = network(id);
         Q_ASSERT(net);
         net->connectToIrc();
     }
 }
 
-
-void CoreSession::addClient(RemotePeer *peer)
+void CoreSession::addClient(RemotePeer* peer)
 {
+    signalProxy()->setTargetPeer(peer);
+
     peer->dispatch(sessionState());
     signalProxy()->addPeer(peer);
-}
+    _coreInfo->setConnectedClientData(signalProxy()->peerCount(), signalProxy()->peerData());
 
+    signalProxy()->setTargetPeer(nullptr);
+}
 
-void CoreSession::addClient(InternalPeer *peer)
+void CoreSession::addClient(InternalPeerpeer)
 {
     signalProxy()->addPeer(peer);
-    emit sessionState(sessionState());
+    emit sessionStateReceived(sessionState());
 }
 
-
-void CoreSession::removeClient(Peer *peer)
+void CoreSession::removeClient(Peer* peer)
 {
-    RemotePeer *p = qobject_cast<RemotePeer *>(peer);
+    auto* p = qobject_cast<RemotePeer*>(peer);
     if (p)
-        quInfo() << qPrintable(tr("Client")) << p->description() << qPrintable(tr("disconnected (UserId: %1).").arg(user().toInt()));
+        qInfo() << qPrintable(tr("Client")) << p->description() << qPrintable(tr("disconnected (UserId: %1).").arg(user().toInt()));
+    _coreInfo->setConnectedClientData(signalProxy()->peerCount(), signalProxy()->peerData());
 }
 
-
 QHash<QString, QString> CoreSession::persistentChannels(NetworkId id) const
 {
     return Core::persistentChannels(user(), id);
 }
 
+QHash<QString, QByteArray> CoreSession::bufferCiphers(NetworkId id) const
+{
+    return Core::bufferCiphers(user(), id);
+}
+
+void CoreSession::setBufferCipher(NetworkId id, const QString& bufferName, const QByteArray& cipher) const
+{
+    Core::setBufferCipher(user(), id, bufferName, cipher);
+}
 
 // FIXME switch to BufferId
 void CoreSession::msgFromClient(BufferInfo bufinfo, QString msg)
 {
-    CoreNetwork *net = network(bufinfo.networkId());
+    CoreNetworknet = network(bufinfo.networkId());
     if (net) {
         net->userInput(bufinfo, msg);
     }
@@ -295,11 +298,15 @@ void CoreSession::msgFromClient(BufferInfo bufinfo, QString msg)
     }
 }
 
-
 // ALL messages coming pass through these functions before going to the GUI.
 // So this is the perfect place for storing the backlog and log stuff.
-void CoreSession::recvMessageFromServer(NetworkId networkId, Message::Type type, BufferInfo::Type bufferType,
-    const QString &target, const QString &text_, const QString &sender, Message::Flags flags)
+void CoreSession::recvMessageFromServer(NetworkId networkId,
+                                        Message::Type type,
+                                        BufferInfo::Type bufferType,
+                                        const QString& target,
+                                        const QString& text_,
+                                        const QString& sender,
+                                        Message::Flags flags)
 {
     // U+FDD0 and U+FDD1 are special characters for Qt's text engine, specifically they mark the boundaries of
     // text frames in a QTextDocument. This might lead to problems in widgets displaying QTextDocuments (such as
@@ -309,11 +316,14 @@ void CoreSession::recvMessageFromServer(NetworkId networkId, Message::Type type,
     RawMessage rawMsg(networkId, type, bufferType, target, text, sender, flags);
 
     // check for HardStrictness ignore
-    CoreNetwork *currentNetwork = network(networkId);
+    CoreNetworkcurrentNetwork = network(networkId);
     QString networkName = currentNetwork ? currentNetwork->networkName() : QString("");
     if (_ignoreListManager.match(rawMsg, networkName) == IgnoreListManager::HardStrictness)
         return;
 
+    if (currentNetwork && _highlightRuleManager.match(rawMsg, currentNetwork->myNick(), currentNetwork->identityPtr()->nicks()))
+        rawMsg.flags |= Message::Flag::Highlight;
+
     _messageQueue << rawMsg;
     if (!_processMessages) {
         _processMessages = true;
@@ -321,32 +331,30 @@ void CoreSession::recvMessageFromServer(NetworkId networkId, Message::Type type,
     }
 }
 
-
 void CoreSession::recvStatusMsgFromServer(QString msg)
 {
-    CoreNetwork *net = qobject_cast<CoreNetwork *>(sender());
+    auto* net = qobject_cast<CoreNetwork*>(sender());
     Q_ASSERT(net);
     emit displayStatusMsg(net->networkName(), msg);
 }
 
-
-void CoreSession::processMessageEvent(MessageEvent *event)
+void CoreSession::processMessageEvent(MessageEvent* event)
 {
-    recvMessageFromServer(event->networkId(), event->msgType(), event->bufferType(),
-        event->target().isNull() ? "" : event->target(),
-        event->text().isNull() ? "" : event->text(),
-        event->sender().isNull() ? "" : event->sender(),
-        event->msgFlags());
+    recvMessageFromServer(event->networkId(),
+                          event->msgType(),
+                          event->bufferType(),
+                          event->target().isNull() ? "" : event->target(),
+                          event->text().isNull() ? "" : event->text(),
+                          event->sender().isNull() ? "" : event->sender(),
+                          event->msgFlags());
 }
 
-
 QList<BufferInfo> CoreSession::buffers() const
 {
     return Core::requestBuffers(user());
 }
 
-
-void CoreSession::customEvent(QEvent *event)
+void CoreSession::customEvent(QEvent* event)
 {
     if (event->type() != QEvent::User)
         return;
@@ -355,28 +363,34 @@ void CoreSession::customEvent(QEvent *event)
     event->accept();
 }
 
-
 void CoreSession::processMessages()
 {
     if (_messageQueue.count() == 1) {
-        const RawMessage &rawMsg = _messageQueue.first();
+        const RawMessagerawMsg = _messageQueue.first();
         bool createBuffer = !(rawMsg.flags & Message::Redirected);
         BufferInfo bufferInfo = Core::bufferInfo(user(), rawMsg.networkId, rawMsg.bufferType, rawMsg.target, createBuffer);
         if (!bufferInfo.isValid()) {
             Q_ASSERT(!createBuffer);
             bufferInfo = Core::bufferInfo(user(), rawMsg.networkId, BufferInfo::StatusBuffer, "");
         }
-        Message msg(bufferInfo, rawMsg.type, rawMsg.text, rawMsg.sender, rawMsg.flags);
-        if(Core::storeMessage(msg))
+        Message msg(bufferInfo,
+                    rawMsg.type,
+                    rawMsg.text,
+                    rawMsg.sender,
+                    senderPrefixes(rawMsg.sender, bufferInfo),
+                    realName(rawMsg.sender, rawMsg.networkId),
+                    avatarUrl(rawMsg.sender, rawMsg.networkId),
+                    rawMsg.flags);
+        if (Core::storeMessage(msg))
             emit displayMsg(msg);
     }
     else {
-        QHash<NetworkId, QHash<QString, BufferInfo> > bufferInfoCache;
+        QHash<NetworkId, QHash<QString, BufferInfo>> bufferInfoCache;
         MessageList messages;
-        QList<RawMessage> redirectedMessages; // list of Messages which don't enforce a buffer creation
+        QList<RawMessage> redirectedMessages;  // list of Messages which don't enforce a buffer creation
         BufferInfo bufferInfo;
         for (int i = 0; i < _messageQueue.count(); i++) {
-            const RawMessage &rawMsg = _messageQueue.at(i);
+            const RawMessagerawMsg = _messageQueue.at(i);
             if (bufferInfoCache.contains(rawMsg.networkId) && bufferInfoCache[rawMsg.networkId].contains(rawMsg.target)) {
                 bufferInfo = bufferInfoCache[rawMsg.networkId][rawMsg.target];
             }
@@ -390,13 +404,20 @@ void CoreSession::processMessages()
                 }
                 bufferInfoCache[rawMsg.networkId][rawMsg.target] = bufferInfo;
             }
-            Message msg(bufferInfo, rawMsg.type, rawMsg.text, rawMsg.sender, rawMsg.flags);
+            Message msg(bufferInfo,
+                        rawMsg.type,
+                        rawMsg.text,
+                        rawMsg.sender,
+                        senderPrefixes(rawMsg.sender, bufferInfo),
+                        realName(rawMsg.sender, rawMsg.networkId),
+                        avatarUrl(rawMsg.sender, rawMsg.networkId),
+                        rawMsg.flags);
             messages << msg;
         }
 
         // recheck if there exists a buffer to store a redirected message in
         for (int i = 0; i < redirectedMessages.count(); i++) {
-            const RawMessage &rawMsg = redirectedMessages.at(i);
+            const RawMessagerawMsg = redirectedMessages.at(i);
             if (bufferInfoCache.contains(rawMsg.networkId) && bufferInfoCache[rawMsg.networkId].contains(rawMsg.target)) {
                 bufferInfo = bufferInfoCache[rawMsg.networkId][rawMsg.target];
             }
@@ -406,11 +427,18 @@ void CoreSession::processMessages()
                 // add the StatusBuffer to the Cache in case there are more Messages for the original target
                 bufferInfoCache[rawMsg.networkId][rawMsg.target] = bufferInfo;
             }
-            Message msg(bufferInfo, rawMsg.type, rawMsg.text, rawMsg.sender, rawMsg.flags);
+            Message msg(bufferInfo,
+                        rawMsg.type,
+                        rawMsg.text,
+                        rawMsg.sender,
+                        senderPrefixes(rawMsg.sender, bufferInfo),
+                        realName(rawMsg.sender, rawMsg.networkId),
+                        avatarUrl(rawMsg.sender, rawMsg.networkId),
+                        rawMsg.flags);
             messages << msg;
         }
 
-        if(Core::storeMessages(messages)) {
+        if (Core::storeMessages(messages)) {
             // FIXME: extend protocol to a displayMessages(MessageList)
             for (int i = 0; i < messages.count(); i++) {
                 emit displayMsg(messages[i]);
@@ -421,6 +449,52 @@ void CoreSession::processMessages()
     _messageQueue.clear();
 }
 
+QString CoreSession::senderPrefixes(const QString& sender, const BufferInfo& bufferInfo) const
+{
+    CoreNetwork* currentNetwork = network(bufferInfo.networkId());
+    if (!currentNetwork) {
+        return {};
+    }
+
+    if (bufferInfo.type() != BufferInfo::ChannelBuffer) {
+        return {};
+    }
+
+    IrcChannel* currentChannel = currentNetwork->ircChannel(bufferInfo.bufferName());
+    if (!currentChannel) {
+        return {};
+    }
+
+    const QString modes = currentChannel->userModes(nickFromMask(sender).toLower());
+    return currentNetwork->modesToPrefixes(modes);
+}
+
+QString CoreSession::realName(const QString& sender, NetworkId networkId) const
+{
+    CoreNetwork* currentNetwork = network(networkId);
+    if (!currentNetwork) {
+        return {};
+    }
+
+    IrcUser* currentUser = currentNetwork->ircUser(nickFromMask(sender));
+    if (!currentUser) {
+        return {};
+    }
+
+    return currentUser->realName();
+}
+
+QString CoreSession::avatarUrl(const QString& sender, NetworkId networkId) const
+{
+    Q_UNUSED(sender);
+    Q_UNUSED(networkId);
+    // Currently we do not have a way to retrieve this value yet.
+    //
+    // This likely will require implementing IRCv3's METADATA spec.
+    // See https://ircv3.net/irc/
+    // And https://blog.irccloud.com/avatars/
+    return "";
+}
 
 Protocol::SessionState CoreSession::sessionState() const
 {
@@ -428,36 +502,33 @@ Protocol::SessionState CoreSession::sessionState() const
     QVariantList networkIds;
     QVariantList identities;
 
-    foreach(const BufferInfo &id, buffers())
+    foreach (const BufferInfo& id, buffers())
         bufferInfos << QVariant::fromValue(id);
-    foreach(const NetworkId &id, _networks.keys())
+    foreach (const NetworkId& id, _networks.keys())
         networkIds << QVariant::fromValue(id);
-    foreach(const Identity *i, _identities.values())
+    foreach (const Identity* i, _identities.values())
         identities << QVariant::fromValue(*i);
 
     return Protocol::SessionState(identities, bufferInfos, networkIds);
 }
 
-
 void CoreSession::initScriptEngine()
 {
-    signalProxy()->attachSlot(SIGNAL(scriptRequest(QString)), this, SLOT(scriptRequest(QString)));
-    signalProxy()->attachSignal(this, SIGNAL(scriptResult(QString)));
+    signalProxy()->attachSlot(SIGNAL(scriptRequest(QString)), this, &CoreSession::scriptRequest);
+    signalProxy()->attachSignal(this, &CoreSession::scriptResult);
 
     // FIXME
-    //QScriptValue storage_ = scriptEngine->newQObject(storage);
-    //scriptEngine->globalObject().setProperty("storage", storage_);
+    // QScriptValue storage_ = scriptEngine->newQObject(storage);
+    // scriptEngine->globalObject().setProperty("storage", storage_);
 }
 
-
 void CoreSession::scriptRequest(QString script)
 {
     emit scriptResult(scriptEngine->evaluate(script).toString());
 }
 
-
 /*** Identity Handling ***/
-void CoreSession::createIdentity(const Identity &identity, const QVariantMap &additional)
+void CoreSession::createIdentity(const Identity& identity, const QVariantMap& additional)
 {
 #ifndef HAVE_SSL
     Q_UNUSED(additional)
@@ -478,30 +549,39 @@ void CoreSession::createIdentity(const Identity &identity, const QVariantMap &ad
         createIdentity(coreIdentity);
 }
 
+const QString CoreSession::strictCompliantIdent(const CoreIdentity* identity)
+{
+    if (_strictIdentEnabled) {
+        // Strict mode enabled: only allow the user's Quassel username as an ident
+        return Core::instance()->strictSysIdent(_user);
+    }
+    else {
+        // Strict mode disabled: allow any identity specified
+        return identity->ident();
+    }
+}
 
-void CoreSession::createIdentity(const CoreIdentity &identity)
+void CoreSession::createIdentity(const CoreIdentityidentity)
 {
-    CoreIdentity *coreIdentity = new CoreIdentity(identity, this);
+    auto* coreIdentity = new CoreIdentity(identity, this);
     _identities[identity.id()] = coreIdentity;
     // CoreIdentity has its own synchronize method since its "private" sslManager needs to be synced as well
     coreIdentity->synchronize(signalProxy());
-    connect(coreIdentity, SIGNAL(updated()), this, SLOT(updateIdentityBySender()));
+    connect(coreIdentity, &SyncableObject::updated, this, &CoreSession::updateIdentityBySender);
     emit identityCreated(*coreIdentity);
 }
 
-
 void CoreSession::updateIdentityBySender()
 {
-    CoreIdentity *identity = qobject_cast<CoreIdentity *>(sender());
+    auto* identity = qobject_cast<CoreIdentity*>(sender());
     if (!identity)
         return;
     Core::updateIdentity(user(), *identity);
 }
 
-
 void CoreSession::removeIdentity(IdentityId id)
 {
-    CoreIdentity *identity = _identities.take(id);
+    CoreIdentityidentity = _identities.take(id);
     if (identity) {
         emit identityRemoved(id);
         Core::removeIdentity(user(), id);
@@ -509,10 +589,9 @@ void CoreSession::removeIdentity(IdentityId id)
     }
 }
 
-
 /*** Network Handling ***/
 
-void CoreSession::createNetwork(const NetworkInfo &info_, const QStringList &persistentChans)
+void CoreSession::createNetwork(const NetworkInfo& info_, const QStringList& persistentChans)
 {
     NetworkInfo info = info_;
     int id;
@@ -521,15 +600,16 @@ void CoreSession::createNetwork(const NetworkInfo &info_, const QStringList &per
         Core::createNetwork(user(), info);
 
     if (!info.networkId.isValid()) {
-        qWarning() << qPrintable(tr("CoreSession::createNetwork(): Got invalid networkId from Core when trying to create network %1!").arg(info.networkName));
+        qWarning() << qPrintable(
+            tr("CoreSession::createNetwork(): Got invalid networkId from Core when trying to create network %1!").arg(info.networkName));
         return;
     }
 
     id = info.networkId.toInt();
     if (!_networks.contains(id)) {
         // create persistent chans
-        QRegExp rx("\\s*(\\S+)(?:\\s*(\\S+))?\\s*");
-        foreach(QString channel, persistentChans) {
+        QRegExp rx(R"(\s*(\S+)(?:\s*(\S+))?\s*)");
+        foreach (QString channel, persistentChans) {
             if (!rx.exactMatch(channel)) {
                 qWarning() << QString("Invalid persistent channel declaration: %1").arg(channel);
                 continue;
@@ -540,11 +620,10 @@ void CoreSession::createNetwork(const NetworkInfo &info_, const QStringList &per
                 Core::setPersistentChannelKey(user(), info.networkId, rx.cap(1), rx.cap(2));
         }
 
-        CoreNetwork *net = new CoreNetwork(id, this);
-        connect(net, SIGNAL(displayMsg(NetworkId, Message::Type, BufferInfo::Type, const QString &, const QString &, const QString &, Message::Flags)),
-            SLOT(recvMessageFromServer(NetworkId, Message::Type, BufferInfo::Type, const QString &, const QString &, const QString &, Message::Flags)));
-        connect(net, SIGNAL(displayStatusMsg(QString)), SLOT(recvStatusMsgFromServer(QString)));
-        connect(net, SIGNAL(disconnected(NetworkId)), SIGNAL(networkDisconnected(NetworkId)));
+        CoreNetwork* net = new CoreNetwork(id, this);
+        connect(net, &CoreNetwork::displayMsg, this, &CoreSession::recvMessageFromServer);
+        connect(net, &CoreNetwork::displayStatusMsg, this, &CoreSession::recvStatusMsgFromServer);
+        connect(net, &CoreNetwork::disconnected, this, &CoreSession::networkDisconnected);
 
         net->setNetworkInfo(info);
         net->setProxy(signalProxy());
@@ -558,19 +637,18 @@ void CoreSession::createNetwork(const NetworkInfo &info_, const QStringList &per
     }
 }
 
-
 void CoreSession::removeNetwork(NetworkId id)
 {
     // Make sure the network is disconnected!
-    CoreNetwork *net = network(id);
+    CoreNetworknet = network(id);
     if (!net)
         return;
 
     if (net->connectionState() != Network::Disconnected) {
         // make sure we no longer receive data from the tcp buffer
-        disconnect(net, SIGNAL(displayMsg(NetworkId, Message::Type, BufferInfo::Type, const QString &, const QString &, const QString &, Message::Flags)), this, 0);
-        disconnect(net, SIGNAL(displayStatusMsg(QString)), this, 0);
-        connect(net, SIGNAL(disconnected(NetworkId)), this, SLOT(destroyNetwork(NetworkId)));
+        disconnect(net, &CoreNetwork::displayMsg, this, nullptr);
+        disconnect(net, &CoreNetwork::displayStatusMsg, this, nullptr);
+        connect(net, &CoreNetwork::disconnected, this, &CoreSession::destroyNetwork);
         net->disconnectFromIrc();
     }
     else {
@@ -578,11 +656,10 @@ void CoreSession::removeNetwork(NetworkId id)
     }
 }
 
-
 void CoreSession::destroyNetwork(NetworkId id)
 {
     QList<BufferId> removedBuffers = Core::requestBufferIdsForNetwork(user(), id);
-    Network *net = _networks.take(id);
+    Networknet = _networks.take(id);
     if (net && Core::removeNetwork(user(), id)) {
         // make sure that all unprocessed RawMessages from this network are removed
         QList<RawMessage>::iterator messageIter = _messageQueue.begin();
@@ -595,7 +672,7 @@ void CoreSession::destroyNetwork(NetworkId id)
             }
         }
         // remove buffers from syncer
-        foreach(BufferId bufferId, removedBuffers) {
+        foreach (BufferId bufferId, removedBuffers) {
             _bufferSyncer->removeBuffer(bufferId);
         }
         emit networkRemoved(id);
@@ -603,8 +680,7 @@ void CoreSession::destroyNetwork(NetworkId id)
     }
 }
 
-
-void CoreSession::renameBuffer(const NetworkId &networkId, const QString &newName, const QString &oldName)
+void CoreSession::renameBuffer(const NetworkId& networkId, const QString& newName, const QString& oldName)
 {
     BufferInfo bufferInfo = Core::bufferInfo(user(), networkId, BufferInfo::QueryBuffer, oldName, false);
     if (bufferInfo.isValid()) {
@@ -612,13 +688,12 @@ void CoreSession::renameBuffer(const NetworkId &networkId, const QString &newNam
     }
 }
 
-
 void CoreSession::clientsConnected()
 {
-    QHash<NetworkId, CoreNetwork *>::iterator netIter = _networks.begin();
-    Identity *identity = 0;
-    CoreNetwork *net = 0;
-    IrcUser *me = 0;
+    QHash<NetworkId, CoreNetwork*>::iterator netIter = _networks.begin();
+    Identity* identity = nullptr;
+    CoreNetwork* net = nullptr;
+    IrcUser* me = nullptr;
     while (netIter != _networks.end()) {
         net = *netIter;
         ++netIter;
@@ -638,13 +713,12 @@ void CoreSession::clientsConnected()
     }
 }
 
-
 void CoreSession::clientsDisconnected()
 {
-    QHash<NetworkId, CoreNetwork *>::iterator netIter = _networks.begin();
-    Identity *identity = 0;
-    CoreNetwork *net = 0;
-    IrcUser *me = 0;
+    QHash<NetworkId, CoreNetwork*>::iterator netIter = _networks.begin();
+    Identity* identity = nullptr;
+    CoreNetwork* net = nullptr;
+    IrcUser* me = nullptr;
     QString awayReason;
     while (netIter != _networks.end()) {
         net = *netIter;
@@ -662,18 +736,18 @@ void CoreSession::clientsDisconnected()
 
         if (identity->detachAwayEnabled() && !me->isAway()) {
             if (!identity->detachAwayReason().isEmpty())
-                awayReason = formatCurrentDateTimeInString(identity->detachAwayReason());
+                awayReason = identity->detachAwayReason();
             net->setAutoAwayActive(true);
+            // Allow handleAway() to format the current date/time in the string.
             net->userInputHandler()->handleAway(BufferInfo(), awayReason);
         }
     }
 }
 
-
-void CoreSession::globalAway(const QString &msg, const bool skipFormatting)
+void CoreSession::globalAway(const QString& msg, const bool skipFormatting)
 {
-    QHash<NetworkId, CoreNetwork *>::iterator netIter = _networks.begin();
-    CoreNetwork *net = 0;
+    QHash<NetworkId, CoreNetwork*>::iterator netIter = _networks.begin();
+    CoreNetwork* net = nullptr;
     while (netIter != _networks.end()) {
         net = *netIter;
         ++netIter;
@@ -685,12 +759,24 @@ void CoreSession::globalAway(const QString &msg, const bool skipFormatting)
     }
 }
 
-void CoreSession::changePassword(PeerPtr peer, const QString &userName, const QString &oldPassword, const QString &newPassword)
+void CoreSession::changePassword(PeerPtr peer, const QString& userName, const QString& oldPassword, const QString& newPassword)
 {
+    Q_UNUSED(peer);
+
     bool success = false;
     UserId uid = Core::validateUser(userName, oldPassword);
     if (uid.isValid() && uid == user())
         success = Core::changeUserPassword(uid, newPassword);
 
-    emit passwordChanged(peer, success);
+    signalProxy()->restrictTargetPeers(signalProxy()->sourcePeer(), [&] { emit passwordChanged(nullptr, success); });
+}
+
+void CoreSession::kickClient(int peerId)
+{
+    auto peer = signalProxy()->peerById(peerId);
+    if (peer == nullptr) {
+        qWarning() << "Invalid peer Id: " << peerId;
+        return;
+    }
+    signalProxy()->restrictTargetPeers(peer, [&] { emit disconnectFromCore(); });
 }