5066 lines
145 KiB
Go
5066 lines
145 KiB
Go
package protocol
|
|
|
|
import (
|
|
"bytes"
|
|
"context"
|
|
"crypto/ecdsa"
|
|
"database/sql"
|
|
"encoding/hex"
|
|
"fmt"
|
|
"io/ioutil"
|
|
"math"
|
|
"math/rand"
|
|
"os"
|
|
"reflect"
|
|
"sync"
|
|
"time"
|
|
|
|
"github.com/libp2p/go-libp2p-core/peer"
|
|
"github.com/pkg/errors"
|
|
"go.uber.org/zap"
|
|
|
|
"github.com/ethereum/go-ethereum/event"
|
|
|
|
"github.com/davecgh/go-spew/spew"
|
|
"github.com/golang/protobuf/proto"
|
|
|
|
gethcommon "github.com/ethereum/go-ethereum/common"
|
|
"github.com/ethereum/go-ethereum/p2p"
|
|
"github.com/ethereum/go-ethereum/p2p/enode"
|
|
"github.com/status-im/status-go/appdatabase"
|
|
"github.com/status-im/status-go/appmetrics"
|
|
"github.com/status-im/status-go/connection"
|
|
"github.com/status-im/status-go/eth-node/crypto"
|
|
"github.com/status-im/status-go/eth-node/types"
|
|
userimage "github.com/status-im/status-go/images"
|
|
"github.com/status-im/status-go/multiaccounts"
|
|
"github.com/status-im/status-go/multiaccounts/accounts"
|
|
"github.com/status-im/status-go/protocol/anonmetrics"
|
|
"github.com/status-im/status-go/protocol/audio"
|
|
"github.com/status-im/status-go/protocol/common"
|
|
"github.com/status-im/status-go/protocol/communities"
|
|
"github.com/status-im/status-go/protocol/encryption"
|
|
"github.com/status-im/status-go/protocol/encryption/multidevice"
|
|
"github.com/status-im/status-go/protocol/encryption/sharedsecret"
|
|
"github.com/status-im/status-go/protocol/ens"
|
|
"github.com/status-im/status-go/protocol/identity/alias"
|
|
"github.com/status-im/status-go/protocol/identity/identicon"
|
|
"github.com/status-im/status-go/protocol/images"
|
|
"github.com/status-im/status-go/protocol/protobuf"
|
|
"github.com/status-im/status-go/protocol/pushnotificationclient"
|
|
"github.com/status-im/status-go/protocol/pushnotificationserver"
|
|
"github.com/status-im/status-go/protocol/sqlite"
|
|
"github.com/status-im/status-go/protocol/transport"
|
|
v1protocol "github.com/status-im/status-go/protocol/v1"
|
|
"github.com/status-im/status-go/services/ext/mailservers"
|
|
mailserversDB "github.com/status-im/status-go/services/mailservers"
|
|
|
|
"github.com/status-im/status-go/telemetry"
|
|
)
|
|
|
|
//todo: kozieiev: get rid of wakutransp word
|
|
type chatContext string
|
|
|
|
const (
|
|
PubKeyStringLength = 132
|
|
|
|
transactionSentTxt = "Transaction sent"
|
|
|
|
publicChat chatContext = "public-chat"
|
|
privateChat chatContext = "private-chat"
|
|
)
|
|
|
|
const messageResendMinDelay = 30
|
|
const messageResendMaxCount = 3
|
|
|
|
var communityAdvertiseIntervalSecond int64 = 60 * 60
|
|
|
|
// messageCacheIntervalMs is how long we should keep processed messages in the cache, in ms
|
|
var messageCacheIntervalMs uint64 = 1000 * 60 * 60 * 48
|
|
|
|
// Messenger is a entity managing chats and messages.
|
|
// It acts as a bridge between the application and encryption
|
|
// layers.
|
|
// It needs to expose an interface to manage installations
|
|
// because installations are managed by the user.
|
|
// Similarly, it needs to expose an interface to manage
|
|
// mailservers because they can also be managed by the user.
|
|
type Messenger struct {
|
|
node types.Node
|
|
server *p2p.Server
|
|
peerStore *mailservers.PeerStore
|
|
config *config
|
|
identity *ecdsa.PrivateKey
|
|
persistence *sqlitePersistence
|
|
transport *transport.Transport
|
|
encryptor *encryption.Protocol
|
|
sender *common.MessageSender
|
|
ensVerifier *ens.Verifier
|
|
anonMetricsClient *anonmetrics.Client
|
|
anonMetricsServer *anonmetrics.Server
|
|
pushNotificationClient *pushnotificationclient.Client
|
|
pushNotificationServer *pushnotificationserver.Server
|
|
communitiesManager *communities.Manager
|
|
logger *zap.Logger
|
|
verifyTransactionClient EthClient
|
|
featureFlags common.FeatureFlags
|
|
shutdownTasks []func() error
|
|
shouldPublishContactCode bool
|
|
systemMessagesTranslations *systemMessageTranslationsMap
|
|
allChats *chatMap
|
|
allContacts *contactMap
|
|
allInstallations *installationMap
|
|
modifiedInstallations *stringBoolMap
|
|
installationID string
|
|
mailserver []byte
|
|
mailserverCycle mailserverCycle
|
|
database *sql.DB
|
|
multiAccounts *multiaccounts.Database
|
|
mailservers *mailserversDB.Database
|
|
settings *accounts.Database
|
|
account *multiaccounts.Account
|
|
mailserversDatabase *mailserversDB.Database
|
|
imageServer *images.Server
|
|
quit chan struct{}
|
|
requestedCommunities map[string]*transport.Filter
|
|
connectionState connection.State
|
|
telemetryClient *telemetry.Client
|
|
|
|
// TODO(samyoul) Determine if/how the remaining usage of this mutex can be removed
|
|
mutex sync.Mutex
|
|
}
|
|
|
|
type connStatus int
|
|
|
|
const (
|
|
disconnected connStatus = iota + 1
|
|
connecting
|
|
connected
|
|
)
|
|
|
|
type peerStatus struct {
|
|
status connStatus
|
|
canConnectAfter time.Time
|
|
lastConnectionAttempt time.Time
|
|
}
|
|
type mailserverCycle struct {
|
|
sync.RWMutex
|
|
activeMailserver *enode.Node // For usage with wakuV1
|
|
activeStoreNode *peer.ID // For usage with wakuV2
|
|
peers map[string]peerStatus
|
|
events chan *p2p.PeerEvent
|
|
subscription event.Subscription
|
|
}
|
|
|
|
type dbConfig struct {
|
|
dbPath string
|
|
dbKey string
|
|
}
|
|
|
|
type EnvelopeEventsInterceptor struct {
|
|
EnvelopeEventsHandler transport.EnvelopeEventsHandler
|
|
Messenger *Messenger
|
|
}
|
|
|
|
// EnvelopeSent triggered when envelope delivered at least to 1 peer.
|
|
func (interceptor EnvelopeEventsInterceptor) EnvelopeSent(identifiers [][]byte) {
|
|
if interceptor.Messenger != nil {
|
|
var ids []string
|
|
for _, identifierBytes := range identifiers {
|
|
ids = append(ids, types.EncodeHex(identifierBytes))
|
|
}
|
|
|
|
err := interceptor.Messenger.processSentMessages(ids)
|
|
if err != nil {
|
|
interceptor.Messenger.logger.Info("Messenger failed to process sent messages", zap.Error(err))
|
|
} else {
|
|
interceptor.EnvelopeEventsHandler.EnvelopeSent(identifiers)
|
|
}
|
|
} else {
|
|
// NOTE(rasom): In case if interceptor.Messenger is not nil and
|
|
// some error occurred on processing sent message we don't want
|
|
// to send envelop.sent signal to the client, thus `else` cause
|
|
// is necessary.
|
|
interceptor.EnvelopeEventsHandler.EnvelopeSent(identifiers)
|
|
}
|
|
}
|
|
|
|
// EnvelopeExpired triggered when envelope is expired but wasn't delivered to any peer.
|
|
func (interceptor EnvelopeEventsInterceptor) EnvelopeExpired(identifiers [][]byte, err error) {
|
|
//we don't track expired events in Messenger, so just redirect to handler
|
|
interceptor.EnvelopeEventsHandler.EnvelopeExpired(identifiers, err)
|
|
}
|
|
|
|
// MailServerRequestCompleted triggered when the mailserver sends a message to notify that the request has been completed
|
|
func (interceptor EnvelopeEventsInterceptor) MailServerRequestCompleted(requestID types.Hash, lastEnvelopeHash types.Hash, cursor []byte, err error) {
|
|
//we don't track mailserver requests in Messenger, so just redirect to handler
|
|
interceptor.EnvelopeEventsHandler.MailServerRequestCompleted(requestID, lastEnvelopeHash, cursor, err)
|
|
}
|
|
|
|
// MailServerRequestExpired triggered when the mailserver request expires
|
|
func (interceptor EnvelopeEventsInterceptor) MailServerRequestExpired(hash types.Hash) {
|
|
//we don't track mailserver requests in Messenger, so just redirect to handler
|
|
interceptor.EnvelopeEventsHandler.MailServerRequestExpired(hash)
|
|
}
|
|
|
|
func NewMessenger(
|
|
nodeName string,
|
|
identity *ecdsa.PrivateKey,
|
|
node types.Node,
|
|
installationID string,
|
|
peerStore *mailservers.PeerStore,
|
|
opts ...Option,
|
|
) (*Messenger, error) {
|
|
var messenger *Messenger
|
|
|
|
c := config{}
|
|
|
|
for _, opt := range opts {
|
|
if err := opt(&c); err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
logger := c.logger
|
|
if c.logger == nil {
|
|
var err error
|
|
if logger, err = zap.NewDevelopment(); err != nil {
|
|
return nil, errors.Wrap(err, "failed to create a logger")
|
|
}
|
|
}
|
|
|
|
if c.systemMessagesTranslations == nil {
|
|
c.systemMessagesTranslations = defaultSystemMessagesTranslations
|
|
}
|
|
|
|
// Configure the database.
|
|
database := c.db
|
|
if c.db == nil && c.dbConfig == (dbConfig{}) {
|
|
return nil, errors.New("database instance or database path needs to be provided")
|
|
}
|
|
if c.db == nil {
|
|
logger.Info("opening a database", zap.String("dbPath", c.dbConfig.dbPath))
|
|
var err error
|
|
database, err = appdatabase.InitializeDB(c.dbConfig.dbPath, c.dbConfig.dbKey)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "failed to initialize database from the db config")
|
|
}
|
|
}
|
|
|
|
// Apply any post database creation changes to the database
|
|
c.db = database
|
|
for _, opt := range c.afterDbCreatedHooks {
|
|
if err := opt(&c); err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
// Apply migrations for all components.
|
|
err := sqlite.Migrate(database)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "failed to apply migrations")
|
|
}
|
|
|
|
// Initialize transport layer.
|
|
var transp *transport.Transport
|
|
|
|
if waku, err := node.GetWaku(nil); err == nil && waku != nil {
|
|
transp, err = transport.NewTransport(
|
|
waku,
|
|
identity,
|
|
database,
|
|
"waku_keys",
|
|
nil,
|
|
c.envelopesMonitorConfig,
|
|
logger,
|
|
)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "failed to create Transport")
|
|
}
|
|
} else {
|
|
logger.Info("failed to find Waku service; trying WakuV2", zap.Error(err))
|
|
wakuV2, err := node.GetWakuV2(nil)
|
|
if err != nil || wakuV2 == nil {
|
|
return nil, errors.Wrap(err, "failed to find Whisper and Waku V1/V2 services")
|
|
}
|
|
transp, err = transport.NewTransport(
|
|
wakuV2,
|
|
identity,
|
|
database,
|
|
"wakuv2_keys",
|
|
nil,
|
|
c.envelopesMonitorConfig,
|
|
logger,
|
|
)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "failed to create Transport")
|
|
}
|
|
}
|
|
|
|
// Initialize encryption layer.
|
|
encryptionProtocol := encryption.New(
|
|
database,
|
|
installationID,
|
|
logger,
|
|
)
|
|
|
|
sender, err := common.NewMessageSender(
|
|
identity,
|
|
database,
|
|
encryptionProtocol,
|
|
transp,
|
|
logger,
|
|
c.featureFlags,
|
|
)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "failed to create messageSender")
|
|
}
|
|
|
|
// Initialise anon metrics client
|
|
var anonMetricsClient *anonmetrics.Client
|
|
if c.anonMetricsClientConfig != nil &&
|
|
c.anonMetricsClientConfig.ShouldSend &&
|
|
c.anonMetricsClientConfig.Active == anonmetrics.ActiveClientPhrase {
|
|
|
|
anonMetricsClient = anonmetrics.NewClient(sender)
|
|
anonMetricsClient.Config = c.anonMetricsClientConfig
|
|
anonMetricsClient.Identity = identity
|
|
anonMetricsClient.DB = appmetrics.NewDB(database)
|
|
anonMetricsClient.Logger = logger
|
|
}
|
|
|
|
// Initialise anon metrics server
|
|
var anonMetricsServer *anonmetrics.Server
|
|
if c.anonMetricsServerConfig != nil &&
|
|
c.anonMetricsServerConfig.Enabled &&
|
|
c.anonMetricsServerConfig.Active == anonmetrics.ActiveServerPhrase {
|
|
|
|
server, err := anonmetrics.NewServer(c.anonMetricsServerConfig.PostgresURI)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "failed to create anonmetrics.Server")
|
|
}
|
|
|
|
anonMetricsServer = server
|
|
anonMetricsServer.Config = c.anonMetricsServerConfig
|
|
anonMetricsServer.Logger = logger
|
|
}
|
|
|
|
var telemetryClient *telemetry.Client
|
|
if c.telemetryServerURL != "" {
|
|
telemetryClient = telemetry.NewClient(logger, c.telemetryServerURL, c.account.KeyUID, nodeName)
|
|
}
|
|
|
|
// Initialize push notification server
|
|
var pushNotificationServer *pushnotificationserver.Server
|
|
if c.pushNotificationServerConfig != nil && c.pushNotificationServerConfig.Enabled {
|
|
c.pushNotificationServerConfig.Identity = identity
|
|
pushNotificationServerPersistence := pushnotificationserver.NewSQLitePersistence(database)
|
|
pushNotificationServer = pushnotificationserver.New(c.pushNotificationServerConfig, pushNotificationServerPersistence, sender)
|
|
}
|
|
|
|
// Initialize push notification client
|
|
pushNotificationClientPersistence := pushnotificationclient.NewPersistence(database)
|
|
pushNotificationClientConfig := c.pushNotificationClientConfig
|
|
if pushNotificationClientConfig == nil {
|
|
pushNotificationClientConfig = &pushnotificationclient.Config{}
|
|
}
|
|
|
|
sqlitePersistence := NewSQLitePersistence(database)
|
|
// Overriding until we handle different identities
|
|
pushNotificationClientConfig.Identity = identity
|
|
pushNotificationClientConfig.Logger = logger
|
|
pushNotificationClientConfig.InstallationID = installationID
|
|
|
|
pushNotificationClient := pushnotificationclient.New(pushNotificationClientPersistence, pushNotificationClientConfig, sender, sqlitePersistence)
|
|
|
|
ensVerifier := ens.New(node, logger, transp, database, c.verifyENSURL, c.verifyENSContractAddress)
|
|
|
|
communitiesManager, err := communities.NewManager(&identity.PublicKey, database, logger, ensVerifier)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
settings := accounts.NewDB(database)
|
|
|
|
mailservers := mailserversDB.NewDB(database)
|
|
imageServer, err := images.NewServer(database, logger)
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
messenger = &Messenger{
|
|
config: &c,
|
|
node: node,
|
|
identity: identity,
|
|
persistence: sqlitePersistence,
|
|
transport: transp,
|
|
encryptor: encryptionProtocol,
|
|
sender: sender,
|
|
anonMetricsClient: anonMetricsClient,
|
|
anonMetricsServer: anonMetricsServer,
|
|
telemetryClient: telemetryClient,
|
|
pushNotificationClient: pushNotificationClient,
|
|
pushNotificationServer: pushNotificationServer,
|
|
communitiesManager: communitiesManager,
|
|
ensVerifier: ensVerifier,
|
|
featureFlags: c.featureFlags,
|
|
systemMessagesTranslations: c.systemMessagesTranslations,
|
|
allChats: new(chatMap),
|
|
allContacts: new(contactMap),
|
|
allInstallations: new(installationMap),
|
|
installationID: installationID,
|
|
modifiedInstallations: new(stringBoolMap),
|
|
verifyTransactionClient: c.verifyTransactionClient,
|
|
database: database,
|
|
multiAccounts: c.multiAccount,
|
|
settings: settings,
|
|
peerStore: peerStore,
|
|
mailservers: mailservers,
|
|
mailserverCycle: mailserverCycle{
|
|
peers: make(map[string]peerStatus),
|
|
},
|
|
mailserversDatabase: c.mailserversDatabase,
|
|
account: c.account,
|
|
quit: make(chan struct{}),
|
|
requestedCommunities: make(map[string]*transport.Filter),
|
|
imageServer: imageServer,
|
|
shutdownTasks: []func() error{
|
|
ensVerifier.Stop,
|
|
pushNotificationClient.Stop,
|
|
communitiesManager.Stop,
|
|
encryptionProtocol.Stop,
|
|
transp.ResetFilters,
|
|
imageServer.Stop,
|
|
transp.Stop,
|
|
func() error { sender.Stop(); return nil },
|
|
// Currently this often fails, seems like it's safe to ignore them
|
|
// https://github.com/uber-go/zap/issues/328
|
|
func() error { _ = logger.Sync; return nil },
|
|
database.Close,
|
|
},
|
|
logger: logger,
|
|
}
|
|
|
|
if anonMetricsClient != nil {
|
|
messenger.shutdownTasks = append(messenger.shutdownTasks, anonMetricsClient.Stop)
|
|
}
|
|
if anonMetricsServer != nil {
|
|
messenger.shutdownTasks = append(messenger.shutdownTasks, anonMetricsServer.Stop)
|
|
}
|
|
|
|
if c.envelopesMonitorConfig != nil {
|
|
interceptor := EnvelopeEventsInterceptor{c.envelopesMonitorConfig.EnvelopeEventsHandler, messenger}
|
|
err := messenger.transport.SetEnvelopeEventsHandler(interceptor)
|
|
if err != nil {
|
|
logger.Info("Unable to set envelopes event handler", zap.Error(err))
|
|
}
|
|
}
|
|
|
|
return messenger, nil
|
|
}
|
|
|
|
func (m *Messenger) SetP2PServer(server *p2p.Server) {
|
|
m.server = server
|
|
}
|
|
|
|
func (m *Messenger) processSentMessages(ids []string) error {
|
|
if m.connectionState.Offline {
|
|
return errors.New("Can't mark message as sent while offline")
|
|
}
|
|
|
|
for _, id := range ids {
|
|
rawMessage, err := m.persistence.RawMessageByID(id)
|
|
if err != nil {
|
|
return errors.Wrapf(err, "Can't get raw message with id %v", id)
|
|
}
|
|
|
|
rawMessage.Sent = true
|
|
|
|
err = m.persistence.SaveRawMessage(rawMessage)
|
|
if err != nil {
|
|
return errors.Wrapf(err, "Can't save raw message marked as sent")
|
|
}
|
|
|
|
err = m.UpdateMessageOutgoingStatus(id, "sent")
|
|
if err != nil {
|
|
return err
|
|
}
|
|
}
|
|
|
|
return nil
|
|
}
|
|
|
|
func shouldResendMessage(message *common.RawMessage, t common.TimeSource) (bool, error) {
|
|
if !(message.MessageType == protobuf.ApplicationMetadataMessage_EMOJI_REACTION ||
|
|
message.MessageType == protobuf.ApplicationMetadataMessage_CHAT_MESSAGE) {
|
|
return false, errors.Errorf("Should resend only specific types of messages, can't resend %v", message.MessageType)
|
|
}
|
|
|
|
if message.Sent {
|
|
return false, errors.New("Should resend only non-sent messages")
|
|
}
|
|
|
|
if message.SendCount > messageResendMaxCount {
|
|
return false, nil
|
|
}
|
|
|
|
//exponential backoff depends on how many attempts to send message already made
|
|
backoff := uint64(math.Pow(2, float64(message.SendCount-1))) * messageResendMinDelay * uint64(time.Second.Milliseconds())
|
|
backoffElapsed := t.GetCurrentTime() > (message.LastSent + backoff)
|
|
return backoffElapsed, nil
|
|
}
|
|
|
|
func (m *Messenger) resendExpiredMessages() error {
|
|
if m.connectionState.Offline {
|
|
return errors.New("offline")
|
|
}
|
|
|
|
ids, err := m.persistence.ExpiredMessagesIDs(messageResendMaxCount)
|
|
if err != nil {
|
|
return errors.Wrapf(err, "Can't get expired reactions from db")
|
|
}
|
|
|
|
for _, id := range ids {
|
|
rawMessage, err := m.persistence.RawMessageByID(id)
|
|
if err != nil {
|
|
return errors.Wrapf(err, "Can't get raw message with id %v", id)
|
|
}
|
|
|
|
chat, ok := m.allChats.Load(rawMessage.LocalChatID)
|
|
if !ok {
|
|
return ErrChatNotFound
|
|
}
|
|
|
|
if !(chat.Public() || chat.CommunityChat()) {
|
|
return errors.New("Only public chats and community chats messages are resent")
|
|
}
|
|
|
|
ok, err = shouldResendMessage(rawMessage, m.getTimesource())
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
if ok {
|
|
err = m.persistence.SaveRawMessage(rawMessage)
|
|
if err != nil {
|
|
return errors.Wrapf(err, "Can't save raw message marked as non-expired")
|
|
}
|
|
|
|
err = m.reSendRawMessage(context.Background(), rawMessage.ID)
|
|
if err != nil {
|
|
return errors.Wrapf(err, "Can't resend expired message with id %v", rawMessage.ID)
|
|
}
|
|
}
|
|
}
|
|
return nil
|
|
}
|
|
|
|
func (m *Messenger) ToForeground() {
|
|
if m.imageServer != nil {
|
|
m.imageServer.ToForeground()
|
|
}
|
|
}
|
|
|
|
func (m *Messenger) ToBackground() {
|
|
if m.imageServer != nil {
|
|
m.imageServer.ToBackground()
|
|
}
|
|
}
|
|
|
|
func (m *Messenger) Start() (*MessengerResponse, error) {
|
|
m.logger.Info("starting messenger", zap.String("identity", types.EncodeHex(crypto.FromECDSAPub(&m.identity.PublicKey))))
|
|
// Start push notification server
|
|
if m.pushNotificationServer != nil {
|
|
if err := m.pushNotificationServer.Start(); err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
// Start push notification client
|
|
if m.pushNotificationClient != nil {
|
|
m.handlePushNotificationClientRegistrations(m.pushNotificationClient.SubscribeToRegistrations())
|
|
|
|
if err := m.pushNotificationClient.Start(); err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
// Start anonymous metrics client
|
|
if m.anonMetricsClient != nil {
|
|
if err := m.anonMetricsClient.Start(); err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
ensSubscription := m.ensVerifier.Subscribe()
|
|
|
|
// Subscrbe
|
|
if err := m.ensVerifier.Start(); err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if err := m.communitiesManager.Start(); err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
// set shared secret handles
|
|
m.sender.SetHandleSharedSecrets(m.handleSharedSecrets)
|
|
|
|
subscriptions, err := m.encryptor.Start(m.identity)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
// handle stored shared secrets
|
|
err = m.handleSharedSecrets(subscriptions.SharedSecrets)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
m.handleEncryptionLayerSubscriptions(subscriptions)
|
|
m.handleCommunitiesSubscription(m.communitiesManager.Subscribe())
|
|
m.handleConnectionChange(m.online())
|
|
m.handleENSVerificationSubscription(ensSubscription)
|
|
m.watchConnectionChange()
|
|
m.watchExpiredMessages()
|
|
m.watchIdentityImageChanges()
|
|
m.broadcastLatestUserStatus()
|
|
m.startBackupLoop()
|
|
err = m.startAutoMessageLoop()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if err := m.cleanTopics(); err != nil {
|
|
return nil, err
|
|
}
|
|
response := &MessengerResponse{}
|
|
|
|
if m.mailserversDatabase != nil {
|
|
mailservers, err := m.mailserversDatabase.Mailservers()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
response.Mailservers = mailservers
|
|
|
|
}
|
|
|
|
if m.config.featureFlags.MailserverCycle {
|
|
err := m.StartMailserverCycle()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
err = m.imageServer.Start()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return response, nil
|
|
}
|
|
|
|
// cleanTopics remove any topic that does not have a Listen flag set
|
|
func (m *Messenger) cleanTopics() error {
|
|
if m.mailserversDatabase == nil {
|
|
return nil
|
|
}
|
|
var filters []*transport.Filter
|
|
for _, f := range m.transport.Filters() {
|
|
if f.Listen && !f.Ephemeral {
|
|
filters = append(filters, f)
|
|
}
|
|
}
|
|
|
|
m.logger.Debug("keeping topics", zap.Any("filters", filters))
|
|
|
|
return m.mailserversDatabase.SetTopics(filters)
|
|
}
|
|
|
|
// handle connection change is called each time we go from offline/online or viceversa
|
|
func (m *Messenger) handleConnectionChange(online bool) {
|
|
if online {
|
|
if m.pushNotificationClient != nil {
|
|
m.pushNotificationClient.Online()
|
|
}
|
|
|
|
if m.shouldPublishContactCode {
|
|
if err := m.publishContactCode(); err != nil {
|
|
m.logger.Error("could not publish on contact code", zap.Error(err))
|
|
return
|
|
}
|
|
m.shouldPublishContactCode = false
|
|
}
|
|
|
|
} else {
|
|
if m.pushNotificationClient != nil {
|
|
m.pushNotificationClient.Offline()
|
|
}
|
|
|
|
if m.config.featureFlags.MailserverCycle {
|
|
m.DisconnectActiveMailserver() // force mailserver cycle to run again
|
|
}
|
|
}
|
|
|
|
m.ensVerifier.SetOnline(online)
|
|
}
|
|
|
|
func (m *Messenger) online() bool {
|
|
switch m.transport.WakuVersion() {
|
|
case 2:
|
|
return m.transport.PeerCount() > 0
|
|
default:
|
|
return m.node.PeersCount() > 0
|
|
}
|
|
}
|
|
|
|
func (m *Messenger) buildContactCodeAdvertisement() (*protobuf.ContactCodeAdvertisement, error) {
|
|
if m.pushNotificationClient == nil || !m.pushNotificationClient.Enabled() {
|
|
return nil, nil
|
|
}
|
|
m.logger.Debug("adding push notification info to contact code bundle")
|
|
info, err := m.pushNotificationClient.MyPushNotificationQueryInfo()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
if len(info) == 0 {
|
|
return nil, nil
|
|
}
|
|
return &protobuf.ContactCodeAdvertisement{
|
|
PushNotificationInfo: info,
|
|
}, nil
|
|
}
|
|
|
|
// publishContactCode sends a public message wrapped in the encryption
|
|
// layer, which will propagate our bundle
|
|
func (m *Messenger) publishContactCode() error {
|
|
var payload []byte
|
|
m.logger.Debug("sending contact code")
|
|
contactCodeAdvertisement, err := m.buildContactCodeAdvertisement()
|
|
if err != nil {
|
|
m.logger.Error("could not build contact code advertisement", zap.Error(err))
|
|
}
|
|
|
|
if contactCodeAdvertisement == nil {
|
|
contactCodeAdvertisement = &protobuf.ContactCodeAdvertisement{}
|
|
}
|
|
|
|
err = m.attachChatIdentity(contactCodeAdvertisement)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
if contactCodeAdvertisement.ChatIdentity != nil {
|
|
m.logger.Debug("attached chat identity", zap.Int("images len", len(contactCodeAdvertisement.ChatIdentity.Images)))
|
|
} else {
|
|
m.logger.Debug("no attached chat identity")
|
|
}
|
|
|
|
payload, err = proto.Marshal(contactCodeAdvertisement)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
contactCodeTopic := transport.ContactCodeTopic(&m.identity.PublicKey)
|
|
rawMessage := common.RawMessage{
|
|
LocalChatID: contactCodeTopic,
|
|
MessageType: protobuf.ApplicationMetadataMessage_CONTACT_CODE_ADVERTISEMENT,
|
|
Payload: payload,
|
|
}
|
|
ctx, cancel := context.WithTimeout(context.Background(), 5*time.Second)
|
|
defer cancel()
|
|
_, err = m.sender.SendPublic(ctx, contactCodeTopic, rawMessage)
|
|
if err != nil {
|
|
m.logger.Warn("failed to send a contact code", zap.Error(err))
|
|
}
|
|
m.logger.Debug("contact code sent")
|
|
return err
|
|
}
|
|
|
|
// contactCodeAdvertisement attaches a protobuf.ChatIdentity to the given protobuf.ContactCodeAdvertisement,
|
|
// if the `shouldPublish` conditions are met
|
|
func (m *Messenger) attachChatIdentity(cca *protobuf.ContactCodeAdvertisement) error {
|
|
contactCodeTopic := transport.ContactCodeTopic(&m.identity.PublicKey)
|
|
|
|
shouldPublish, err := m.shouldPublishChatIdentity(contactCodeTopic)
|
|
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
if !shouldPublish {
|
|
return nil
|
|
}
|
|
|
|
cca.ChatIdentity, err = m.createChatIdentity(privateChat)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
img, err := m.multiAccounts.GetIdentityImage(m.account.KeyUID, userimage.SmallDimName)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
if img == nil {
|
|
return errors.New("could not find image")
|
|
}
|
|
|
|
err = m.persistence.SaveWhenChatIdentityLastPublished(contactCodeTopic, img.Hash())
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
return nil
|
|
}
|
|
|
|
// handleStandaloneChatIdentity sends a standalone ChatIdentity message to a public or private channel if the publish criteria is met
|
|
func (m *Messenger) handleStandaloneChatIdentity(chat *Chat) error {
|
|
if chat.ChatType != ChatTypePublic && chat.ChatType != ChatTypeOneToOne {
|
|
return nil
|
|
}
|
|
shouldPublishChatIdentity, err := m.shouldPublishChatIdentity(chat.ID)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
if !shouldPublishChatIdentity {
|
|
return nil
|
|
}
|
|
|
|
ci, err := m.createChatIdentity(publicChat)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
payload, err := proto.Marshal(ci)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
rawMessage := common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
MessageType: protobuf.ApplicationMetadataMessage_CHAT_IDENTITY,
|
|
Payload: payload,
|
|
}
|
|
ctx, cancel := context.WithTimeout(context.Background(), 5*time.Second)
|
|
defer cancel()
|
|
if chat.ChatType == ChatTypePublic {
|
|
_, err = m.sender.SendPublic(ctx, chat.ID, rawMessage)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
} else {
|
|
pk, err := chat.PublicKey()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
_, err = m.sender.SendPrivate(ctx, pk, &rawMessage)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
}
|
|
|
|
img, err := m.multiAccounts.GetIdentityImage(m.account.KeyUID, userimage.SmallDimName)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
if img == nil {
|
|
return errors.New("could not find image")
|
|
}
|
|
|
|
err = m.persistence.SaveWhenChatIdentityLastPublished(chat.ID, img.Hash())
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
return nil
|
|
}
|
|
|
|
// shouldPublishChatIdentity returns true if the last time the ChatIdentity was attached was more than 24 hours ago
|
|
func (m *Messenger) shouldPublishChatIdentity(chatID string) (bool, error) {
|
|
if m.account == nil {
|
|
return false, nil
|
|
}
|
|
|
|
// Check we have at least one image
|
|
img, err := m.multiAccounts.GetIdentityImage(m.account.KeyUID, userimage.SmallDimName)
|
|
if err != nil {
|
|
return false, err
|
|
}
|
|
|
|
if img == nil {
|
|
return false, nil
|
|
}
|
|
|
|
lp, hash, err := m.persistence.GetWhenChatIdentityLastPublished(chatID)
|
|
if err != nil {
|
|
return false, err
|
|
}
|
|
|
|
if !bytes.Equal(hash, img.Hash()) {
|
|
return true, nil
|
|
}
|
|
|
|
// Note: If Alice does not add bob as a contact she will not update her contact code with images
|
|
return lp == 0 || time.Now().Unix()-lp > 24*60*60, nil
|
|
}
|
|
|
|
// createChatIdentity creates a context based protobuf.ChatIdentity.
|
|
// context 'public-chat' will attach only the 'thumbnail' IdentityImage
|
|
// context 'private-chat' will attach all IdentityImage
|
|
func (m *Messenger) createChatIdentity(context chatContext) (*protobuf.ChatIdentity, error) {
|
|
m.logger.Info(fmt.Sprintf("account keyUID '%s'", m.account.KeyUID))
|
|
m.logger.Info(fmt.Sprintf("context '%s'", context))
|
|
|
|
ci := &protobuf.ChatIdentity{
|
|
Clock: m.transport.GetCurrentTime(),
|
|
EnsName: "", // TODO add ENS name handling to dedicate PR
|
|
}
|
|
err := m.attachIdentityImagesToChatIdentity(context, ci)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return ci, nil
|
|
}
|
|
|
|
// adaptIdentityImageToProtobuf Adapts a images.IdentityImage to protobuf.IdentityImage
|
|
func (m *Messenger) adaptIdentityImageToProtobuf(img *userimage.IdentityImage) *protobuf.IdentityImage {
|
|
return &protobuf.IdentityImage{
|
|
Payload: img.Payload,
|
|
SourceType: protobuf.IdentityImage_RAW_PAYLOAD, // TODO add ENS avatar handling to dedicated PR
|
|
ImageType: images.ImageType(img.Payload),
|
|
}
|
|
}
|
|
|
|
func (m *Messenger) attachIdentityImagesToChatIdentity(context chatContext, ci *protobuf.ChatIdentity) error {
|
|
s, err := m.getSettings()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
if s.ProfilePicturesShowTo == accounts.ProfilePicturesShowToNone {
|
|
m.logger.Info(fmt.Sprintf("settings.ProfilePicturesShowTo is set to '%d', skipping attaching IdentityImages", s.ProfilePicturesShowTo))
|
|
return nil
|
|
}
|
|
|
|
ciis := make(map[string]*protobuf.IdentityImage)
|
|
|
|
switch context {
|
|
case publicChat:
|
|
m.logger.Info(fmt.Sprintf("handling %s ChatIdentity", context))
|
|
|
|
img, err := m.multiAccounts.GetIdentityImage(m.account.KeyUID, userimage.SmallDimName)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
m.logger.Debug(fmt.Sprintf("%s images.IdentityImage '%s'", context, spew.Sdump(img)))
|
|
|
|
ciis[userimage.SmallDimName] = m.adaptIdentityImageToProtobuf(img)
|
|
m.logger.Debug(fmt.Sprintf("%s protobuf.IdentityImage '%s'", context, spew.Sdump(ciis)))
|
|
ci.Images = ciis
|
|
|
|
case privateChat:
|
|
m.logger.Info(fmt.Sprintf("handling %s ChatIdentity", context))
|
|
|
|
imgs, err := m.multiAccounts.GetIdentityImages(m.account.KeyUID)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
m.logger.Debug(fmt.Sprintf("%s images.IdentityImage '%s'", context, spew.Sdump(imgs)))
|
|
|
|
for _, img := range imgs {
|
|
ciis[img.Name] = m.adaptIdentityImageToProtobuf(img)
|
|
}
|
|
m.logger.Debug(fmt.Sprintf("%s protobuf.IdentityImage '%s'", context, spew.Sdump(ciis)))
|
|
ci.Images = ciis
|
|
|
|
default:
|
|
return fmt.Errorf("unknown ChatIdentity context '%s'", context)
|
|
}
|
|
|
|
if s.ProfilePicturesShowTo == accounts.ProfilePicturesShowToContactsOnly {
|
|
err := EncryptIdentityImagesWithContactPubKeys(ci.Images, m)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
}
|
|
|
|
return nil
|
|
}
|
|
|
|
// handleSharedSecrets process the negotiated secrets received from the encryption layer
|
|
func (m *Messenger) handleSharedSecrets(secrets []*sharedsecret.Secret) error {
|
|
for _, secret := range secrets {
|
|
fSecret := types.NegotiatedSecret{
|
|
PublicKey: secret.Identity,
|
|
Key: secret.Key,
|
|
}
|
|
_, err := m.transport.ProcessNegotiatedSecret(fSecret)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
}
|
|
return nil
|
|
}
|
|
|
|
// handleInstallations adds the installations in the installations map
|
|
func (m *Messenger) handleInstallations(installations []*multidevice.Installation) {
|
|
for _, installation := range installations {
|
|
if installation.Identity == contactIDFromPublicKey(&m.identity.PublicKey) {
|
|
if _, ok := m.allInstallations.Load(installation.ID); !ok {
|
|
m.allInstallations.Store(installation.ID, installation)
|
|
m.modifiedInstallations.Store(installation.ID, true)
|
|
}
|
|
}
|
|
}
|
|
}
|
|
|
|
// handleEncryptionLayerSubscriptions handles events from the encryption layer
|
|
func (m *Messenger) handleEncryptionLayerSubscriptions(subscriptions *encryption.Subscriptions) {
|
|
go func() {
|
|
for {
|
|
select {
|
|
case <-subscriptions.SendContactCode:
|
|
if err := m.publishContactCode(); err != nil {
|
|
m.logger.Error("failed to publish contact code", zap.Error(err))
|
|
}
|
|
// we also piggy-back to clean up cached messages
|
|
if err := m.transport.CleanMessagesProcessed(m.getTimesource().GetCurrentTime() - messageCacheIntervalMs); err != nil {
|
|
m.logger.Error("failed to clean processed messages", zap.Error(err))
|
|
}
|
|
|
|
case <-subscriptions.Quit:
|
|
m.logger.Debug("quitting encryption subscription loop")
|
|
return
|
|
}
|
|
}
|
|
}()
|
|
}
|
|
|
|
func (m *Messenger) handleENSVerified(records []*ens.VerificationRecord) {
|
|
var contacts []*Contact
|
|
for _, record := range records {
|
|
m.logger.Info("handling record", zap.Any("record", record))
|
|
contact, ok := m.allContacts.Load(record.PublicKey)
|
|
if !ok {
|
|
m.logger.Info("contact not found")
|
|
continue
|
|
}
|
|
|
|
contact.ENSVerified = record.Verified
|
|
contact.Name = record.Name
|
|
contacts = append(contacts, contact)
|
|
}
|
|
|
|
m.logger.Info("handled records", zap.Any("contacts", contacts))
|
|
if len(contacts) != 0 {
|
|
if err := m.persistence.SaveContacts(contacts); err != nil {
|
|
m.logger.Error("failed to save contacts", zap.Error(err))
|
|
return
|
|
}
|
|
}
|
|
|
|
m.logger.Info("calling on contacts")
|
|
if m.config.onContactENSVerified != nil {
|
|
m.logger.Info("called on contacts")
|
|
response := &MessengerResponse{Contacts: contacts}
|
|
m.config.onContactENSVerified(response)
|
|
}
|
|
|
|
}
|
|
|
|
func (m *Messenger) handleENSVerificationSubscription(c chan []*ens.VerificationRecord) {
|
|
go func() {
|
|
for {
|
|
select {
|
|
case records, more := <-c:
|
|
if !more {
|
|
m.logger.Info("No more records, quitting")
|
|
return
|
|
}
|
|
if len(records) != 0 {
|
|
m.logger.Info("handling records", zap.Any("records", records))
|
|
m.handleENSVerified(records)
|
|
}
|
|
case <-m.quit:
|
|
return
|
|
}
|
|
}
|
|
}()
|
|
}
|
|
|
|
// watchConnectionChange checks the connection status and call handleConnectionChange when this changes
|
|
func (m *Messenger) watchConnectionChange() {
|
|
m.logger.Debug("watching connection changes")
|
|
state := m.online()
|
|
go func() {
|
|
for {
|
|
select {
|
|
case <-time.After(200 * time.Millisecond):
|
|
newState := m.online()
|
|
if state != newState {
|
|
state = newState
|
|
m.logger.Debug("connection changed", zap.Bool("online", state))
|
|
m.handleConnectionChange(state)
|
|
}
|
|
case <-m.quit:
|
|
return
|
|
}
|
|
}
|
|
}()
|
|
}
|
|
|
|
// watchExpiredMessages regularly checks for expired emojis and invoke their resending
|
|
func (m *Messenger) watchExpiredMessages() {
|
|
m.logger.Debug("watching expired messages")
|
|
go func() {
|
|
for {
|
|
select {
|
|
case <-time.After(time.Second):
|
|
if m.online() {
|
|
err := m.resendExpiredMessages()
|
|
if err != nil {
|
|
m.logger.Debug("Error when resending expired emoji reactions", zap.Error(err))
|
|
}
|
|
}
|
|
case <-m.quit:
|
|
return
|
|
}
|
|
}
|
|
}()
|
|
}
|
|
|
|
// watchIdentityImageChanges checks for identity images changes and publishes to the contact code when it happens
|
|
func (m *Messenger) watchIdentityImageChanges() {
|
|
m.logger.Debug("watching identity image changes")
|
|
if m.multiAccounts == nil {
|
|
return
|
|
}
|
|
|
|
channel := m.multiAccounts.SubscribeToIdentityImageChanges()
|
|
|
|
go func() {
|
|
for {
|
|
select {
|
|
case <-channel:
|
|
err := m.PublishIdentityImage()
|
|
if err != nil {
|
|
m.logger.Error("failed to publish identity image", zap.Error(err))
|
|
}
|
|
case <-m.quit:
|
|
return
|
|
}
|
|
}
|
|
}()
|
|
}
|
|
|
|
func (m *Messenger) PublishIdentityImage() error {
|
|
// Reset last published time for ChatIdentity so new contact can receive data
|
|
err := m.resetLastPublishedTimeForChatIdentity()
|
|
if err != nil {
|
|
m.logger.Error("failed to reset publish time", zap.Error(err))
|
|
return err
|
|
}
|
|
|
|
// If not online, we schedule it
|
|
if !m.online() {
|
|
m.shouldPublishContactCode = true
|
|
return nil
|
|
}
|
|
|
|
return m.publishContactCode()
|
|
}
|
|
|
|
// handlePushNotificationClientRegistration handles registration events
|
|
func (m *Messenger) handlePushNotificationClientRegistrations(c chan struct{}) {
|
|
go func() {
|
|
for {
|
|
_, more := <-c
|
|
if !more {
|
|
return
|
|
}
|
|
if err := m.publishContactCode(); err != nil {
|
|
m.logger.Error("failed to publish contact code", zap.Error(err))
|
|
}
|
|
|
|
}
|
|
}()
|
|
}
|
|
|
|
// Init analyzes chats and contacts in order to setup filters
|
|
// which are responsible for retrieving messages.
|
|
func (m *Messenger) Init() error {
|
|
|
|
// Seed the for color generation
|
|
rand.Seed(time.Now().Unix())
|
|
|
|
logger := m.logger.With(zap.String("site", "Init"))
|
|
|
|
var (
|
|
publicChatIDs []string
|
|
publicKeys []*ecdsa.PublicKey
|
|
)
|
|
|
|
joinedCommunities, err := m.communitiesManager.Joined()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
for _, org := range joinedCommunities {
|
|
// the org advertise on the public topic derived by the pk
|
|
publicChatIDs = append(publicChatIDs, org.IDString())
|
|
}
|
|
|
|
// Init filters for the communities we are an admin of
|
|
var adminCommunitiesPks []*ecdsa.PrivateKey
|
|
adminCommunities, err := m.communitiesManager.Created()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
for _, c := range adminCommunities {
|
|
adminCommunitiesPks = append(adminCommunitiesPks, c.PrivateKey())
|
|
}
|
|
|
|
_, err = m.transport.InitCommunityFilters(adminCommunitiesPks)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
// Get chat IDs and public keys from the existing chats.
|
|
// TODO: Get only active chats by the query.
|
|
chats, err := m.persistence.Chats()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
for _, chat := range chats {
|
|
if err := chat.Validate(); err != nil {
|
|
logger.Warn("failed to validate chat", zap.Error(err))
|
|
continue
|
|
}
|
|
|
|
m.allChats.Store(chat.ID, chat)
|
|
|
|
if !chat.Active || chat.Timeline() {
|
|
continue
|
|
}
|
|
|
|
switch chat.ChatType {
|
|
case ChatTypePublic, ChatTypeProfile:
|
|
publicChatIDs = append(publicChatIDs, chat.ID)
|
|
case ChatTypeCommunityChat:
|
|
publicChatIDs = append(publicChatIDs, chat.ID)
|
|
case ChatTypeOneToOne:
|
|
pk, err := chat.PublicKey()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
publicKeys = append(publicKeys, pk)
|
|
case ChatTypePrivateGroupChat:
|
|
for _, member := range chat.Members {
|
|
publicKey, err := member.PublicKey()
|
|
if err != nil {
|
|
return errors.Wrapf(err, "invalid public key for member %s in chat %s", member.ID, chat.Name)
|
|
}
|
|
publicKeys = append(publicKeys, publicKey)
|
|
}
|
|
default:
|
|
return errors.New("invalid chat type")
|
|
}
|
|
}
|
|
// upsert timeline chat
|
|
err = m.ensureTimelineChat()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
// upsert profile chat
|
|
err = m.ensureMyOwnProfileChat()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
// Get chat IDs and public keys from the contacts.
|
|
contacts, err := m.persistence.Contacts()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
for idx, contact := range contacts {
|
|
m.allContacts.Store(contact.ID, contacts[idx])
|
|
// We only need filters for contacts added by us and not blocked.
|
|
if !contact.Added || contact.Blocked {
|
|
continue
|
|
}
|
|
publicKey, err := contact.PublicKey()
|
|
if err != nil {
|
|
logger.Error("failed to get contact's public key", zap.Error(err))
|
|
continue
|
|
}
|
|
publicKeys = append(publicKeys, publicKey)
|
|
}
|
|
|
|
installations, err := m.encryptor.GetOurInstallations(&m.identity.PublicKey)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
for _, installation := range installations {
|
|
m.allInstallations.Store(installation.ID, installation)
|
|
}
|
|
|
|
_, err = m.transport.InitFilters(publicChatIDs, publicKeys)
|
|
return err
|
|
}
|
|
|
|
// Shutdown takes care of ensuring a clean shutdown of Messenger
|
|
func (m *Messenger) Shutdown() (err error) {
|
|
close(m.quit)
|
|
|
|
for i, task := range m.shutdownTasks {
|
|
m.logger.Debug("running shutdown task", zap.Int("n", i))
|
|
if tErr := task(); tErr != nil {
|
|
m.logger.Info("shutdown task failed", zap.Error(tErr))
|
|
if err == nil {
|
|
// First error appeared.
|
|
err = tErr
|
|
} else {
|
|
// We return all errors. They will be concatenated in the order of occurrence,
|
|
// however, they will also be returned as a single error.
|
|
err = errors.Wrap(err, tErr.Error())
|
|
}
|
|
}
|
|
}
|
|
return
|
|
}
|
|
|
|
func (m *Messenger) EnableInstallation(id string) error {
|
|
installation, ok := m.allInstallations.Load(id)
|
|
if !ok {
|
|
return errors.New("no installation found")
|
|
}
|
|
|
|
err := m.encryptor.EnableInstallation(&m.identity.PublicKey, id)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
installation.Enabled = true
|
|
// TODO(samyoul) remove storing of an updated reference pointer?
|
|
m.allInstallations.Store(id, installation)
|
|
return nil
|
|
}
|
|
|
|
func (m *Messenger) DisableInstallation(id string) error {
|
|
installation, ok := m.allInstallations.Load(id)
|
|
if !ok {
|
|
return errors.New("no installation found")
|
|
}
|
|
|
|
err := m.encryptor.DisableInstallation(&m.identity.PublicKey, id)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
installation.Enabled = false
|
|
// TODO(samyoul) remove storing of an updated reference pointer?
|
|
m.allInstallations.Store(id, installation)
|
|
return nil
|
|
}
|
|
|
|
func (m *Messenger) Installations() []*multidevice.Installation {
|
|
installations := make([]*multidevice.Installation, m.allInstallations.Len())
|
|
|
|
var i = 0
|
|
m.allInstallations.Range(func(installationID string, installation *multidevice.Installation) (shouldContinue bool) {
|
|
installations[i] = installation
|
|
i++
|
|
return true
|
|
})
|
|
return installations
|
|
}
|
|
|
|
func (m *Messenger) setInstallationMetadata(id string, data *multidevice.InstallationMetadata) error {
|
|
installation, ok := m.allInstallations.Load(id)
|
|
if !ok {
|
|
return errors.New("no installation found")
|
|
}
|
|
|
|
installation.InstallationMetadata = data
|
|
return m.encryptor.SetInstallationMetadata(&m.identity.PublicKey, id, data)
|
|
}
|
|
|
|
func (m *Messenger) SetInstallationMetadata(id string, data *multidevice.InstallationMetadata) error {
|
|
return m.setInstallationMetadata(id, data)
|
|
}
|
|
|
|
// NOT IMPLEMENTED
|
|
func (m *Messenger) SelectMailserver(id string) error {
|
|
return ErrNotImplemented
|
|
}
|
|
|
|
// NOT IMPLEMENTED
|
|
func (m *Messenger) AddMailserver(enode string) error {
|
|
return ErrNotImplemented
|
|
}
|
|
|
|
// NOT IMPLEMENTED
|
|
func (m *Messenger) RemoveMailserver(id string) error {
|
|
return ErrNotImplemented
|
|
}
|
|
|
|
// NOT IMPLEMENTED
|
|
func (m *Messenger) Mailservers() ([]string, error) {
|
|
return nil, ErrNotImplemented
|
|
}
|
|
|
|
func (m *Messenger) CreateGroupChatWithMembers(ctx context.Context, name string, members []string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
logger := m.logger.With(zap.String("site", "CreateGroupChatWithMembers"))
|
|
logger.Info("Creating group chat", zap.String("name", name), zap.Any("members", members))
|
|
chat := CreateGroupChat(m.getTimesource())
|
|
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
|
|
group, err := v1protocol.NewGroupWithCreator(name, clock, m.identity)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
chat.LastClockValue = clock
|
|
|
|
chat.updateChatFromGroupMembershipChanges(group)
|
|
chat.Joined = int64(m.getTimesource().GetCurrentTime())
|
|
|
|
clock, _ = chat.NextClockAndTimestamp(m.getTimesource())
|
|
|
|
// Add members
|
|
if len(members) > 0 {
|
|
event := v1protocol.NewMembersAddedEvent(members, clock)
|
|
event.ChatID = chat.ID
|
|
err = event.Sign(m.identity)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = group.ProcessEvent(event)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
recipients, err := stringSliceToPublicKeys(group.Members())
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
encodedMessage, err := m.sender.EncodeMembershipUpdate(group, nil)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
m.allChats.Store(chat.ID, &chat)
|
|
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_MEMBERSHIP_UPDATE_MESSAGE,
|
|
Recipients: recipients,
|
|
})
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
chat.updateChatFromGroupMembershipChanges(group)
|
|
|
|
return m.addMessagesAndChat(&chat, buildSystemMessages(chat.MembershipUpdates, m.systemMessagesTranslations), &response)
|
|
}
|
|
|
|
func (m *Messenger) addMessagesAndChat(chat *Chat, messages []*common.Message, response *MessengerResponse) (*MessengerResponse, error) {
|
|
response.AddChat(chat)
|
|
response.AddMessages(messages)
|
|
err := m.persistence.SaveMessages(response.Messages())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return response, m.saveChat(chat)
|
|
}
|
|
|
|
func (m *Messenger) CreateGroupChatFromInvitation(name string, chatID string, adminPK string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
logger := m.logger.With(zap.String("site", "CreateGroupChatFromInvitation"))
|
|
logger.Info("Creating group chat from invitation", zap.String("name", name))
|
|
chat := CreateGroupChat(m.getTimesource())
|
|
chat.ID = chatID
|
|
chat.Name = name
|
|
chat.InvitationAdmin = adminPK
|
|
|
|
response.AddChat(&chat)
|
|
|
|
return &response, m.saveChat(&chat)
|
|
}
|
|
|
|
func (m *Messenger) RemoveMemberFromGroupChat(ctx context.Context, chatID string, member string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
logger := m.logger.With(zap.String("site", "RemoveMemberFromGroupChat"))
|
|
logger.Info("Removing member form group chat", zap.String("chatID", chatID), zap.String("member", member))
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, ErrChatNotFound
|
|
}
|
|
|
|
group, err := newProtocolGroupFromChat(chat)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
// We save the initial recipients as we want to send updates to also
|
|
// the members kicked out
|
|
oldRecipients, err := stringSliceToPublicKeys(group.Members())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
// Remove member
|
|
event := v1protocol.NewMemberRemovedEvent(member, clock)
|
|
event.ChatID = chat.ID
|
|
err = event.Sign(m.identity)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = group.ProcessEvent(event)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
encodedMessage, err := m.sender.EncodeMembershipUpdate(group, nil)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_MEMBERSHIP_UPDATE_MESSAGE,
|
|
Recipients: oldRecipients,
|
|
})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
chat.updateChatFromGroupMembershipChanges(group)
|
|
|
|
return m.addMessagesAndChat(chat, buildSystemMessages(chat.MembershipUpdates, m.systemMessagesTranslations), &response)
|
|
}
|
|
|
|
func (m *Messenger) AddMembersToGroupChat(ctx context.Context, chatID string, members []string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
logger := m.logger.With(zap.String("site", "AddMembersFromGroupChat"))
|
|
logger.Info("Adding members form group chat", zap.String("chatID", chatID), zap.Any("members", members))
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, ErrChatNotFound
|
|
}
|
|
|
|
group, err := newProtocolGroupFromChat(chat)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
// Add members
|
|
event := v1protocol.NewMembersAddedEvent(members, clock)
|
|
event.ChatID = chat.ID
|
|
err = event.Sign(m.identity)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
//approve invitations
|
|
for _, member := range members {
|
|
logger.Info("ApproveInvitationByChatIdAndFrom", zap.String("chatID", chatID), zap.Any("member", member))
|
|
|
|
groupChatInvitation := &GroupChatInvitation{
|
|
GroupChatInvitation: protobuf.GroupChatInvitation{
|
|
ChatId: chat.ID,
|
|
},
|
|
From: member,
|
|
}
|
|
|
|
groupChatInvitation, err = m.persistence.InvitationByID(groupChatInvitation.ID())
|
|
if err != nil && err != common.ErrRecordNotFound {
|
|
return nil, err
|
|
}
|
|
if groupChatInvitation != nil {
|
|
groupChatInvitation.State = protobuf.GroupChatInvitation_APPROVED
|
|
|
|
err := m.persistence.SaveInvitation(groupChatInvitation)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
response.Invitations = append(response.Invitations, groupChatInvitation)
|
|
}
|
|
}
|
|
|
|
err = group.ProcessEvent(event)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
recipients, err := stringSliceToPublicKeys(group.Members())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
encodedMessage, err := m.sender.EncodeMembershipUpdate(group, nil)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_MEMBERSHIP_UPDATE_MESSAGE,
|
|
Recipients: recipients,
|
|
})
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
chat.updateChatFromGroupMembershipChanges(group)
|
|
|
|
return m.addMessagesAndChat(chat, buildSystemMessages([]v1protocol.MembershipUpdateEvent{event}, m.systemMessagesTranslations), &response)
|
|
}
|
|
|
|
func (m *Messenger) ChangeGroupChatName(ctx context.Context, chatID string, name string) (*MessengerResponse, error) {
|
|
logger := m.logger.With(zap.String("site", "ChangeGroupChatName"))
|
|
logger.Info("Changing group chat name", zap.String("chatID", chatID), zap.String("name", name))
|
|
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, ErrChatNotFound
|
|
}
|
|
|
|
group, err := newProtocolGroupFromChat(chat)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
// Add members
|
|
event := v1protocol.NewNameChangedEvent(name, clock)
|
|
event.ChatID = chat.ID
|
|
err = event.Sign(m.identity)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
// Update in-memory group
|
|
err = group.ProcessEvent(event)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
recipients, err := stringSliceToPublicKeys(group.Members())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
encodedMessage, err := m.sender.EncodeMembershipUpdate(group, nil)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_MEMBERSHIP_UPDATE_MESSAGE,
|
|
Recipients: recipients,
|
|
})
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
chat.updateChatFromGroupMembershipChanges(group)
|
|
|
|
var response MessengerResponse
|
|
|
|
return m.addMessagesAndChat(chat, buildSystemMessages([]v1protocol.MembershipUpdateEvent{event}, m.systemMessagesTranslations), &response)
|
|
}
|
|
|
|
func (m *Messenger) SendGroupChatInvitationRequest(ctx context.Context, chatID string, adminPK string,
|
|
message string) (*MessengerResponse, error) {
|
|
logger := m.logger.With(zap.String("site", "SendGroupChatInvitationRequest"))
|
|
logger.Info("Sending group chat invitation request", zap.String("chatID", chatID),
|
|
zap.String("adminPK", adminPK), zap.String("message", message))
|
|
|
|
var response MessengerResponse
|
|
|
|
// Get chat and clock
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, ErrChatNotFound
|
|
}
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
|
|
invitationR := &GroupChatInvitation{
|
|
GroupChatInvitation: protobuf.GroupChatInvitation{
|
|
Clock: clock,
|
|
ChatId: chatID,
|
|
IntroductionMessage: message,
|
|
State: protobuf.GroupChatInvitation_REQUEST,
|
|
},
|
|
From: types.EncodeHex(crypto.FromECDSAPub(&m.identity.PublicKey)),
|
|
}
|
|
|
|
encodedMessage, err := proto.Marshal(invitationR.GetProtobuf())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
spec := common.RawMessage{
|
|
LocalChatID: adminPK,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_GROUP_CHAT_INVITATION,
|
|
ResendAutomatically: true,
|
|
}
|
|
|
|
pkey, err := hex.DecodeString(adminPK[2:])
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
// Safety check, make sure is well formed
|
|
adminpk, err := crypto.UnmarshalPubkey(pkey)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
id, err := m.sender.SendPrivate(ctx, adminpk, &spec)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
spec.ID = types.EncodeHex(id)
|
|
spec.SendCount++
|
|
err = m.persistence.SaveRawMessage(&spec)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
response.Invitations = []*GroupChatInvitation{invitationR}
|
|
|
|
err = m.persistence.SaveInvitation(invitationR)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return &response, nil
|
|
}
|
|
|
|
func (m *Messenger) GetGroupChatInvitations() ([]*GroupChatInvitation, error) {
|
|
return m.persistence.GetGroupChatInvitations()
|
|
}
|
|
|
|
func (m *Messenger) SendGroupChatInvitationRejection(ctx context.Context, invitationRequestID string) (*MessengerResponse, error) {
|
|
logger := m.logger.With(zap.String("site", "SendGroupChatInvitationRejection"))
|
|
logger.Info("Sending group chat invitation reject", zap.String("invitationRequestID", invitationRequestID))
|
|
|
|
invitationR, err := m.persistence.InvitationByID(invitationRequestID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
invitationR.State = protobuf.GroupChatInvitation_REJECTED
|
|
|
|
// Get chat and clock
|
|
chat, ok := m.allChats.Load(invitationR.ChatId)
|
|
if !ok {
|
|
return nil, ErrChatNotFound
|
|
}
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
|
|
invitationR.Clock = clock
|
|
|
|
encodedMessage, err := proto.Marshal(invitationR.GetProtobuf())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
spec := common.RawMessage{
|
|
LocalChatID: invitationR.From,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_GROUP_CHAT_INVITATION,
|
|
ResendAutomatically: true,
|
|
}
|
|
|
|
pkey, err := hex.DecodeString(invitationR.From[2:])
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
// Safety check, make sure is well formed
|
|
userpk, err := crypto.UnmarshalPubkey(pkey)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
id, err := m.sender.SendPrivate(ctx, userpk, &spec)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
spec.ID = types.EncodeHex(id)
|
|
spec.SendCount++
|
|
err = m.persistence.SaveRawMessage(&spec)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
var response MessengerResponse
|
|
|
|
response.Invitations = []*GroupChatInvitation{invitationR}
|
|
|
|
err = m.persistence.SaveInvitation(invitationR)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return &response, nil
|
|
}
|
|
|
|
func (m *Messenger) AddAdminsToGroupChat(ctx context.Context, chatID string, members []string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
logger := m.logger.With(zap.String("site", "AddAdminsToGroupChat"))
|
|
logger.Info("Add admins to group chat", zap.String("chatID", chatID), zap.Any("members", members))
|
|
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, ErrChatNotFound
|
|
}
|
|
|
|
group, err := newProtocolGroupFromChat(chat)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
// Add members
|
|
event := v1protocol.NewAdminsAddedEvent(members, clock)
|
|
event.ChatID = chat.ID
|
|
err = event.Sign(m.identity)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = group.ProcessEvent(event)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
recipients, err := stringSliceToPublicKeys(group.Members())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
encodedMessage, err := m.sender.EncodeMembershipUpdate(group, nil)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_MEMBERSHIP_UPDATE_MESSAGE,
|
|
Recipients: recipients,
|
|
})
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
chat.updateChatFromGroupMembershipChanges(group)
|
|
return m.addMessagesAndChat(chat, buildSystemMessages([]v1protocol.MembershipUpdateEvent{event}, m.systemMessagesTranslations), &response)
|
|
}
|
|
|
|
func (m *Messenger) ConfirmJoiningGroup(ctx context.Context, chatID string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, ErrChatNotFound
|
|
}
|
|
|
|
_, err := m.Join(chat)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
group, err := newProtocolGroupFromChat(chat)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
event := v1protocol.NewMemberJoinedEvent(
|
|
clock,
|
|
)
|
|
event.ChatID = chat.ID
|
|
err = event.Sign(m.identity)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = group.ProcessEvent(event)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
recipients, err := stringSliceToPublicKeys(group.Members())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
encodedMessage, err := m.sender.EncodeMembershipUpdate(group, nil)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_MEMBERSHIP_UPDATE_MESSAGE,
|
|
Recipients: recipients,
|
|
})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
chat.updateChatFromGroupMembershipChanges(group)
|
|
chat.Joined = int64(m.getTimesource().GetCurrentTime())
|
|
|
|
return m.addMessagesAndChat(chat, buildSystemMessages([]v1protocol.MembershipUpdateEvent{event}, m.systemMessagesTranslations), &response)
|
|
}
|
|
|
|
func (m *Messenger) leaveGroupChat(ctx context.Context, response *MessengerResponse, chatID string, remove bool, shouldBeSynced bool) (*MessengerResponse, error) {
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, ErrChatNotFound
|
|
}
|
|
|
|
joined := chat.HasJoinedMember(common.PubkeyToHex(&m.identity.PublicKey))
|
|
|
|
if joined {
|
|
group, err := newProtocolGroupFromChat(chat)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
event := v1protocol.NewMemberRemovedEvent(
|
|
contactIDFromPublicKey(&m.identity.PublicKey),
|
|
clock,
|
|
)
|
|
event.ChatID = chat.ID
|
|
err = event.Sign(m.identity)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = group.ProcessEvent(event)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
recipients, err := stringSliceToPublicKeys(group.Members())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
encodedMessage, err := m.sender.EncodeMembershipUpdate(group, nil)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
// shouldBeSynced is false if we got here because a synced client has already
|
|
// sent the leave group message. In that case we don't need to send it again.
|
|
if shouldBeSynced {
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_MEMBERSHIP_UPDATE_MESSAGE,
|
|
Recipients: recipients,
|
|
})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
chat.updateChatFromGroupMembershipChanges(group)
|
|
response.AddMessages(buildSystemMessages([]v1protocol.MembershipUpdateEvent{event}, m.systemMessagesTranslations))
|
|
err = m.persistence.SaveMessages(response.Messages())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
if remove {
|
|
chat.Active = false
|
|
}
|
|
|
|
if remove && shouldBeSynced {
|
|
err := m.syncChatRemoving(ctx, chat.ID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
response.AddChat(chat)
|
|
|
|
return response, m.saveChat(chat)
|
|
}
|
|
|
|
func (m *Messenger) LeaveGroupChat(ctx context.Context, chatID string, remove bool) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
return m.leaveGroupChat(ctx, &response, chatID, remove, true)
|
|
}
|
|
|
|
// Decline all pending group invites from a user
|
|
func (m *Messenger) DeclineAllPendingGroupInvitesFromUser(response *MessengerResponse, userPublicKey string) (*MessengerResponse, error) {
|
|
|
|
// Decline group invites from active chats
|
|
chats, err := m.persistence.Chats()
|
|
var ctx context.Context
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
for _, chat := range chats {
|
|
if chat.ChatType == ChatTypePrivateGroupChat &&
|
|
chat.ReceivedInvitationAdmin == userPublicKey &&
|
|
chat.Joined == 0 && chat.Active {
|
|
response, err = m.leaveGroupChat(ctx, response, chat.ID, true, true)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
}
|
|
|
|
// Decline group invites from activity center notifications
|
|
notifications, err := m.persistence.AcceptActivityCenterNotificationsForInvitesFromUser(userPublicKey)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
for _, notification := range notifications {
|
|
response, err = m.leaveGroupChat(ctx, response, notification.ChatID, true, true)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
return response, nil
|
|
}
|
|
|
|
func (m *Messenger) reregisterForPushNotifications() error {
|
|
m.logger.Info("contact state changed, re-registering for push notification")
|
|
if m.pushNotificationClient == nil {
|
|
return nil
|
|
}
|
|
|
|
return m.pushNotificationClient.Reregister(m.pushNotificationOptions())
|
|
}
|
|
|
|
// pull a message from the database and send it again
|
|
func (m *Messenger) reSendRawMessage(ctx context.Context, messageID string) error {
|
|
message, err := m.persistence.RawMessageByID(messageID)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
chat, ok := m.allChats.Load(message.LocalChatID)
|
|
if !ok {
|
|
return errors.New("chat not found")
|
|
}
|
|
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: message.Payload,
|
|
MessageType: message.MessageType,
|
|
Recipients: message.Recipients,
|
|
ResendAutomatically: message.ResendAutomatically,
|
|
SendCount: message.SendCount,
|
|
})
|
|
return err
|
|
}
|
|
|
|
// ReSendChatMessage pulls a message from the database and sends it again
|
|
func (m *Messenger) ReSendChatMessage(ctx context.Context, messageID string) error {
|
|
return m.reSendRawMessage(ctx, messageID)
|
|
}
|
|
|
|
func (m *Messenger) hasPairedDevices() bool {
|
|
logger := m.logger.Named("hasPairedDevices")
|
|
|
|
var count int
|
|
m.allInstallations.Range(func(installationID string, installation *multidevice.Installation) (shouldContinue bool) {
|
|
if installation.Enabled {
|
|
count++
|
|
}
|
|
return true
|
|
})
|
|
logger.Debug("installations info",
|
|
zap.Int("Number of installations", m.allInstallations.Len()),
|
|
zap.Int("Number of enabled installations", count))
|
|
return count > 1
|
|
}
|
|
|
|
// sendToPairedDevices will check if we have any paired devices and send to them if necessary
|
|
func (m *Messenger) sendToPairedDevices(ctx context.Context, spec common.RawMessage) error {
|
|
hasPairedDevices := m.hasPairedDevices()
|
|
// We send a message to any paired device
|
|
if hasPairedDevices {
|
|
_, err := m.sender.SendPrivate(ctx, &m.identity.PublicKey, &spec)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
}
|
|
return nil
|
|
}
|
|
|
|
func (m *Messenger) dispatchPairInstallationMessage(ctx context.Context, spec common.RawMessage) ([]byte, error) {
|
|
var err error
|
|
var id []byte
|
|
|
|
id, err = m.sender.SendPairInstallation(ctx, &m.identity.PublicKey, spec)
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
spec.ID = types.EncodeHex(id)
|
|
spec.SendCount++
|
|
err = m.persistence.SaveRawMessage(&spec)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return id, nil
|
|
}
|
|
|
|
func (m *Messenger) dispatchMessage(ctx context.Context, spec common.RawMessage) (common.RawMessage, error) {
|
|
var err error
|
|
var id []byte
|
|
logger := m.logger.With(zap.String("site", "dispatchMessage"), zap.String("chatID", spec.LocalChatID))
|
|
chat, ok := m.allChats.Load(spec.LocalChatID)
|
|
if !ok {
|
|
return spec, errors.New("no chat found")
|
|
}
|
|
|
|
switch chat.ChatType {
|
|
case ChatTypeOneToOne:
|
|
publicKey, err := chat.PublicKey()
|
|
if err != nil {
|
|
return spec, err
|
|
}
|
|
|
|
//SendPrivate will alter message identity and possibly datasyncid, so we save an unchanged
|
|
//message for sending to paired devices later
|
|
specCopyForPairedDevices := spec
|
|
if !common.IsPubKeyEqual(publicKey, &m.identity.PublicKey) || spec.SkipEncryption {
|
|
id, err = m.sender.SendPrivate(ctx, publicKey, &spec)
|
|
|
|
if err != nil {
|
|
return spec, err
|
|
}
|
|
}
|
|
|
|
err = m.sendToPairedDevices(ctx, specCopyForPairedDevices)
|
|
|
|
if err != nil {
|
|
return spec, err
|
|
}
|
|
|
|
case ChatTypePublic, ChatTypeProfile:
|
|
logger.Debug("sending public message", zap.String("chatName", chat.Name))
|
|
id, err = m.sender.SendPublic(ctx, chat.ID, spec)
|
|
if err != nil {
|
|
return spec, err
|
|
}
|
|
case ChatTypeCommunityChat:
|
|
// TODO: add grant
|
|
canPost, err := m.communitiesManager.CanPost(&m.identity.PublicKey, chat.CommunityID, chat.CommunityChatID(), nil)
|
|
if err != nil {
|
|
return spec, err
|
|
}
|
|
|
|
// We allow emoji reactions by anyone
|
|
if spec.MessageType != protobuf.ApplicationMetadataMessage_EMOJI_REACTION && !canPost {
|
|
m.logger.Error("can't post on chat", zap.String("chat-id", chat.ID), zap.String("chat-name", chat.Name))
|
|
|
|
return spec, errors.New("can't post on chat")
|
|
}
|
|
|
|
logger.Debug("sending community chat message", zap.String("chatName", chat.Name))
|
|
id, err = m.sender.SendPublic(ctx, chat.ID, spec)
|
|
if err != nil {
|
|
return spec, err
|
|
}
|
|
case ChatTypePrivateGroupChat:
|
|
logger.Debug("sending group message", zap.String("chatName", chat.Name))
|
|
if spec.Recipients == nil {
|
|
// Anything that is not a membership update message is only dispatched to joined users
|
|
// NOTE: I think here it might make sense to always invite to joined users apart from the
|
|
// initial message
|
|
if spec.MessageType != protobuf.ApplicationMetadataMessage_MEMBERSHIP_UPDATE_MESSAGE {
|
|
spec.Recipients, err = chat.JoinedMembersAsPublicKeys()
|
|
if err != nil {
|
|
return spec, err
|
|
}
|
|
|
|
} else {
|
|
spec.Recipients, err = chat.MembersAsPublicKeys()
|
|
if err != nil {
|
|
return spec, err
|
|
}
|
|
}
|
|
}
|
|
|
|
hasPairedDevices := m.hasPairedDevices()
|
|
|
|
if !hasPairedDevices {
|
|
|
|
// Filter out my key from the recipients
|
|
n := 0
|
|
for _, recipient := range spec.Recipients {
|
|
if !common.IsPubKeyEqual(recipient, &m.identity.PublicKey) {
|
|
spec.Recipients[n] = recipient
|
|
n++
|
|
}
|
|
}
|
|
spec.Recipients = spec.Recipients[:n]
|
|
}
|
|
|
|
// We won't really send the message out if there's no recipients
|
|
if len(spec.Recipients) == 0 {
|
|
spec.Sent = true
|
|
}
|
|
|
|
// We skip wrapping in some cases (emoji reactions for example)
|
|
if !spec.SkipGroupMessageWrap {
|
|
spec.MessageType = protobuf.ApplicationMetadataMessage_MEMBERSHIP_UPDATE_MESSAGE
|
|
}
|
|
|
|
id, err = m.sender.SendGroup(ctx, spec.Recipients, spec)
|
|
if err != nil {
|
|
return spec, err
|
|
}
|
|
|
|
default:
|
|
return spec, errors.New("chat type not supported")
|
|
}
|
|
spec.ID = types.EncodeHex(id)
|
|
spec.SendCount++
|
|
spec.LastSent = m.getTimesource().GetCurrentTime()
|
|
err = m.persistence.SaveRawMessage(&spec)
|
|
if err != nil {
|
|
return spec, err
|
|
}
|
|
|
|
return spec, nil
|
|
}
|
|
|
|
// SendChatMessage takes a minimal message and sends it based on the corresponding chat
|
|
func (m *Messenger) SendChatMessage(ctx context.Context, message *common.Message) (*MessengerResponse, error) {
|
|
return m.sendChatMessage(ctx, message)
|
|
}
|
|
|
|
// SendChatMessages takes a array of messages and sends it based on the corresponding chats
|
|
func (m *Messenger) SendChatMessages(ctx context.Context, messages []*common.Message) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
|
|
for _, message := range messages {
|
|
messageResponse, err := m.SendChatMessage(ctx, message)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
err = response.Merge(messageResponse)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
return &response, nil
|
|
}
|
|
|
|
// SendChatMessage takes a minimal message and sends it based on the corresponding chat
|
|
func (m *Messenger) sendChatMessage(ctx context.Context, message *common.Message) (*MessengerResponse, error) {
|
|
if len(message.ImagePath) != 0 {
|
|
file, err := os.Open(message.ImagePath)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
defer file.Close()
|
|
|
|
payload, err := ioutil.ReadAll(file)
|
|
if err != nil {
|
|
return nil, err
|
|
|
|
}
|
|
image := protobuf.ImageMessage{
|
|
Payload: payload,
|
|
Type: images.ImageType(payload),
|
|
}
|
|
message.Payload = &protobuf.ChatMessage_Image{Image: &image}
|
|
|
|
} else if len(message.CommunityID) != 0 {
|
|
community, err := m.communitiesManager.GetByIDString(message.CommunityID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if community == nil {
|
|
return nil, errors.New("community not found")
|
|
}
|
|
|
|
wrappedCommunity, err := community.ToBytes()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
message.Payload = &protobuf.ChatMessage_Community{Community: wrappedCommunity}
|
|
|
|
message.ContentType = protobuf.ChatMessage_COMMUNITY
|
|
|
|
} else if len(message.AudioPath) != 0 {
|
|
file, err := os.Open(message.AudioPath)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
defer file.Close()
|
|
|
|
payload, err := ioutil.ReadAll(file)
|
|
if err != nil {
|
|
return nil, err
|
|
|
|
}
|
|
audioMessage := message.GetAudio()
|
|
if audioMessage == nil {
|
|
return nil, errors.New("no audio has been passed")
|
|
}
|
|
audioMessage.Payload = payload
|
|
audioMessage.Type = audio.Type(payload)
|
|
message.Payload = &protobuf.ChatMessage_Audio{Audio: audioMessage}
|
|
err = os.Remove(message.AudioPath)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
var response MessengerResponse
|
|
|
|
// A valid added chat is required.
|
|
chat, ok := m.allChats.Load(message.ChatId)
|
|
if !ok {
|
|
return nil, errors.New("Chat not found")
|
|
}
|
|
|
|
err := m.handleStandaloneChatIdentity(chat)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = extendMessageFromChat(message, chat, &m.identity.PublicKey, m.getTimesource())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
encodedMessage, err := m.encodeChatEntity(chat, message)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
rawMessage := common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
SendPushNotification: m.featureFlags.PushNotifications,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_CHAT_MESSAGE,
|
|
ResendAutomatically: true,
|
|
}
|
|
rawMessage, err = m.dispatchMessage(ctx, rawMessage)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if rawMessage.Sent {
|
|
message.OutgoingStatus = common.OutgoingStatusSent
|
|
}
|
|
message.ID = rawMessage.ID
|
|
err = message.PrepareContent(common.PubkeyToHex(&m.identity.PublicKey))
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = chat.UpdateFromMessage(message, m.getTimesource())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = m.persistence.SaveMessages([]*common.Message{message})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
msg, err := m.pullMessagesAndResponsesFromDB([]*common.Message{message})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
response.SetMessages(msg)
|
|
|
|
response.AddChat(chat)
|
|
m.logger.Debug("sent message", zap.String("id", message.ID))
|
|
m.prepareMessages(response.messages)
|
|
|
|
return &response, m.saveChat(chat)
|
|
}
|
|
|
|
// SyncDevices sends all public chats and contacts to paired devices
|
|
// TODO remove use of photoPath in contacts
|
|
func (m *Messenger) SyncDevices(ctx context.Context, ensName, photoPath string) (err error) {
|
|
myID := contactIDFromPublicKey(&m.identity.PublicKey)
|
|
|
|
if _, err = m.sendContactUpdate(ctx, myID, ensName, photoPath); err != nil {
|
|
return err
|
|
}
|
|
|
|
m.allChats.Range(func(chatID string, chat *Chat) (shouldContinue bool) {
|
|
isPublicChat := !chat.Timeline() && !chat.ProfileUpdates() && chat.Public()
|
|
if isPublicChat && chat.Active {
|
|
err = m.syncPublicChat(ctx, chat)
|
|
if err != nil {
|
|
return false
|
|
}
|
|
}
|
|
|
|
if (isPublicChat || chat.OneToOne() || chat.PrivateGroupChat()) && !chat.Active {
|
|
pending, err := m.persistence.HasPendingNotificationsForChat(chat.ID)
|
|
if err != nil {
|
|
return false
|
|
}
|
|
|
|
if !pending {
|
|
err = m.syncChatRemoving(ctx, chatID)
|
|
if err != nil {
|
|
return false
|
|
}
|
|
}
|
|
}
|
|
|
|
if (isPublicChat || chat.OneToOne() || chat.PrivateGroupChat() || chat.CommunityChat()) && chat.Active {
|
|
err := m.syncChatMessagesRead(ctx, chatID, chat.ReadMessagesAtClockValue)
|
|
if err != nil {
|
|
return false
|
|
}
|
|
}
|
|
|
|
return true
|
|
})
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
m.allContacts.Range(func(contactID string, contact *Contact) (shouldContinue bool) {
|
|
if contact.ID != myID &&
|
|
(contact.LocalNickname != "" || contact.Added || contact.Blocked) {
|
|
if err = m.syncContact(ctx, contact); err != nil {
|
|
return false
|
|
}
|
|
}
|
|
return true
|
|
})
|
|
|
|
cs, err := m.communitiesManager.JoinedAndPendingCommunitiesWithRequests()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
for _, c := range cs {
|
|
if err = m.syncCommunity(ctx, c); err != nil {
|
|
return err
|
|
}
|
|
}
|
|
|
|
return err
|
|
}
|
|
|
|
func (m *Messenger) getLastClockWithRelatedChat() (uint64, *Chat) {
|
|
chatID := contactIDFromPublicKey(&m.identity.PublicKey)
|
|
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
chat = OneToOneFromPublicKey(&m.identity.PublicKey, m.getTimesource())
|
|
// We don't want to show the chat to the user
|
|
chat.Active = false
|
|
}
|
|
|
|
m.allChats.Store(chat.ID, chat)
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
|
|
return clock, chat
|
|
}
|
|
|
|
// SendPairInstallation sends a pair installation message
|
|
func (m *Messenger) SendPairInstallation(ctx context.Context) (*MessengerResponse, error) {
|
|
var err error
|
|
var response MessengerResponse
|
|
|
|
installation, ok := m.allInstallations.Load(m.installationID)
|
|
if !ok {
|
|
return nil, errors.New("no installation found")
|
|
}
|
|
|
|
if installation.InstallationMetadata == nil {
|
|
return nil, errors.New("no installation metadata")
|
|
}
|
|
|
|
clock, chat := m.getLastClockWithRelatedChat()
|
|
|
|
pairMessage := &protobuf.PairInstallation{
|
|
Clock: clock,
|
|
Name: installation.InstallationMetadata.Name,
|
|
InstallationId: installation.ID,
|
|
DeviceType: installation.InstallationMetadata.DeviceType}
|
|
encodedMessage, err := proto.Marshal(pairMessage)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
_, err = m.dispatchPairInstallationMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_PAIR_INSTALLATION,
|
|
ResendAutomatically: true,
|
|
})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
response.AddChat(chat)
|
|
|
|
chat.LastClockValue = clock
|
|
err = m.saveChat(chat)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
return &response, nil
|
|
}
|
|
|
|
// syncPublicChat sync a public chat with paired devices
|
|
func (m *Messenger) syncPublicChat(ctx context.Context, publicChat *Chat) error {
|
|
var err error
|
|
if !m.hasPairedDevices() {
|
|
return nil
|
|
}
|
|
clock, chat := m.getLastClockWithRelatedChat()
|
|
|
|
syncMessage := &protobuf.SyncInstallationPublicChat{
|
|
Clock: clock,
|
|
Id: publicChat.ID,
|
|
}
|
|
encodedMessage, err := proto.Marshal(syncMessage)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_SYNC_INSTALLATION_PUBLIC_CHAT,
|
|
ResendAutomatically: true,
|
|
})
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
chat.LastClockValue = clock
|
|
return m.saveChat(chat)
|
|
}
|
|
|
|
func (m *Messenger) syncChatRemoving(ctx context.Context, id string) error {
|
|
var err error
|
|
if !m.hasPairedDevices() {
|
|
return nil
|
|
}
|
|
clock, chat := m.getLastClockWithRelatedChat()
|
|
|
|
syncMessage := &protobuf.SyncChatRemoved{
|
|
Clock: clock,
|
|
Id: id,
|
|
}
|
|
encodedMessage, err := proto.Marshal(syncMessage)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_SYNC_CHAT_REMOVED,
|
|
ResendAutomatically: true,
|
|
})
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
chat.LastClockValue = clock
|
|
return m.saveChat(chat)
|
|
}
|
|
|
|
// syncContact sync as contact with paired devices
|
|
func (m *Messenger) syncContact(ctx context.Context, contact *Contact) error {
|
|
var err error
|
|
if contact.IsSyncing {
|
|
return nil
|
|
}
|
|
if !m.hasPairedDevices() {
|
|
return nil
|
|
}
|
|
clock, chat := m.getLastClockWithRelatedChat()
|
|
|
|
var ensName string
|
|
if contact.ENSVerified {
|
|
ensName = contact.Name
|
|
}
|
|
|
|
oneToOneChat, ok := m.allChats.Load(contact.ID)
|
|
muted := false
|
|
if ok {
|
|
muted = oneToOneChat.Muted
|
|
}
|
|
|
|
syncMessage := &protobuf.SyncInstallationContactV2{
|
|
LastUpdatedLocally: contact.LastUpdatedLocally,
|
|
LastUpdated: contact.LastUpdated,
|
|
Id: contact.ID,
|
|
EnsName: ensName,
|
|
LocalNickname: contact.LocalNickname,
|
|
Added: contact.Added,
|
|
Blocked: contact.Blocked,
|
|
Muted: muted,
|
|
Removed: contact.Removed,
|
|
}
|
|
|
|
encodedMessage, err := proto.Marshal(syncMessage)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_SYNC_INSTALLATION_CONTACT,
|
|
ResendAutomatically: true,
|
|
})
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
chat.LastClockValue = clock
|
|
return m.saveChat(chat)
|
|
}
|
|
|
|
func (m *Messenger) syncCommunity(ctx context.Context, community *communities.Community) error {
|
|
logger := m.logger.Named("syncCommunity")
|
|
if !m.hasPairedDevices() {
|
|
logger.Debug("device has no paired devices")
|
|
return nil
|
|
}
|
|
logger.Debug("device has paired device(s)")
|
|
|
|
clock, chat := m.getLastClockWithRelatedChat()
|
|
|
|
syncMessage, err := community.ToSyncCommunityProtobuf(clock)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
encodedMessage, err := proto.Marshal(syncMessage)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_SYNC_INSTALLATION_COMMUNITY,
|
|
ResendAutomatically: true,
|
|
})
|
|
if err != nil {
|
|
return err
|
|
}
|
|
logger.Debug("message dispatched")
|
|
|
|
chat.LastClockValue = clock
|
|
return m.saveChat(chat)
|
|
}
|
|
|
|
// RetrieveAll retrieves messages from all filters, processes them and returns a
|
|
// MessengerResponse to the client
|
|
func (m *Messenger) RetrieveAll() (*MessengerResponse, error) {
|
|
chatWithMessages, err := m.transport.RetrieveRawAll()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return m.handleRetrievedMessages(chatWithMessages)
|
|
}
|
|
|
|
func (m *Messenger) GetStats() types.StatsSummary {
|
|
return m.transport.GetStats()
|
|
}
|
|
|
|
type CurrentMessageState struct {
|
|
// Message is the protobuf message received
|
|
Message protobuf.ChatMessage
|
|
// MessageID is the ID of the message
|
|
MessageID string
|
|
// WhisperTimestamp is the whisper timestamp of the message
|
|
WhisperTimestamp uint64
|
|
// Contact is the contact associated with the author of the message
|
|
Contact *Contact
|
|
// PublicKey is the public key of the author of the message
|
|
PublicKey *ecdsa.PublicKey
|
|
}
|
|
|
|
type ReceivedMessageState struct {
|
|
// State on the message being processed
|
|
CurrentMessageState *CurrentMessageState
|
|
// AllChats in memory
|
|
AllChats *chatMap
|
|
// All contacts in memory
|
|
AllContacts *contactMap
|
|
// List of contacts modified
|
|
ModifiedContacts *stringBoolMap
|
|
// All installations in memory
|
|
AllInstallations *installationMap
|
|
// List of communities modified
|
|
ModifiedInstallations *stringBoolMap
|
|
// Map of existing messages
|
|
ExistingMessagesMap map[string]bool
|
|
// EmojiReactions is a list of emoji reactions for the current batch
|
|
// indexed by from-message-id-emoji-type
|
|
EmojiReactions map[string]*EmojiReaction
|
|
// GroupChatInvitations is a list of invitation requests or rejections
|
|
GroupChatInvitations map[string]*GroupChatInvitation
|
|
// Response to the client
|
|
Response *MessengerResponse
|
|
// Timesource is a time source for clock values/timestamps.
|
|
Timesource common.TimeSource
|
|
}
|
|
|
|
func (m *Messenger) markDeliveredMessages(acks [][]byte) {
|
|
for _, ack := range acks {
|
|
//get message ID from database by datasync ID, with at-least-one
|
|
// semantic
|
|
messageIDBytes, err := m.persistence.MarkAsConfirmed(ack, true)
|
|
if err != nil {
|
|
m.logger.Info("got datasync acknowledge for message we don't have in db", zap.String("ack", hex.EncodeToString(ack)))
|
|
continue
|
|
}
|
|
|
|
messageID := messageIDBytes.String()
|
|
//mark messages as delivered
|
|
err = m.UpdateMessageOutgoingStatus(messageID, common.OutgoingStatusDelivered)
|
|
if err != nil {
|
|
m.logger.Debug("Can't set message status as delivered", zap.Error(err))
|
|
}
|
|
|
|
//send signal to client that message status updated
|
|
if m.config.messengerSignalsHandler != nil {
|
|
message, err := m.persistence.MessageByID(messageID)
|
|
if err != nil {
|
|
m.logger.Debug("Can't get message from database", zap.Error(err))
|
|
continue
|
|
}
|
|
m.config.messengerSignalsHandler.MessageDelivered(message.LocalChatID, messageID)
|
|
}
|
|
}
|
|
}
|
|
|
|
// addNewMessageNotification takes a common.Message and generates a new NotificationBody and appends it to the
|
|
// []Response.Notifications if the message is m.New
|
|
func (r *ReceivedMessageState) addNewMessageNotification(publicKey ecdsa.PublicKey, m *common.Message, responseTo *common.Message, profilePicturesVisibility int) error {
|
|
if !m.New {
|
|
return nil
|
|
}
|
|
|
|
pubKey, err := m.GetSenderPubKey()
|
|
if err != nil {
|
|
return err
|
|
}
|
|
contactID := contactIDFromPublicKey(pubKey)
|
|
|
|
chat, ok := r.AllChats.Load(m.LocalChatID)
|
|
if !ok {
|
|
return fmt.Errorf("chat ID '%s' not present", m.LocalChatID)
|
|
}
|
|
|
|
contact, ok := r.AllContacts.Load(contactID)
|
|
if !ok {
|
|
return fmt.Errorf("contact ID '%s' not present", contactID)
|
|
}
|
|
|
|
if showMessageNotification(publicKey, m, chat, responseTo) {
|
|
notification, err := NewMessageNotification(m.ID, m, chat, contact, r.AllContacts, profilePicturesVisibility)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
r.Response.AddNotification(notification)
|
|
}
|
|
|
|
return nil
|
|
}
|
|
|
|
// addNewActivityCenterNotification takes a common.Message and generates a new ActivityCenterNotification and appends it to the
|
|
// []Response.ActivityCenterNotifications if the message is m.New
|
|
func (r *ReceivedMessageState) addNewActivityCenterNotification(publicKey ecdsa.PublicKey, m *Messenger, message *common.Message, responseTo *common.Message) error {
|
|
if !message.New {
|
|
return nil
|
|
}
|
|
|
|
chat, ok := r.AllChats.Load(message.LocalChatID)
|
|
if !ok {
|
|
return fmt.Errorf("chat ID '%s' not present", message.LocalChatID)
|
|
}
|
|
|
|
isNotification, notificationType := showMentionOrReplyActivityCenterNotification(publicKey, message, chat, responseTo)
|
|
if isNotification {
|
|
notification := &ActivityCenterNotification{
|
|
ID: types.FromHex(message.ID),
|
|
Name: chat.Name,
|
|
Message: message,
|
|
ReplyMessage: responseTo,
|
|
Type: notificationType,
|
|
Timestamp: message.WhisperTimestamp,
|
|
ChatID: chat.ID,
|
|
Author: message.From,
|
|
}
|
|
|
|
err := m.persistence.SaveActivityCenterNotification(notification)
|
|
if err != nil {
|
|
m.logger.Warn("failed to save notification", zap.Error(err))
|
|
return err
|
|
}
|
|
r.Response.AddActivityCenterNotification(notification)
|
|
}
|
|
|
|
return nil
|
|
}
|
|
|
|
func (m *Messenger) handleRetrievedMessages(chatWithMessages map[transport.Filter][]*types.Message) (*MessengerResponse, error) {
|
|
response := &MessengerResponse{}
|
|
messageState := &ReceivedMessageState{
|
|
AllChats: m.allChats,
|
|
AllContacts: m.allContacts,
|
|
ModifiedContacts: new(stringBoolMap),
|
|
AllInstallations: m.allInstallations,
|
|
ModifiedInstallations: m.modifiedInstallations,
|
|
ExistingMessagesMap: make(map[string]bool),
|
|
EmojiReactions: make(map[string]*EmojiReaction),
|
|
GroupChatInvitations: make(map[string]*GroupChatInvitation),
|
|
Response: response,
|
|
Timesource: m.getTimesource(),
|
|
}
|
|
|
|
logger := m.logger.With(zap.String("site", "RetrieveAll"))
|
|
|
|
for filter, messages := range chatWithMessages {
|
|
var processedMessages []string
|
|
for _, shhMessage := range messages {
|
|
logger := logger.With(zap.String("hash", types.EncodeHex(shhMessage.Hash)))
|
|
// Indicates tha all messages in the batch have been processed correctly
|
|
allMessagesProcessed := true
|
|
statusMessages, acks, err := m.sender.HandleMessages(shhMessage, true)
|
|
if err != nil {
|
|
logger.Info("failed to decode messages", zap.Error(err))
|
|
continue
|
|
}
|
|
|
|
if m.telemetryClient != nil {
|
|
go m.telemetryClient.PushReceivedMessages(filter, shhMessage, statusMessages)
|
|
}
|
|
m.markDeliveredMessages(acks)
|
|
|
|
logger.Debug("processing messages further", zap.Int("count", len(statusMessages)))
|
|
|
|
for _, msg := range statusMessages {
|
|
logger := logger.With(zap.String("message-id", msg.ID.String()))
|
|
logger.Debug("processing message")
|
|
publicKey := msg.SigPubKey()
|
|
|
|
m.handleInstallations(msg.Installations)
|
|
err := m.handleSharedSecrets(msg.SharedSecrets)
|
|
if err != nil {
|
|
// log and continue, non-critical error
|
|
logger.Warn("failed to handle shared secrets")
|
|
}
|
|
|
|
// Check for messages from blocked users
|
|
senderID := contactIDFromPublicKey(publicKey)
|
|
if contact, ok := messageState.AllContacts.Load(senderID); ok && contact.Blocked {
|
|
continue
|
|
}
|
|
|
|
// Don't process duplicates
|
|
messageID := types.EncodeHex(msg.ID)
|
|
exists, err := m.messageExists(messageID, messageState.ExistingMessagesMap)
|
|
if err != nil {
|
|
logger.Warn("failed to check message exists", zap.Error(err))
|
|
}
|
|
if exists {
|
|
logger.Debug("messageExists", zap.String("messageID", messageID))
|
|
continue
|
|
}
|
|
|
|
var contact *Contact
|
|
if c, ok := messageState.AllContacts.Load(senderID); ok {
|
|
contact = c
|
|
} else {
|
|
c, err := buildContact(senderID, publicKey)
|
|
if err != nil {
|
|
logger.Info("failed to build contact", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
contact = c
|
|
messageState.AllContacts.Store(senderID, contact)
|
|
}
|
|
messageState.CurrentMessageState = &CurrentMessageState{
|
|
MessageID: messageID,
|
|
WhisperTimestamp: uint64(msg.TransportMessage.Timestamp) * 1000,
|
|
Contact: contact,
|
|
PublicKey: publicKey,
|
|
}
|
|
|
|
if msg.ParsedMessage != nil {
|
|
|
|
logger.Debug("Handling parsed message")
|
|
switch msg.ParsedMessage.Interface().(type) {
|
|
case protobuf.MembershipUpdateMessage:
|
|
logger.Debug("Handling MembershipUpdateMessage")
|
|
rawMembershipUpdate := msg.ParsedMessage.Interface().(protobuf.MembershipUpdateMessage)
|
|
|
|
chat, _ := messageState.AllChats.Load(rawMembershipUpdate.ChatId)
|
|
err = m.HandleMembershipUpdate(messageState, chat, rawMembershipUpdate, m.systemMessagesTranslations)
|
|
if err != nil {
|
|
logger.Warn("failed to handle MembershipUpdate", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.ChatMessage:
|
|
logger.Debug("Handling ChatMessage")
|
|
messageState.CurrentMessageState.Message = msg.ParsedMessage.Interface().(protobuf.ChatMessage)
|
|
err = m.HandleChatMessage(messageState)
|
|
if err != nil {
|
|
logger.Warn("failed to handle ChatMessage", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.EditMessage:
|
|
logger.Debug("Handling EditMessage")
|
|
editProto := msg.ParsedMessage.Interface().(protobuf.EditMessage)
|
|
editMessage := EditMessage{
|
|
EditMessage: editProto,
|
|
From: contact.ID,
|
|
ID: messageID,
|
|
SigPubKey: publicKey,
|
|
}
|
|
err = m.HandleEditMessage(response, editMessage)
|
|
if err != nil {
|
|
logger.Warn("failed to handle EditMessage", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.DeleteMessage:
|
|
logger.Debug("Handling DeleteMessage")
|
|
deleteProto := msg.ParsedMessage.Interface().(protobuf.DeleteMessage)
|
|
deleteMessage := DeleteMessage{
|
|
DeleteMessage: deleteProto,
|
|
From: contact.ID,
|
|
ID: messageID,
|
|
SigPubKey: publicKey,
|
|
}
|
|
|
|
err = m.HandleDeleteMessage(messageState, deleteMessage)
|
|
if err != nil {
|
|
logger.Warn("failed to handle DeleteMessage", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.PinMessage:
|
|
pinMessage := msg.ParsedMessage.Interface().(protobuf.PinMessage)
|
|
err = m.HandlePinMessage(messageState, pinMessage)
|
|
if err != nil {
|
|
logger.Warn("failed to handle PinMessage", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.PairInstallation:
|
|
if !common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("not coming from us, ignoring")
|
|
continue
|
|
}
|
|
p := msg.ParsedMessage.Interface().(protobuf.PairInstallation)
|
|
logger.Debug("Handling PairInstallation", zap.Any("message", p))
|
|
err = m.HandlePairInstallation(messageState, p)
|
|
if err != nil {
|
|
logger.Warn("failed to handle PairInstallation", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.StatusUpdate:
|
|
p := msg.ParsedMessage.Interface().(protobuf.StatusUpdate)
|
|
logger.Debug("Handling StatusUpdate", zap.Any("message", p))
|
|
err = m.HandleStatusUpdate(messageState, p)
|
|
if err != nil {
|
|
logger.Warn("failed to handle StatusMessage", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.SyncInstallationContact:
|
|
logger.Warn("SyncInstallationContact is not supported")
|
|
continue
|
|
|
|
case protobuf.SyncInstallationContactV2:
|
|
if !common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("not coming from us, ignoring")
|
|
continue
|
|
}
|
|
|
|
p := msg.ParsedMessage.Interface().(protobuf.SyncInstallationContactV2)
|
|
logger.Debug("Handling SyncInstallationContact", zap.Any("message", p))
|
|
err = m.HandleSyncInstallationContact(messageState, p)
|
|
if err != nil {
|
|
logger.Warn("failed to handle SyncInstallationContact", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.Backup:
|
|
if !common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("not coming from us, ignoring")
|
|
continue
|
|
}
|
|
|
|
p := msg.ParsedMessage.Interface().(protobuf.Backup)
|
|
logger.Debug("Handling Backup", zap.Any("message", p))
|
|
err = m.HandleBackup(messageState, p)
|
|
if err != nil {
|
|
logger.Warn("failed to handle Backup", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.SyncInstallationPublicChat:
|
|
if !common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("not coming from us, ignoring")
|
|
continue
|
|
}
|
|
|
|
p := msg.ParsedMessage.Interface().(protobuf.SyncInstallationPublicChat)
|
|
logger.Debug("Handling SyncInstallationPublicChat", zap.Any("message", p))
|
|
addedChat := m.HandleSyncInstallationPublicChat(messageState, p)
|
|
|
|
// We join and re-register as we want to receive mentions from the newly joined public chat
|
|
if addedChat != nil {
|
|
_, err = m.createPublicChat(addedChat.ID, messageState.Response)
|
|
if err != nil {
|
|
allMessagesProcessed = false
|
|
logger.Error("error joining chat", zap.Error(err))
|
|
continue
|
|
}
|
|
}
|
|
|
|
case protobuf.SyncChatRemoved:
|
|
if !common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("not coming from us, ignoring")
|
|
continue
|
|
}
|
|
|
|
p := msg.ParsedMessage.Interface().(protobuf.SyncChatRemoved)
|
|
logger.Debug("Handling SyncChatRemoved", zap.Any("message", p))
|
|
err := m.HandleSyncChatRemoved(messageState, p)
|
|
if err != nil {
|
|
logger.Warn("failed to handle sync removing chat", zap.Error(err))
|
|
continue
|
|
}
|
|
|
|
case protobuf.SyncChatMessagesRead:
|
|
if !common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("not coming from us, ignoring")
|
|
continue
|
|
}
|
|
|
|
p := msg.ParsedMessage.Interface().(protobuf.SyncChatMessagesRead)
|
|
logger.Debug("Handling SyncChatMessagesRead", zap.Any("message", p))
|
|
err := m.HandleSyncChatMessagesRead(messageState, p)
|
|
if err != nil {
|
|
logger.Warn("failed to handle sync removing chat", zap.Error(err))
|
|
continue
|
|
}
|
|
|
|
case protobuf.SyncCommunity:
|
|
if !common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("not coming from us, ignoring")
|
|
continue
|
|
}
|
|
|
|
community := msg.ParsedMessage.Interface().(protobuf.SyncCommunity)
|
|
logger.Debug("Handling SyncCommunity", zap.Any("message", community))
|
|
|
|
err = m.handleSyncCommunity(messageState, community)
|
|
if err != nil {
|
|
logger.Warn("failed to handle SyncCommunity", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.SyncActivityCenterRead:
|
|
if !common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("not coming from us, ignoring")
|
|
continue
|
|
}
|
|
|
|
a := msg.ParsedMessage.Interface().(protobuf.SyncActivityCenterRead)
|
|
logger.Debug("Handling SyncActivityCenterRead", zap.Any("message", a))
|
|
|
|
err = m.handleActivityCenterRead(messageState, a)
|
|
if err != nil {
|
|
logger.Warn("failed to handle SyncActivityCenterRead", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.SyncActivityCenterAccepted:
|
|
if !common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("not coming from us, ignoring")
|
|
continue
|
|
}
|
|
|
|
a := msg.ParsedMessage.Interface().(protobuf.SyncActivityCenterAccepted)
|
|
logger.Debug("Handling SyncActivityCenterAccepted", zap.Any("message", a))
|
|
|
|
err = m.handleActivityCenterAccepted(messageState, a)
|
|
if err != nil {
|
|
logger.Warn("failed to handle SyncActivityCenterAccepted", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.SyncActivityCenterDismissed:
|
|
if !common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("not coming from us, ignoring")
|
|
continue
|
|
}
|
|
|
|
a := msg.ParsedMessage.Interface().(protobuf.SyncActivityCenterDismissed)
|
|
logger.Debug("Handling SyncActivityCenterDismissed", zap.Any("message", a))
|
|
|
|
err = m.handleActivityCenterDismissed(messageState, a)
|
|
if err != nil {
|
|
logger.Warn("failed to handle SyncActivityCenterDismissed", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.RequestAddressForTransaction:
|
|
command := msg.ParsedMessage.Interface().(protobuf.RequestAddressForTransaction)
|
|
logger.Debug("Handling RequestAddressForTransaction", zap.Any("message", command))
|
|
err = m.HandleRequestAddressForTransaction(messageState, command)
|
|
if err != nil {
|
|
logger.Warn("failed to handle RequestAddressForTransaction", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.SendTransaction:
|
|
command := msg.ParsedMessage.Interface().(protobuf.SendTransaction)
|
|
logger.Debug("Handling SendTransaction", zap.Any("message", command))
|
|
err = m.HandleSendTransaction(messageState, command)
|
|
if err != nil {
|
|
logger.Warn("failed to handle SendTransaction", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.AcceptRequestAddressForTransaction:
|
|
command := msg.ParsedMessage.Interface().(protobuf.AcceptRequestAddressForTransaction)
|
|
logger.Debug("Handling AcceptRequestAddressForTransaction")
|
|
err = m.HandleAcceptRequestAddressForTransaction(messageState, command)
|
|
if err != nil {
|
|
logger.Warn("failed to handle AcceptRequestAddressForTransaction", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.DeclineRequestAddressForTransaction:
|
|
command := msg.ParsedMessage.Interface().(protobuf.DeclineRequestAddressForTransaction)
|
|
logger.Debug("Handling DeclineRequestAddressForTransaction")
|
|
err = m.HandleDeclineRequestAddressForTransaction(messageState, command)
|
|
if err != nil {
|
|
logger.Warn("failed to handle DeclineRequestAddressForTransaction", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.DeclineRequestTransaction:
|
|
command := msg.ParsedMessage.Interface().(protobuf.DeclineRequestTransaction)
|
|
logger.Debug("Handling DeclineRequestTransaction")
|
|
err = m.HandleDeclineRequestTransaction(messageState, command)
|
|
if err != nil {
|
|
logger.Warn("failed to handle DeclineRequestTransaction", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.RequestTransaction:
|
|
command := msg.ParsedMessage.Interface().(protobuf.RequestTransaction)
|
|
|
|
logger.Debug("Handling RequestTransaction")
|
|
err = m.HandleRequestTransaction(messageState, command)
|
|
if err != nil {
|
|
logger.Warn("failed to handle RequestTransaction", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.ContactUpdate:
|
|
if common.IsPubKeyEqual(messageState.CurrentMessageState.PublicKey, &m.identity.PublicKey) {
|
|
logger.Warn("coming from us, ignoring")
|
|
continue
|
|
}
|
|
|
|
contactUpdate := msg.ParsedMessage.Interface().(protobuf.ContactUpdate)
|
|
err = m.HandleContactUpdate(messageState, contactUpdate)
|
|
if err != nil {
|
|
logger.Warn("failed to handle ContactUpdate", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
case protobuf.PushNotificationQuery:
|
|
logger.Debug("Received PushNotificationQuery")
|
|
if m.pushNotificationServer == nil {
|
|
continue
|
|
}
|
|
logger.Debug("Handling PushNotificationQuery")
|
|
if err := m.pushNotificationServer.HandlePushNotificationQuery(publicKey, msg.ID, msg.ParsedMessage.Interface().(protobuf.PushNotificationQuery)); err != nil {
|
|
allMessagesProcessed = false
|
|
logger.Warn("failed to handle PushNotificationQuery", zap.Error(err))
|
|
}
|
|
// We continue in any case, no changes to messenger
|
|
continue
|
|
case protobuf.PushNotificationRegistrationResponse:
|
|
logger.Debug("Received PushNotificationRegistrationResponse")
|
|
if m.pushNotificationClient == nil {
|
|
continue
|
|
}
|
|
logger.Debug("Handling PushNotificationRegistrationResponse")
|
|
if err := m.pushNotificationClient.HandlePushNotificationRegistrationResponse(publicKey, msg.ParsedMessage.Interface().(protobuf.PushNotificationRegistrationResponse)); err != nil {
|
|
allMessagesProcessed = false
|
|
logger.Warn("failed to handle PushNotificationRegistrationResponse", zap.Error(err))
|
|
}
|
|
// We continue in any case, no changes to messenger
|
|
continue
|
|
case protobuf.ContactCodeAdvertisement:
|
|
logger.Debug("Received ContactCodeAdvertisement")
|
|
|
|
cca := msg.ParsedMessage.Interface().(protobuf.ContactCodeAdvertisement)
|
|
logger.Debug("protobuf.ContactCodeAdvertisement received", zap.Any("cca", cca))
|
|
if cca.ChatIdentity != nil {
|
|
|
|
logger.Debug("Received ContactCodeAdvertisement ChatIdentity")
|
|
err = m.HandleChatIdentity(messageState, *cca.ChatIdentity)
|
|
if err != nil {
|
|
allMessagesProcessed = false
|
|
logger.Warn("failed to handle ContactCodeAdvertisement ChatIdentity", zap.Error(err))
|
|
// No continue as Chat Identity may fail but the rest of the cca may process fine.
|
|
}
|
|
}
|
|
|
|
if m.pushNotificationClient == nil {
|
|
continue
|
|
}
|
|
logger.Debug("Handling ContactCodeAdvertisement")
|
|
if err := m.pushNotificationClient.HandleContactCodeAdvertisement(publicKey, cca); err != nil {
|
|
allMessagesProcessed = false
|
|
logger.Warn("failed to handle ContactCodeAdvertisement", zap.Error(err))
|
|
}
|
|
|
|
// We continue in any case, no changes to messenger
|
|
continue
|
|
|
|
case protobuf.PushNotificationResponse:
|
|
logger.Debug("Received PushNotificationResponse")
|
|
if m.pushNotificationClient == nil {
|
|
continue
|
|
}
|
|
logger.Debug("Handling PushNotificationResponse")
|
|
if err := m.pushNotificationClient.HandlePushNotificationResponse(publicKey, msg.ParsedMessage.Interface().(protobuf.PushNotificationResponse)); err != nil {
|
|
allMessagesProcessed = false
|
|
logger.Warn("failed to handle PushNotificationResponse", zap.Error(err))
|
|
}
|
|
// We continue in any case, no changes to messenger
|
|
continue
|
|
|
|
case protobuf.PushNotificationQueryResponse:
|
|
logger.Debug("Received PushNotificationQueryResponse")
|
|
if m.pushNotificationClient == nil {
|
|
continue
|
|
}
|
|
logger.Debug("Handling PushNotificationQueryResponse")
|
|
if err := m.pushNotificationClient.HandlePushNotificationQueryResponse(publicKey, msg.ParsedMessage.Interface().(protobuf.PushNotificationQueryResponse)); err != nil {
|
|
allMessagesProcessed = false
|
|
logger.Warn("failed to handle PushNotificationQueryResponse", zap.Error(err))
|
|
}
|
|
// We continue in any case, no changes to messenger
|
|
continue
|
|
|
|
case protobuf.PushNotificationRequest:
|
|
logger.Debug("Received PushNotificationRequest")
|
|
if m.pushNotificationServer == nil {
|
|
continue
|
|
}
|
|
logger.Debug("Handling PushNotificationRequest")
|
|
if err := m.pushNotificationServer.HandlePushNotificationRequest(publicKey, msg.ID, msg.ParsedMessage.Interface().(protobuf.PushNotificationRequest)); err != nil {
|
|
allMessagesProcessed = false
|
|
logger.Warn("failed to handle PushNotificationRequest", zap.Error(err))
|
|
}
|
|
// We continue in any case, no changes to messenger
|
|
continue
|
|
case protobuf.EmojiReaction:
|
|
logger.Debug("Handling EmojiReaction")
|
|
err = m.HandleEmojiReaction(messageState, msg.ParsedMessage.Interface().(protobuf.EmojiReaction))
|
|
if err != nil {
|
|
logger.Warn("failed to handle EmojiReaction", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
case protobuf.GroupChatInvitation:
|
|
logger.Debug("Handling GroupChatInvitation")
|
|
err = m.HandleGroupChatInvitation(messageState, msg.ParsedMessage.Interface().(protobuf.GroupChatInvitation))
|
|
if err != nil {
|
|
logger.Warn("failed to handle GroupChatInvitation", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
case protobuf.ChatIdentity:
|
|
err = m.HandleChatIdentity(messageState, msg.ParsedMessage.Interface().(protobuf.ChatIdentity))
|
|
if err != nil {
|
|
logger.Warn("failed to handle ChatIdentity", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
case protobuf.CommunityDescription:
|
|
logger.Debug("Handling CommunityDescription")
|
|
err = m.handleCommunityDescription(messageState, publicKey, msg.ParsedMessage.Interface().(protobuf.CommunityDescription), msg.DecryptedPayload)
|
|
if err != nil {
|
|
logger.Warn("failed to handle CommunityDescription", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
|
|
//if community was among requested ones, send its info and remove filter
|
|
for communityID := range m.requestedCommunities {
|
|
if _, ok := messageState.Response.communities[communityID]; ok {
|
|
m.passStoredCommunityInfoToSignalHandler(communityID)
|
|
}
|
|
}
|
|
|
|
case protobuf.CommunityInvitation:
|
|
logger.Debug("Handling CommunityInvitation")
|
|
invitation := msg.ParsedMessage.Interface().(protobuf.CommunityInvitation)
|
|
err = m.HandleCommunityInvitation(messageState, publicKey, invitation, invitation.CommunityDescription)
|
|
if err != nil {
|
|
logger.Warn("failed to handle CommunityInvitation", zap.Error(err))
|
|
allMessagesProcessed = false
|
|
continue
|
|
}
|
|
case protobuf.CommunityRequestToJoin:
|
|
logger.Debug("Handling CommunityRequestToJoin")
|
|
request := msg.ParsedMessage.Interface().(protobuf.CommunityRequestToJoin)
|
|
err = m.HandleCommunityRequestToJoin(messageState, publicKey, request)
|
|
if err != nil {
|
|
logger.Warn("failed to handle CommunityRequestToJoin", zap.Error(err))
|
|
continue
|
|
}
|
|
|
|
case protobuf.AnonymousMetricBatch:
|
|
logger.Debug("Handling AnonymousMetricBatch")
|
|
if m.anonMetricsServer == nil {
|
|
logger.Warn("unable to handle AnonymousMetricBatch, anonMetricsServer is nil")
|
|
continue
|
|
}
|
|
|
|
ams, err := m.anonMetricsServer.StoreMetrics(msg.ParsedMessage.Interface().(protobuf.AnonymousMetricBatch))
|
|
if err != nil {
|
|
logger.Warn("failed to store AnonymousMetricBatch", zap.Error(err))
|
|
continue
|
|
}
|
|
messageState.Response.AnonymousMetrics = append(messageState.Response.AnonymousMetrics, ams...)
|
|
|
|
default:
|
|
// Check if is an encrypted PushNotificationRegistration
|
|
if msg.Type == protobuf.ApplicationMetadataMessage_PUSH_NOTIFICATION_REGISTRATION {
|
|
logger.Debug("Received PushNotificationRegistration")
|
|
if m.pushNotificationServer == nil {
|
|
continue
|
|
}
|
|
logger.Debug("Handling PushNotificationRegistration")
|
|
if err := m.pushNotificationServer.HandlePushNotificationRegistration(publicKey, msg.ParsedMessage.Interface().([]byte)); err != nil {
|
|
allMessagesProcessed = false
|
|
logger.Warn("failed to handle PushNotificationRegistration", zap.Error(err))
|
|
}
|
|
// We continue in any case, no changes to messenger
|
|
continue
|
|
}
|
|
|
|
logger.Debug("message not handled", zap.Any("messageType", reflect.TypeOf(msg.ParsedMessage.Interface())))
|
|
|
|
}
|
|
} else {
|
|
logger.Debug("parsed message is nil")
|
|
}
|
|
}
|
|
|
|
// Process any community changes
|
|
for _, changes := range messageState.Response.CommunityChanges {
|
|
if changes.ShouldMemberJoin {
|
|
response, err := m.joinCommunity(context.TODO(), changes.Community.ID())
|
|
if err != nil {
|
|
logger.Error("cannot join community", zap.Error(err))
|
|
continue
|
|
}
|
|
|
|
if err := messageState.Response.Merge(response); err != nil {
|
|
logger.Error("cannot merge join community response", zap.Error(err))
|
|
continue
|
|
}
|
|
|
|
} else if changes.ShouldMemberLeave {
|
|
response, err := m.leaveCommunity(changes.Community.ID())
|
|
if err != nil {
|
|
logger.Error("cannot join community", zap.Error(err))
|
|
continue
|
|
}
|
|
|
|
if err := messageState.Response.Merge(response); err != nil {
|
|
logger.Error("cannot merge join community response", zap.Error(err))
|
|
continue
|
|
|
|
}
|
|
|
|
}
|
|
}
|
|
|
|
// Clean up as not used by clients currently
|
|
messageState.Response.CommunityChanges = nil
|
|
|
|
// NOTE: for now we confirm messages as processed regardless whether we
|
|
// actually processed them, this is because we need to differentiate
|
|
// from messages that we want to retry to process and messages that
|
|
// are never going to be processed
|
|
m.transport.MarkP2PMessageAsProcessed(gethcommon.BytesToHash(shhMessage.Hash))
|
|
|
|
if allMessagesProcessed {
|
|
processedMessages = append(processedMessages, types.EncodeHex(shhMessage.Hash))
|
|
}
|
|
}
|
|
|
|
if len(processedMessages) != 0 {
|
|
if err := m.transport.ConfirmMessagesProcessed(processedMessages, m.getTimesource().GetCurrentTime()); err != nil {
|
|
logger.Warn("failed to confirm processed messages", zap.Error(err))
|
|
}
|
|
}
|
|
}
|
|
|
|
var contactsToSave []*Contact
|
|
messageState.ModifiedContacts.Range(func(id string, value bool) (shouldContinue bool) {
|
|
contact, ok := messageState.AllContacts.Load(id)
|
|
if ok {
|
|
contactsToSave = append(contactsToSave, contact)
|
|
messageState.Response.Contacts = append(messageState.Response.Contacts, contact)
|
|
}
|
|
return true
|
|
})
|
|
|
|
// Hydrate chat alias and identicon
|
|
for id := range messageState.Response.chats {
|
|
chat, _ := messageState.AllChats.Load(id)
|
|
if chat == nil {
|
|
continue
|
|
}
|
|
if chat.OneToOne() {
|
|
contact, ok := m.allContacts.Load(chat.ID)
|
|
if ok {
|
|
chat.Alias = contact.Alias
|
|
chat.Identicon = contact.Identicon
|
|
}
|
|
}
|
|
|
|
messageState.Response.AddChat(chat)
|
|
}
|
|
|
|
var err error
|
|
messageState.ModifiedInstallations.Range(func(id string, value bool) (shouldContinue bool) {
|
|
installation, _ := messageState.AllInstallations.Load(id)
|
|
messageState.Response.Installations = append(messageState.Response.Installations, installation)
|
|
if installation.InstallationMetadata != nil {
|
|
err = m.setInstallationMetadata(id, installation.InstallationMetadata)
|
|
if err != nil {
|
|
return false
|
|
}
|
|
}
|
|
|
|
return true
|
|
})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if len(messageState.Response.chats) > 0 {
|
|
err = m.saveChats(messageState.Response.Chats())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
if len(messageState.Response.pinMessages) > 0 {
|
|
err = m.SavePinMessages(messageState.Response.PinMessages())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
messagesToSave := messageState.Response.Messages()
|
|
if len(messageState.Response.messages) > 0 {
|
|
err = m.SaveMessages(messagesToSave)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
for _, emojiReaction := range messageState.EmojiReactions {
|
|
messageState.Response.EmojiReactions = append(messageState.Response.EmojiReactions, emojiReaction)
|
|
}
|
|
|
|
for _, groupChatInvitation := range messageState.GroupChatInvitations {
|
|
messageState.Response.Invitations = append(messageState.Response.Invitations, groupChatInvitation)
|
|
}
|
|
|
|
if len(contactsToSave) > 0 {
|
|
err = m.persistence.SaveContacts(contactsToSave)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
newMessagesIds := map[string]struct{}{}
|
|
for _, message := range messagesToSave {
|
|
if message.New {
|
|
newMessagesIds[message.ID] = struct{}{}
|
|
}
|
|
}
|
|
|
|
messagesWithResponses, err := m.pullMessagesAndResponsesFromDB(messagesToSave)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
messagesByID := map[string]*common.Message{}
|
|
for _, message := range messagesWithResponses {
|
|
messagesByID[message.ID] = message
|
|
}
|
|
messageState.Response.SetMessages(messagesWithResponses)
|
|
|
|
notificationsEnabled, err := m.settings.GetNotificationsEnabled()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
profilePicturesVisibility, err := m.settings.GetProfilePicturesVisibility()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
m.prepareMessages(messageState.Response.messages)
|
|
|
|
for _, message := range messageState.Response.messages {
|
|
if _, ok := newMessagesIds[message.ID]; ok {
|
|
message.New = true
|
|
|
|
if notificationsEnabled {
|
|
// Create notification body to be eventually passed to `localnotifications.SendMessageNotifications()`
|
|
if err = messageState.addNewMessageNotification(m.identity.PublicKey, message, messagesByID[message.ResponseTo], profilePicturesVisibility); err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
// Create activity center notification body to be eventually passed to `activitycenter.SendActivityCenterNotifications()`
|
|
if err = messageState.addNewActivityCenterNotification(m.identity.PublicKey, m, message, messagesByID[message.ResponseTo]); err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
}
|
|
|
|
// Reset installations
|
|
m.modifiedInstallations = new(stringBoolMap)
|
|
|
|
return messageState.Response, nil
|
|
}
|
|
|
|
// SetMailserver sets the currently used mailserver
|
|
func (m *Messenger) SetMailserver(peer []byte) {
|
|
m.mailserver = peer
|
|
}
|
|
|
|
func (m *Messenger) RequestHistoricMessages(
|
|
ctx context.Context,
|
|
from, to uint32,
|
|
cursor []byte,
|
|
storeCursor *types.StoreRequestCursor,
|
|
waitForResponse bool,
|
|
) ([]byte, *types.StoreRequestCursor, error) {
|
|
if m.mailserver == nil {
|
|
return nil, nil, errors.New("no mailserver selected")
|
|
}
|
|
return m.transport.SendMessagesRequest(ctx, m.mailserver, from, to, cursor, storeCursor, waitForResponse)
|
|
}
|
|
|
|
func (m *Messenger) MessageByID(id string) (*common.Message, error) {
|
|
return m.persistence.MessageByID(id)
|
|
}
|
|
|
|
func (m *Messenger) MessagesExist(ids []string) (map[string]bool, error) {
|
|
return m.persistence.MessagesExist(ids)
|
|
}
|
|
|
|
func (m *Messenger) MessageByChatID(chatID, cursor string, limit int) ([]*common.Message, string, error) {
|
|
chat, err := m.persistence.Chat(chatID)
|
|
if err != nil {
|
|
return nil, "", err
|
|
}
|
|
|
|
if chat == nil {
|
|
return nil, "", ErrChatNotFound
|
|
}
|
|
|
|
var msgs []*common.Message
|
|
var nextCursor string
|
|
|
|
if chat.Timeline() {
|
|
var chatIDs = []string{"@" + contactIDFromPublicKey(&m.identity.PublicKey)}
|
|
m.allContacts.Range(func(contactID string, contact *Contact) (shouldContinue bool) {
|
|
if contact.Added {
|
|
chatIDs = append(chatIDs, "@"+contact.ID)
|
|
}
|
|
return true
|
|
})
|
|
msgs, nextCursor, err = m.persistence.MessageByChatIDs(chatIDs, cursor, limit)
|
|
if err != nil {
|
|
return nil, "", err
|
|
}
|
|
} else {
|
|
msgs, nextCursor, err = m.persistence.MessageByChatID(chatID, cursor, limit)
|
|
if err != nil {
|
|
return nil, "", err
|
|
}
|
|
|
|
}
|
|
for idx := range msgs {
|
|
msgs[idx].PrepareImageURL(m.imageServer.Port)
|
|
}
|
|
|
|
return msgs, nextCursor, nil
|
|
}
|
|
|
|
func (m *Messenger) prepareMessages(messages map[string]*common.Message) {
|
|
for idx := range messages {
|
|
messages[idx].PrepareImageURL(m.imageServer.Port)
|
|
}
|
|
|
|
}
|
|
|
|
func (m *Messenger) AllMessageByChatIDWhichMatchTerm(chatID string, searchTerm string, caseSensitive bool) ([]*common.Message, error) {
|
|
_, err := m.persistence.Chat(chatID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return m.persistence.AllMessageByChatIDWhichMatchTerm(chatID, searchTerm, caseSensitive)
|
|
}
|
|
|
|
func (m *Messenger) AllMessagesFromChatsAndCommunitiesWhichMatchTerm(communityIds []string, chatIds []string, searchTerm string, caseSensitive bool) ([]*common.Message, error) {
|
|
return m.persistence.AllMessagesFromChatsAndCommunitiesWhichMatchTerm(communityIds, chatIds, searchTerm, caseSensitive)
|
|
}
|
|
|
|
func (m *Messenger) SaveMessages(messages []*common.Message) error {
|
|
return m.persistence.SaveMessages(messages)
|
|
}
|
|
|
|
func (m *Messenger) DeleteMessage(id string) error {
|
|
return m.persistence.DeleteMessage(id)
|
|
}
|
|
|
|
func (m *Messenger) DeleteMessagesByChatID(id string) error {
|
|
return m.persistence.DeleteMessagesByChatID(id)
|
|
}
|
|
|
|
// MarkMessagesSeen marks messages with `ids` as seen in the chat `chatID`.
|
|
// It returns the number of affected messages or error. If there is an error,
|
|
// the number of affected messages is always zero.
|
|
func (m *Messenger) MarkMessagesSeen(chatID string, ids []string) (uint64, uint64, error) {
|
|
count, countWithMentions, err := m.persistence.MarkMessagesSeen(chatID, ids)
|
|
if err != nil {
|
|
return 0, 0, err
|
|
}
|
|
chat, err := m.persistence.Chat(chatID)
|
|
if err != nil {
|
|
return 0, 0, err
|
|
}
|
|
m.allChats.Store(chatID, chat)
|
|
return count, countWithMentions, nil
|
|
}
|
|
|
|
func (m *Messenger) syncChatMessagesRead(ctx context.Context, chatID string, clock uint64) error {
|
|
if !m.hasPairedDevices() {
|
|
return nil
|
|
}
|
|
|
|
_, chat := m.getLastClockWithRelatedChat()
|
|
|
|
syncMessage := &protobuf.SyncChatMessagesRead{
|
|
Clock: clock,
|
|
Id: chatID,
|
|
}
|
|
encodedMessage, err := proto.Marshal(syncMessage)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_SYNC_CHAT_MESSAGES_READ,
|
|
ResendAutomatically: true,
|
|
})
|
|
|
|
return err
|
|
}
|
|
|
|
func (m *Messenger) markAllRead(chatID string, clock uint64, shouldBeSynced bool) error {
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return errors.New("chat not found")
|
|
}
|
|
|
|
seen, mentioned, err := m.persistence.MarkAllRead(chatID, clock)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
if shouldBeSynced {
|
|
err := m.syncChatMessagesRead(context.Background(), chatID, clock)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
}
|
|
|
|
chat.ReadMessagesAtClockValue = clock
|
|
chat.Highlight = false
|
|
|
|
if chat.UnviewedMessagesCount >= uint(seen) {
|
|
chat.UnviewedMessagesCount -= uint(seen)
|
|
} else {
|
|
chat.UnviewedMessagesCount = 0
|
|
}
|
|
|
|
if chat.UnviewedMentionsCount >= uint(mentioned) {
|
|
chat.UnviewedMentionsCount -= uint(mentioned)
|
|
} else {
|
|
chat.UnviewedMentionsCount = 0
|
|
}
|
|
|
|
// TODO(samyoul) remove storing of an updated reference pointer?
|
|
m.allChats.Store(chat.ID, chat)
|
|
return m.persistence.SaveChats([]*Chat{chat})
|
|
}
|
|
|
|
func (m *Messenger) MarkAllRead(chatID string) error {
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return errors.New("chat not found")
|
|
}
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
|
|
return m.markAllRead(chatID, clock, true)
|
|
}
|
|
|
|
func (m *Messenger) MarkAllReadInCommunity(communityID string) ([]string, error) {
|
|
chatIDs, err := m.persistence.AllChatIDsByCommunity(communityID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = m.persistence.MarkAllReadMultiple(chatIDs)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
for _, chatID := range chatIDs {
|
|
chat, ok := m.allChats.Load(chatID)
|
|
|
|
if ok {
|
|
chat.UnviewedMessagesCount = 0
|
|
chat.UnviewedMentionsCount = 0
|
|
m.allChats.Store(chat.ID, chat)
|
|
} else {
|
|
err = errors.New(fmt.Sprintf("chat with chatID %s not found", chatID))
|
|
}
|
|
}
|
|
|
|
return chatIDs, err
|
|
}
|
|
|
|
// MuteChat signals to the messenger that we don't want to be notified
|
|
// on new messages from this chat
|
|
func (m *Messenger) MuteChat(chatID string) error {
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
// Only one to one chan be muted when it's not in the database
|
|
publicKey, err := common.HexToPubkey(chatID)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
// Create a one to one chat and set active to false
|
|
chat = CreateOneToOneChat(chatID, publicKey, m.getTimesource())
|
|
chat.Active = false
|
|
err = m.initChatSyncFields(chat)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
err = m.saveChat(chat)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
}
|
|
|
|
var contact *Contact
|
|
if chat.OneToOne() {
|
|
contact, _ = m.allContacts.Load(chatID)
|
|
}
|
|
|
|
return m.muteChat(chat, contact)
|
|
}
|
|
|
|
func (m *Messenger) muteChat(chat *Chat, contact *Contact) error {
|
|
err := m.persistence.MuteChat(chat.ID)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
chat.Muted = true
|
|
// TODO(samyoul) remove storing of an updated reference pointer?
|
|
m.allChats.Store(chat.ID, chat)
|
|
|
|
if contact != nil {
|
|
err := m.syncContact(context.Background(), contact)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
}
|
|
|
|
return m.reregisterForPushNotifications()
|
|
}
|
|
|
|
// UnmuteChat signals to the messenger that we want to be notified
|
|
// on new messages from this chat
|
|
func (m *Messenger) UnmuteChat(chatID string) error {
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return errors.New("chat not found")
|
|
}
|
|
|
|
var contact *Contact
|
|
if chat.OneToOne() {
|
|
contact, _ = m.allContacts.Load(chatID)
|
|
}
|
|
|
|
return m.unmuteChat(chat, contact)
|
|
}
|
|
|
|
func (m *Messenger) unmuteChat(chat *Chat, contact *Contact) error {
|
|
err := m.persistence.UnmuteChat(chat.ID)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
chat.Muted = false
|
|
// TODO(samyoul) remove storing of an updated reference pointer?
|
|
m.allChats.Store(chat.ID, chat)
|
|
|
|
if contact != nil {
|
|
err := m.syncContact(context.Background(), contact)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
}
|
|
return m.reregisterForPushNotifications()
|
|
}
|
|
|
|
func (m *Messenger) UpdateMessageOutgoingStatus(id, newOutgoingStatus string) error {
|
|
return m.persistence.UpdateMessageOutgoingStatus(id, newOutgoingStatus)
|
|
}
|
|
|
|
// Identicon returns an identicon based on the input string
|
|
func Identicon(id string) (string, error) {
|
|
return identicon.GenerateBase64(id)
|
|
}
|
|
|
|
// GenerateAlias name returns the generated name given a public key hex encoded prefixed with 0x
|
|
func GenerateAlias(id string) (string, error) {
|
|
return alias.GenerateFromPublicKeyString(id)
|
|
}
|
|
|
|
func (m *Messenger) RequestTransaction(ctx context.Context, chatID, value, contract, address string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
|
|
// A valid added chat is required.
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, errors.New("Chat not found")
|
|
}
|
|
if chat.ChatType != ChatTypeOneToOne {
|
|
return nil, errors.New("Need to be a one-to-one chat")
|
|
}
|
|
|
|
message := &common.Message{}
|
|
err := extendMessageFromChat(message, chat, &m.identity.PublicKey, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
message.MessageType = protobuf.MessageType_ONE_TO_ONE
|
|
message.ContentType = protobuf.ChatMessage_TRANSACTION_COMMAND
|
|
message.Seen = true
|
|
message.Text = "Request transaction"
|
|
|
|
request := &protobuf.RequestTransaction{
|
|
Clock: message.Clock,
|
|
Address: address,
|
|
Value: value,
|
|
Contract: contract,
|
|
ChatId: chatID,
|
|
}
|
|
encodedMessage, err := proto.Marshal(request)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
rawMessage, err := m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_REQUEST_TRANSACTION,
|
|
ResendAutomatically: true,
|
|
})
|
|
|
|
message.CommandParameters = &common.CommandParameters{
|
|
ID: rawMessage.ID,
|
|
Value: value,
|
|
Address: address,
|
|
Contract: contract,
|
|
CommandState: common.CommandStateRequestTransaction,
|
|
}
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
messageID := rawMessage.ID
|
|
|
|
message.ID = messageID
|
|
message.CommandParameters.ID = messageID
|
|
err = message.PrepareContent(common.PubkeyToHex(&m.identity.PublicKey))
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = chat.UpdateFromMessage(message, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = m.persistence.SaveMessages([]*common.Message{message})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return m.addMessagesAndChat(chat, []*common.Message{message}, &response)
|
|
}
|
|
|
|
func (m *Messenger) RequestAddressForTransaction(ctx context.Context, chatID, from, value, contract string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
|
|
// A valid added chat is required.
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, errors.New("Chat not found")
|
|
}
|
|
if chat.ChatType != ChatTypeOneToOne {
|
|
return nil, errors.New("Need to be a one-to-one chat")
|
|
}
|
|
|
|
message := &common.Message{}
|
|
err := extendMessageFromChat(message, chat, &m.identity.PublicKey, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
message.MessageType = protobuf.MessageType_ONE_TO_ONE
|
|
message.ContentType = protobuf.ChatMessage_TRANSACTION_COMMAND
|
|
message.Seen = true
|
|
message.Text = "Request address for transaction"
|
|
|
|
request := &protobuf.RequestAddressForTransaction{
|
|
Clock: message.Clock,
|
|
Value: value,
|
|
Contract: contract,
|
|
ChatId: chatID,
|
|
}
|
|
encodedMessage, err := proto.Marshal(request)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
rawMessage, err := m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_REQUEST_ADDRESS_FOR_TRANSACTION,
|
|
ResendAutomatically: true,
|
|
})
|
|
|
|
message.CommandParameters = &common.CommandParameters{
|
|
ID: rawMessage.ID,
|
|
From: from,
|
|
Value: value,
|
|
Contract: contract,
|
|
CommandState: common.CommandStateRequestAddressForTransaction,
|
|
}
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
messageID := rawMessage.ID
|
|
|
|
message.ID = messageID
|
|
message.CommandParameters.ID = messageID
|
|
err = message.PrepareContent(common.PubkeyToHex(&m.identity.PublicKey))
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = chat.UpdateFromMessage(message, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = m.persistence.SaveMessages([]*common.Message{message})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return m.addMessagesAndChat(chat, []*common.Message{message}, &response)
|
|
}
|
|
|
|
func (m *Messenger) AcceptRequestAddressForTransaction(ctx context.Context, messageID, address string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
|
|
message, err := m.MessageByID(messageID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if message == nil {
|
|
return nil, errors.New("message not found")
|
|
}
|
|
|
|
chatID := message.LocalChatID
|
|
|
|
// A valid added chat is required.
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, errors.New("Chat not found")
|
|
}
|
|
if chat.ChatType != ChatTypeOneToOne {
|
|
return nil, errors.New("Need to be a one-to-one chat")
|
|
}
|
|
|
|
clock, timestamp := chat.NextClockAndTimestamp(m.transport)
|
|
message.Clock = clock
|
|
message.WhisperTimestamp = timestamp
|
|
message.Timestamp = timestamp
|
|
message.Text = "Request address for transaction accepted"
|
|
message.Seen = true
|
|
message.OutgoingStatus = common.OutgoingStatusSending
|
|
|
|
// Hide previous message
|
|
previousMessage, err := m.persistence.MessageByCommandID(chatID, messageID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if previousMessage == nil {
|
|
return nil, errors.New("No previous message found")
|
|
}
|
|
|
|
err = m.persistence.HideMessage(previousMessage.ID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
message.Replace = previousMessage.ID
|
|
|
|
request := &protobuf.AcceptRequestAddressForTransaction{
|
|
Clock: message.Clock,
|
|
Id: messageID,
|
|
Address: address,
|
|
ChatId: chatID,
|
|
}
|
|
encodedMessage, err := proto.Marshal(request)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
rawMessage, err := m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_ACCEPT_REQUEST_ADDRESS_FOR_TRANSACTION,
|
|
ResendAutomatically: true,
|
|
})
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
message.ID = rawMessage.ID
|
|
message.CommandParameters.Address = address
|
|
message.CommandParameters.CommandState = common.CommandStateRequestAddressForTransactionAccepted
|
|
|
|
err = message.PrepareContent(common.PubkeyToHex(&m.identity.PublicKey))
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = chat.UpdateFromMessage(message, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = m.persistence.SaveMessages([]*common.Message{message})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return m.addMessagesAndChat(chat, []*common.Message{message}, &response)
|
|
}
|
|
|
|
func (m *Messenger) DeclineRequestTransaction(ctx context.Context, messageID string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
|
|
message, err := m.MessageByID(messageID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if message == nil {
|
|
return nil, errors.New("message not found")
|
|
}
|
|
|
|
chatID := message.LocalChatID
|
|
|
|
// A valid added chat is required.
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, errors.New("Chat not found")
|
|
}
|
|
if chat.ChatType != ChatTypeOneToOne {
|
|
return nil, errors.New("Need to be a one-to-one chat")
|
|
}
|
|
|
|
clock, timestamp := chat.NextClockAndTimestamp(m.transport)
|
|
message.Clock = clock
|
|
message.WhisperTimestamp = timestamp
|
|
message.Timestamp = timestamp
|
|
message.Text = "Transaction request declined"
|
|
message.Seen = true
|
|
message.OutgoingStatus = common.OutgoingStatusSending
|
|
message.Replace = messageID
|
|
|
|
err = m.persistence.HideMessage(messageID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
request := &protobuf.DeclineRequestTransaction{
|
|
Clock: message.Clock,
|
|
Id: messageID,
|
|
ChatId: chatID,
|
|
}
|
|
encodedMessage, err := proto.Marshal(request)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
rawMessage, err := m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_DECLINE_REQUEST_TRANSACTION,
|
|
ResendAutomatically: true,
|
|
})
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
message.ID = rawMessage.ID
|
|
message.CommandParameters.CommandState = common.CommandStateRequestTransactionDeclined
|
|
|
|
err = message.PrepareContent(common.PubkeyToHex(&m.identity.PublicKey))
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = chat.UpdateFromMessage(message, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = m.persistence.SaveMessages([]*common.Message{message})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return m.addMessagesAndChat(chat, []*common.Message{message}, &response)
|
|
}
|
|
|
|
func (m *Messenger) DeclineRequestAddressForTransaction(ctx context.Context, messageID string) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
|
|
message, err := m.MessageByID(messageID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if message == nil {
|
|
return nil, errors.New("message not found")
|
|
}
|
|
|
|
chatID := message.LocalChatID
|
|
|
|
// A valid added chat is required.
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, errors.New("Chat not found")
|
|
}
|
|
if chat.ChatType != ChatTypeOneToOne {
|
|
return nil, errors.New("Need to be a one-to-one chat")
|
|
}
|
|
|
|
clock, timestamp := chat.NextClockAndTimestamp(m.transport)
|
|
message.Clock = clock
|
|
message.WhisperTimestamp = timestamp
|
|
message.Timestamp = timestamp
|
|
message.Text = "Request address for transaction declined"
|
|
message.Seen = true
|
|
message.OutgoingStatus = common.OutgoingStatusSending
|
|
message.Replace = messageID
|
|
|
|
err = m.persistence.HideMessage(messageID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
request := &protobuf.DeclineRequestAddressForTransaction{
|
|
Clock: message.Clock,
|
|
Id: messageID,
|
|
ChatId: chatID,
|
|
}
|
|
encodedMessage, err := proto.Marshal(request)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
rawMessage, err := m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_DECLINE_REQUEST_ADDRESS_FOR_TRANSACTION,
|
|
ResendAutomatically: true,
|
|
})
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
message.ID = rawMessage.ID
|
|
message.CommandParameters.CommandState = common.CommandStateRequestAddressForTransactionDeclined
|
|
|
|
err = message.PrepareContent(common.PubkeyToHex(&m.identity.PublicKey))
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = chat.UpdateFromMessage(message, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = m.persistence.SaveMessages([]*common.Message{message})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return m.addMessagesAndChat(chat, []*common.Message{message}, &response)
|
|
}
|
|
|
|
func (m *Messenger) AcceptRequestTransaction(ctx context.Context, transactionHash, messageID string, signature []byte) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
|
|
message, err := m.MessageByID(messageID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if message == nil {
|
|
return nil, errors.New("message not found")
|
|
}
|
|
|
|
chatID := message.LocalChatID
|
|
|
|
// A valid added chat is required.
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, errors.New("Chat not found")
|
|
}
|
|
if chat.ChatType != ChatTypeOneToOne {
|
|
return nil, errors.New("Need to be a one-to-one chat")
|
|
}
|
|
|
|
clock, timestamp := chat.NextClockAndTimestamp(m.transport)
|
|
message.Clock = clock
|
|
message.WhisperTimestamp = timestamp
|
|
message.Timestamp = timestamp
|
|
message.Seen = true
|
|
message.Text = transactionSentTxt
|
|
message.OutgoingStatus = common.OutgoingStatusSending
|
|
|
|
// Hide previous message
|
|
previousMessage, err := m.persistence.MessageByCommandID(chatID, messageID)
|
|
if err != nil && err != common.ErrRecordNotFound {
|
|
return nil, err
|
|
}
|
|
|
|
if previousMessage != nil {
|
|
err = m.persistence.HideMessage(previousMessage.ID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
message.Replace = previousMessage.ID
|
|
}
|
|
|
|
err = m.persistence.HideMessage(messageID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
request := &protobuf.SendTransaction{
|
|
Clock: message.Clock,
|
|
Id: messageID,
|
|
TransactionHash: transactionHash,
|
|
Signature: signature,
|
|
ChatId: chatID,
|
|
}
|
|
encodedMessage, err := proto.Marshal(request)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
rawMessage, err := m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_SEND_TRANSACTION,
|
|
ResendAutomatically: true,
|
|
})
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
message.ID = rawMessage.ID
|
|
message.CommandParameters.TransactionHash = transactionHash
|
|
message.CommandParameters.Signature = signature
|
|
message.CommandParameters.CommandState = common.CommandStateTransactionSent
|
|
|
|
err = message.PrepareContent(common.PubkeyToHex(&m.identity.PublicKey))
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = chat.UpdateFromMessage(message, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = m.persistence.SaveMessages([]*common.Message{message})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return m.addMessagesAndChat(chat, []*common.Message{message}, &response)
|
|
}
|
|
|
|
func (m *Messenger) SendTransaction(ctx context.Context, chatID, value, contract, transactionHash string, signature []byte) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
|
|
// A valid added chat is required.
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, errors.New("Chat not found")
|
|
}
|
|
if chat.ChatType != ChatTypeOneToOne {
|
|
return nil, errors.New("Need to be a one-to-one chat")
|
|
}
|
|
|
|
message := &common.Message{}
|
|
err := extendMessageFromChat(message, chat, &m.identity.PublicKey, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
message.MessageType = protobuf.MessageType_ONE_TO_ONE
|
|
message.ContentType = protobuf.ChatMessage_TRANSACTION_COMMAND
|
|
message.LocalChatID = chatID
|
|
|
|
clock, timestamp := chat.NextClockAndTimestamp(m.transport)
|
|
message.Clock = clock
|
|
message.WhisperTimestamp = timestamp
|
|
message.Seen = true
|
|
message.Timestamp = timestamp
|
|
message.Text = transactionSentTxt
|
|
|
|
request := &protobuf.SendTransaction{
|
|
Clock: message.Clock,
|
|
TransactionHash: transactionHash,
|
|
Signature: signature,
|
|
ChatId: chatID,
|
|
}
|
|
encodedMessage, err := proto.Marshal(request)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
rawMessage, err := m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chat.ID,
|
|
Payload: encodedMessage,
|
|
MessageType: protobuf.ApplicationMetadataMessage_SEND_TRANSACTION,
|
|
ResendAutomatically: true,
|
|
})
|
|
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
message.ID = rawMessage.ID
|
|
message.CommandParameters = &common.CommandParameters{
|
|
TransactionHash: transactionHash,
|
|
Value: value,
|
|
Contract: contract,
|
|
Signature: signature,
|
|
CommandState: common.CommandStateTransactionSent,
|
|
}
|
|
|
|
err = message.PrepareContent(common.PubkeyToHex(&m.identity.PublicKey))
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = chat.UpdateFromMessage(message, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = m.persistence.SaveMessages([]*common.Message{message})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return m.addMessagesAndChat(chat, []*common.Message{message}, &response)
|
|
}
|
|
|
|
func (m *Messenger) ValidateTransactions(ctx context.Context, addresses []types.Address) (*MessengerResponse, error) {
|
|
if m.verifyTransactionClient == nil {
|
|
return nil, nil
|
|
}
|
|
|
|
logger := m.logger.With(zap.String("site", "ValidateTransactions"))
|
|
logger.Debug("Validating transactions")
|
|
txs, err := m.persistence.TransactionsToValidate()
|
|
if err != nil {
|
|
logger.Error("Error pulling", zap.Error(err))
|
|
return nil, err
|
|
}
|
|
logger.Debug("Txs", zap.Int("count", len(txs)), zap.Any("txs", txs))
|
|
var response MessengerResponse
|
|
validator := NewTransactionValidator(addresses, m.persistence, m.verifyTransactionClient, m.logger)
|
|
responses, err := validator.ValidateTransactions(ctx)
|
|
if err != nil {
|
|
logger.Error("Error validating", zap.Error(err))
|
|
return nil, err
|
|
}
|
|
for _, validationResult := range responses {
|
|
var message *common.Message
|
|
chatID := contactIDFromPublicKey(validationResult.Transaction.From)
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
chat = OneToOneFromPublicKey(validationResult.Transaction.From, m.transport)
|
|
}
|
|
if validationResult.Message != nil {
|
|
message = validationResult.Message
|
|
} else {
|
|
message = &common.Message{}
|
|
err := extendMessageFromChat(message, chat, &m.identity.PublicKey, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
message.MessageType = protobuf.MessageType_ONE_TO_ONE
|
|
message.ContentType = protobuf.ChatMessage_TRANSACTION_COMMAND
|
|
message.LocalChatID = chatID
|
|
message.OutgoingStatus = ""
|
|
|
|
clock, timestamp := chat.NextClockAndTimestamp(m.transport)
|
|
message.Clock = clock
|
|
message.Timestamp = timestamp
|
|
message.WhisperTimestamp = timestamp
|
|
message.Text = "Transaction received"
|
|
message.Seen = false
|
|
|
|
message.ID = validationResult.Transaction.MessageID
|
|
if message.CommandParameters == nil {
|
|
message.CommandParameters = &common.CommandParameters{}
|
|
} else {
|
|
message.CommandParameters = validationResult.Message.CommandParameters
|
|
}
|
|
|
|
message.CommandParameters.Value = validationResult.Value
|
|
message.CommandParameters.Contract = validationResult.Contract
|
|
message.CommandParameters.Address = validationResult.Address
|
|
message.CommandParameters.CommandState = common.CommandStateTransactionSent
|
|
message.CommandParameters.TransactionHash = validationResult.Transaction.TransactionHash
|
|
|
|
err = message.PrepareContent(common.PubkeyToHex(&m.identity.PublicKey))
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
err = chat.UpdateFromMessage(message, m.transport)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if len(message.CommandParameters.ID) != 0 {
|
|
// Hide previous message
|
|
previousMessage, err := m.persistence.MessageByCommandID(chatID, message.CommandParameters.ID)
|
|
if err != nil && err != common.ErrRecordNotFound {
|
|
return nil, err
|
|
}
|
|
|
|
if previousMessage != nil {
|
|
err = m.persistence.HideMessage(previousMessage.ID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
message.Replace = previousMessage.ID
|
|
}
|
|
}
|
|
|
|
response.AddMessage(message)
|
|
m.allChats.Store(chat.ID, chat)
|
|
response.AddChat(chat)
|
|
|
|
contact, err := m.getOrBuildContactFromMessage(message)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
notificationsEnabled, err := m.settings.GetNotificationsEnabled()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
profilePicturesVisibility, err := m.settings.GetProfilePicturesVisibility()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if notificationsEnabled {
|
|
notification, err := NewMessageNotification(message.ID, message, chat, contact, m.allContacts, profilePicturesVisibility)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
response.AddNotification(notification)
|
|
}
|
|
|
|
}
|
|
|
|
if len(response.messages) > 0 {
|
|
err = m.SaveMessages(response.Messages())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
return &response, nil
|
|
}
|
|
|
|
// pullMessagesAndResponsesFromDB pulls all the messages and the one that have
|
|
// been replied to from the database
|
|
func (m *Messenger) pullMessagesAndResponsesFromDB(messages []*common.Message) ([]*common.Message, error) {
|
|
var messageIDs []string
|
|
for _, message := range messages {
|
|
messageIDs = append(messageIDs, message.ID)
|
|
if len(message.ResponseTo) != 0 {
|
|
messageIDs = append(messageIDs, message.ResponseTo)
|
|
}
|
|
|
|
}
|
|
// We pull from the database all the messages & replies involved,
|
|
// so we let the db build the correct messages
|
|
return m.persistence.MessagesByIDs(messageIDs)
|
|
}
|
|
|
|
func (m *Messenger) SignMessage(message string) ([]byte, error) {
|
|
hash := crypto.TextHash([]byte(message))
|
|
return crypto.Sign(hash, m.identity)
|
|
}
|
|
|
|
func (m *Messenger) getTimesource() common.TimeSource {
|
|
return m.transport
|
|
}
|
|
|
|
// AddPushNotificationsServer adds a push notification server
|
|
func (m *Messenger) AddPushNotificationsServer(ctx context.Context, publicKey *ecdsa.PublicKey, serverType pushnotificationclient.ServerType) error {
|
|
if m.pushNotificationClient == nil {
|
|
return errors.New("push notification client not enabled")
|
|
}
|
|
return m.pushNotificationClient.AddPushNotificationsServer(publicKey, serverType)
|
|
}
|
|
|
|
// RemovePushNotificationServer removes a push notification server
|
|
func (m *Messenger) RemovePushNotificationServer(ctx context.Context, publicKey *ecdsa.PublicKey) error {
|
|
if m.pushNotificationClient == nil {
|
|
return errors.New("push notification client not enabled")
|
|
}
|
|
return m.pushNotificationClient.RemovePushNotificationServer(publicKey)
|
|
}
|
|
|
|
// UnregisterFromPushNotifications unregister from any server
|
|
func (m *Messenger) UnregisterFromPushNotifications(ctx context.Context) error {
|
|
return m.pushNotificationClient.Unregister()
|
|
}
|
|
|
|
// DisableSendingPushNotifications signals the client not to send any push notification
|
|
func (m *Messenger) DisableSendingPushNotifications() error {
|
|
if m.pushNotificationClient == nil {
|
|
return errors.New("push notification client not enabled")
|
|
}
|
|
m.pushNotificationClient.DisableSending()
|
|
return nil
|
|
}
|
|
|
|
// EnableSendingPushNotifications signals the client to send push notifications
|
|
func (m *Messenger) EnableSendingPushNotifications() error {
|
|
if m.pushNotificationClient == nil {
|
|
return errors.New("push notification client not enabled")
|
|
}
|
|
m.pushNotificationClient.EnableSending()
|
|
return nil
|
|
}
|
|
|
|
func (m *Messenger) pushNotificationOptions() *pushnotificationclient.RegistrationOptions {
|
|
var contactIDs []*ecdsa.PublicKey
|
|
var mutedChatIDs []string
|
|
var publicChatIDs []string
|
|
|
|
m.allContacts.Range(func(contactID string, contact *Contact) (shouldContinue bool) {
|
|
if contact.Added && !contact.Blocked {
|
|
pk, err := contact.PublicKey()
|
|
if err != nil {
|
|
m.logger.Warn("could not parse contact public key")
|
|
return true
|
|
}
|
|
contactIDs = append(contactIDs, pk)
|
|
} else if contact.Blocked {
|
|
mutedChatIDs = append(mutedChatIDs, contact.ID)
|
|
}
|
|
return true
|
|
})
|
|
|
|
m.allChats.Range(func(chatID string, chat *Chat) (shouldContinue bool) {
|
|
if chat.Muted {
|
|
mutedChatIDs = append(mutedChatIDs, chat.ID)
|
|
}
|
|
if chat.Active && (chat.Public() || chat.CommunityChat()) {
|
|
publicChatIDs = append(publicChatIDs, chat.ID)
|
|
}
|
|
return true
|
|
})
|
|
|
|
return &pushnotificationclient.RegistrationOptions{
|
|
ContactIDs: contactIDs,
|
|
MutedChatIDs: mutedChatIDs,
|
|
PublicChatIDs: publicChatIDs,
|
|
}
|
|
}
|
|
|
|
// RegisterForPushNotification register deviceToken with any push notification server enabled
|
|
func (m *Messenger) RegisterForPushNotifications(ctx context.Context, deviceToken, apnTopic string, tokenType protobuf.PushNotificationRegistration_TokenType) error {
|
|
if m.pushNotificationClient == nil {
|
|
return errors.New("push notification client not enabled")
|
|
}
|
|
m.mutex.Lock()
|
|
defer m.mutex.Unlock()
|
|
|
|
err := m.pushNotificationClient.Register(deviceToken, apnTopic, tokenType, m.pushNotificationOptions())
|
|
if err != nil {
|
|
m.logger.Error("failed to register for push notifications", zap.Error(err))
|
|
return err
|
|
}
|
|
return nil
|
|
}
|
|
|
|
// RegisteredForPushNotifications returns whether we successfully registered with all the servers
|
|
func (m *Messenger) RegisteredForPushNotifications() (bool, error) {
|
|
if m.pushNotificationClient == nil {
|
|
return false, errors.New("no push notification client")
|
|
}
|
|
return m.pushNotificationClient.Registered()
|
|
}
|
|
|
|
// EnablePushNotificationsFromContactsOnly is used to indicate that we want to received push notifications only from contacts
|
|
func (m *Messenger) EnablePushNotificationsFromContactsOnly() error {
|
|
if m.pushNotificationClient == nil {
|
|
return errors.New("no push notification client")
|
|
}
|
|
m.mutex.Lock()
|
|
defer m.mutex.Unlock()
|
|
|
|
return m.pushNotificationClient.EnablePushNotificationsFromContactsOnly(m.pushNotificationOptions())
|
|
}
|
|
|
|
// DisablePushNotificationsFromContactsOnly is used to indicate that we want to received push notifications from anyone
|
|
func (m *Messenger) DisablePushNotificationsFromContactsOnly() error {
|
|
if m.pushNotificationClient == nil {
|
|
return errors.New("no push notification client")
|
|
}
|
|
m.mutex.Lock()
|
|
defer m.mutex.Unlock()
|
|
|
|
return m.pushNotificationClient.DisablePushNotificationsFromContactsOnly(m.pushNotificationOptions())
|
|
}
|
|
|
|
// EnablePushNotificationsBlockMentions is used to indicate that we dont want to received push notifications for mentions
|
|
func (m *Messenger) EnablePushNotificationsBlockMentions() error {
|
|
if m.pushNotificationClient == nil {
|
|
return errors.New("no push notification client")
|
|
}
|
|
m.mutex.Lock()
|
|
defer m.mutex.Unlock()
|
|
|
|
return m.pushNotificationClient.EnablePushNotificationsBlockMentions(m.pushNotificationOptions())
|
|
}
|
|
|
|
// DisablePushNotificationsBlockMentions is used to indicate that we want to received push notifications for mentions
|
|
func (m *Messenger) DisablePushNotificationsBlockMentions() error {
|
|
if m.pushNotificationClient == nil {
|
|
return errors.New("no push notification client")
|
|
}
|
|
m.mutex.Lock()
|
|
defer m.mutex.Unlock()
|
|
|
|
return m.pushNotificationClient.DisablePushNotificationsBlockMentions(m.pushNotificationOptions())
|
|
}
|
|
|
|
// GetPushNotificationsServers returns the servers used for push notifications
|
|
func (m *Messenger) GetPushNotificationsServers() ([]*pushnotificationclient.PushNotificationServer, error) {
|
|
if m.pushNotificationClient == nil {
|
|
return nil, errors.New("no push notification client")
|
|
}
|
|
return m.pushNotificationClient.GetServers()
|
|
}
|
|
|
|
// StartPushNotificationsServer initialize and start a push notification server, using the current messenger identity key
|
|
func (m *Messenger) StartPushNotificationsServer() error {
|
|
if m.pushNotificationServer == nil {
|
|
pushNotificationServerPersistence := pushnotificationserver.NewSQLitePersistence(m.database)
|
|
config := &pushnotificationserver.Config{
|
|
Enabled: true,
|
|
Logger: m.logger,
|
|
Identity: m.identity,
|
|
}
|
|
m.pushNotificationServer = pushnotificationserver.New(config, pushNotificationServerPersistence, m.sender)
|
|
}
|
|
|
|
return m.pushNotificationServer.Start()
|
|
}
|
|
|
|
// StopPushNotificationServer stops the push notification server if running
|
|
func (m *Messenger) StopPushNotificationsServer() error {
|
|
m.pushNotificationServer = nil
|
|
return nil
|
|
}
|
|
|
|
func generateAliasAndIdenticon(pk string) (string, string, error) {
|
|
identicon, err := identicon.GenerateBase64(pk)
|
|
if err != nil {
|
|
return "", "", err
|
|
}
|
|
|
|
name, err := alias.GenerateFromPublicKeyString(pk)
|
|
if err != nil {
|
|
return "", "", err
|
|
}
|
|
return name, identicon, nil
|
|
|
|
}
|
|
|
|
func (m *Messenger) SendEmojiReaction(ctx context.Context, chatID, messageID string, emojiID protobuf.EmojiReaction_Type) (*MessengerResponse, error) {
|
|
var response MessengerResponse
|
|
|
|
chat, ok := m.allChats.Load(chatID)
|
|
if !ok {
|
|
return nil, ErrChatNotFound
|
|
}
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
|
|
emojiR := &EmojiReaction{
|
|
EmojiReaction: protobuf.EmojiReaction{
|
|
Clock: clock,
|
|
MessageId: messageID,
|
|
ChatId: chatID,
|
|
Type: emojiID,
|
|
},
|
|
LocalChatID: chatID,
|
|
From: types.EncodeHex(crypto.FromECDSAPub(&m.identity.PublicKey)),
|
|
}
|
|
encodedMessage, err := m.encodeChatEntity(chat, emojiR)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: chatID,
|
|
Payload: encodedMessage,
|
|
SkipGroupMessageWrap: true,
|
|
MessageType: protobuf.ApplicationMetadataMessage_EMOJI_REACTION,
|
|
// Don't resend using datasync, that would create quite a lot
|
|
// of traffic if clicking too eagelry
|
|
ResendAutomatically: false,
|
|
})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
response.EmojiReactions = []*EmojiReaction{emojiR}
|
|
response.AddChat(chat)
|
|
|
|
err = m.persistence.SaveEmojiReaction(emojiR)
|
|
if err != nil {
|
|
return nil, errors.Wrap(err, "Can't save emoji reaction in db")
|
|
}
|
|
|
|
return &response, nil
|
|
}
|
|
|
|
func (m *Messenger) EmojiReactionsByChatID(chatID string, cursor string, limit int) ([]*EmojiReaction, error) {
|
|
chat, err := m.persistence.Chat(chatID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
if chat.Timeline() {
|
|
var chatIDs = []string{"@" + contactIDFromPublicKey(&m.identity.PublicKey)}
|
|
m.allContacts.Range(func(contactID string, contact *Contact) (shouldContinue bool) {
|
|
if contact.Added {
|
|
chatIDs = append(chatIDs, "@"+contact.ID)
|
|
}
|
|
return true
|
|
})
|
|
return m.persistence.EmojiReactionsByChatIDs(chatIDs, cursor, limit)
|
|
}
|
|
return m.persistence.EmojiReactionsByChatID(chatID, cursor, limit)
|
|
}
|
|
|
|
func (m *Messenger) EmojiReactionsByChatIDMessageID(chatID string, messageID string) ([]*EmojiReaction, error) {
|
|
_, err := m.persistence.Chat(chatID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return m.persistence.EmojiReactionsByChatIDMessageID(chatID, messageID)
|
|
}
|
|
|
|
func (m *Messenger) SendEmojiReactionRetraction(ctx context.Context, emojiReactionID string) (*MessengerResponse, error) {
|
|
emojiR, err := m.persistence.EmojiReactionByID(emojiReactionID)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
// Check that the sender is the key owner
|
|
pk := types.EncodeHex(crypto.FromECDSAPub(&m.identity.PublicKey))
|
|
if emojiR.From != pk {
|
|
return nil, errors.Errorf("identity mismatch, "+
|
|
"emoji reactions can only be retracted by the reaction sender, "+
|
|
"emoji reaction sent by '%s', current identity '%s'",
|
|
emojiR.From, pk,
|
|
)
|
|
}
|
|
|
|
// Get chat and clock
|
|
chat, ok := m.allChats.Load(emojiR.GetChatId())
|
|
if !ok {
|
|
return nil, ErrChatNotFound
|
|
}
|
|
clock, _ := chat.NextClockAndTimestamp(m.getTimesource())
|
|
|
|
// Update the relevant fields
|
|
emojiR.Clock = clock
|
|
emojiR.Retracted = true
|
|
|
|
encodedMessage, err := m.encodeChatEntity(chat, emojiR)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
// Send the marshalled EmojiReactionRetraction protobuf
|
|
_, err = m.dispatchMessage(ctx, common.RawMessage{
|
|
LocalChatID: emojiR.GetChatId(),
|
|
Payload: encodedMessage,
|
|
SkipGroupMessageWrap: true,
|
|
MessageType: protobuf.ApplicationMetadataMessage_EMOJI_REACTION,
|
|
// Don't resend using datasync, that would create quite a lot
|
|
// of traffic if clicking too eagelry
|
|
ResendAutomatically: false,
|
|
})
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
// Update MessengerResponse
|
|
response := MessengerResponse{}
|
|
emojiR.Retracted = true
|
|
response.EmojiReactions = []*EmojiReaction{emojiR}
|
|
response.AddChat(chat)
|
|
|
|
// Persist retraction state for emoji reaction
|
|
err = m.persistence.SaveEmojiReaction(emojiR)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
return &response, nil
|
|
}
|
|
|
|
func (m *Messenger) encodeChatEntity(chat *Chat, message common.ChatEntity) ([]byte, error) {
|
|
var encodedMessage []byte
|
|
var err error
|
|
l := m.logger.With(zap.String("site", "Send"), zap.String("chatID", chat.ID))
|
|
|
|
switch chat.ChatType {
|
|
case ChatTypeOneToOne:
|
|
l.Debug("sending private message")
|
|
message.SetMessageType(protobuf.MessageType_ONE_TO_ONE)
|
|
encodedMessage, err = proto.Marshal(message.GetProtobuf())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
case ChatTypePublic, ChatTypeProfile:
|
|
l.Debug("sending public message", zap.String("chatName", chat.Name))
|
|
message.SetMessageType(protobuf.MessageType_PUBLIC_GROUP)
|
|
encodedMessage, err = proto.Marshal(message.GetProtobuf())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
case ChatTypeCommunityChat:
|
|
l.Debug("sending community chat message", zap.String("chatName", chat.Name))
|
|
// TODO: add grant
|
|
message.SetMessageType(protobuf.MessageType_COMMUNITY_CHAT)
|
|
encodedMessage, err = proto.Marshal(message.GetProtobuf())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
case ChatTypePrivateGroupChat:
|
|
message.SetMessageType(protobuf.MessageType_PRIVATE_GROUP)
|
|
l.Debug("sending group message", zap.String("chatName", chat.Name))
|
|
if !message.WrapGroupMessage() {
|
|
encodedMessage, err = proto.Marshal(message.GetProtobuf())
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
} else {
|
|
|
|
group, err := newProtocolGroupFromChat(chat)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
encodedMessage, err = m.sender.EncodeAbridgedMembershipUpdate(group, message)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
}
|
|
|
|
default:
|
|
return nil, errors.New("chat type not supported")
|
|
}
|
|
|
|
return encodedMessage, nil
|
|
}
|
|
|
|
func (m *Messenger) getOrBuildContactFromMessage(msg *common.Message) (*Contact, error) {
|
|
if c, ok := m.allContacts.Load(msg.From); ok {
|
|
return c, nil
|
|
}
|
|
|
|
senderPubKey, err := msg.GetSenderPubKey()
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
senderID := contactIDFromPublicKey(senderPubKey)
|
|
c, err := buildContact(senderID, senderPubKey)
|
|
if err != nil {
|
|
return nil, err
|
|
}
|
|
|
|
// TODO(samyoul) remove storing of an updated reference pointer?
|
|
m.allContacts.Store(msg.From, c)
|
|
return c, nil
|
|
}
|
|
|
|
func (m *Messenger) BloomFilter() []byte {
|
|
return m.transport.BloomFilter()
|
|
}
|
|
|
|
func (m *Messenger) getSettings() (accounts.Settings, error) {
|
|
sDB := accounts.NewDB(m.database)
|
|
return sDB.GetSettings()
|
|
}
|