status-go/protocol/push_notification_client/client.go

698 lines
21 KiB
Go
Raw Normal View History

package push_notification_client
2020-06-30 07:50:59 +00:00
import (
2020-07-14 14:07:19 +00:00
"bytes"
"context"
2020-06-30 07:50:59 +00:00
"crypto/aes"
"crypto/cipher"
"crypto/ecdsa"
"crypto/rand"
2020-07-09 16:52:26 +00:00
"encoding/hex"
2020-07-14 14:07:19 +00:00
"encoding/json"
"errors"
2020-06-30 07:50:59 +00:00
"io"
2020-07-14 14:07:19 +00:00
"sort"
"time"
2020-06-30 07:50:59 +00:00
"github.com/golang/protobuf/proto"
2020-06-30 07:50:59 +00:00
"github.com/google/uuid"
"github.com/status-im/status-go/eth-node/crypto"
2020-06-30 07:50:59 +00:00
"github.com/status-im/status-go/eth-node/crypto/ecies"
2020-07-14 14:07:19 +00:00
"github.com/status-im/status-go/eth-node/types"
"github.com/status-im/status-go/protocol/common"
2020-06-30 07:50:59 +00:00
"github.com/status-im/status-go/protocol/protobuf"
"go.uber.org/zap"
2020-06-30 07:50:59 +00:00
)
const encryptedPayloadKeyLength = 16
2020-06-30 07:50:59 +00:00
const accessTokenKeyLength = 16
const staleQueryTimeInSeconds = 86400
2020-06-30 07:50:59 +00:00
type PushNotificationServer struct {
2020-07-14 14:07:19 +00:00
PublicKey *ecdsa.PublicKey `json:"-"`
Registered bool `json:"registered,omitempty"`
RegisteredAt int64 `json:"registeredAt,omitempty"`
AccessToken string `json:"accessToken,omitempty"`
}
func (s *PushNotificationServer) MarshalJSON() ([]byte, error) {
type ServerAlias PushNotificationServer
item := struct {
*ServerAlias
PublicKeyString string `json:"publicKey"`
}{
ServerAlias: (*ServerAlias)(s),
PublicKeyString: types.EncodeHex(crypto.FromECDSAPub(s.PublicKey)),
}
return json.Marshal(item)
}
type PushNotificationInfo struct {
AccessToken string
InstallationID string
PublicKey *ecdsa.PublicKey
ServerPublicKey *ecdsa.PublicKey
RetrievedAt int64
2020-06-30 07:50:59 +00:00
}
type Config struct {
2020-06-30 07:50:59 +00:00
// Identity is our identity key
Identity *ecdsa.PrivateKey
// SendEnabled indicates whether we should be sending push notifications
SendEnabled bool
// RemoteNotificationsEnabled is whether we should register with a remote server for push notifications
RemoteNotificationsEnabled bool
// AllowOnlyFromContacts indicates whether we should be receiving push notifications
// only from contacts
AllowOnlyFromContacts bool
// PushNotificationServers is an array of push notification servers we want to register with
PushNotificationServers []*PushNotificationServer
// InstallationID is the installation-id for this device
InstallationID string
Logger *zap.Logger
// TokenType is the type of token
TokenType protobuf.PushNotificationRegistration_TokenType
2020-06-30 07:50:59 +00:00
}
type Client struct {
persistence *Persistence
quit chan struct{}
config *Config
2020-06-30 07:50:59 +00:00
2020-07-01 08:37:54 +00:00
// lastPushNotificationVersion is the latest known push notification version
lastPushNotificationVersion uint64
2020-06-30 07:50:59 +00:00
// AccessToken is the access token that is currently being used
AccessToken string
// DeviceToken is the device token for this device
DeviceToken string
// randomReader only used for testing so we have deterministic encryption
reader io.Reader
//messageProcessor is a message processor used to send and being notified of messages
messageProcessor *common.MessageProcessor
}
func New(persistence *Persistence, config *Config, processor *common.MessageProcessor) *Client {
return &Client{
quit: make(chan struct{}),
config: config,
messageProcessor: processor,
persistence: persistence,
reader: rand.Reader}
}
func (c *Client) Start() error {
if c.messageProcessor == nil {
return errors.New("can't start, missing message processor")
}
go func() {
subscription := c.messageProcessor.Subscribe()
for {
select {
2020-07-14 14:07:19 +00:00
case m, more := <-subscription:
if !more {
c.config.Logger.Info("no more")
return
}
c.config.Logger.Info("handling message sent")
if err := c.HandleMessageSent(m); err != nil {
c.config.Logger.Error("failed to handle message", zap.Error(err))
}
case <-c.quit:
return
}
}
}()
return nil
2020-06-30 07:50:59 +00:00
}
func (c *Client) Stop() error {
close(c.quit)
return nil
2020-06-30 07:50:59 +00:00
}
// The message has been sent
// We should:
// 1) Check whether we should notify on anything
// 2) Refresh info if necessaary
// 3) Sent push notifications
2020-07-14 14:07:19 +00:00
// TODO: handle DH messages
func (c *Client) HandleMessageSent(sentMessage *common.SentMessage) error {
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("sent message", zap.Any("sent message", sentMessage))
if !c.config.SendEnabled {
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("send not enabled, ignoring")
return nil
}
publicKey := sentMessage.PublicKey
2020-07-14 14:07:19 +00:00
// Check we track this messages fist
var trackedMessageIDs [][]byte
for _, messageID := range sentMessage.MessageIDs {
tracked, err := c.persistence.TrackedMessage(messageID)
if err != nil {
return err
}
if tracked {
trackedMessageIDs = append(trackedMessageIDs, messageID)
}
}
// Nothing to do
if len(trackedMessageIDs) == 0 {
return nil
}
sendToAllDevices := len(sentMessage.Spec.Installations) == 0
var installationIDs []string
2020-07-14 14:07:19 +00:00
anyActionableMessage := sendToAllDevices
c.config.Logger.Info("send to all devices", zap.Bool("send to all", sendToAllDevices))
2020-07-14 14:07:19 +00:00
// Collect installationIDs
for _, messageID := range trackedMessageIDs {
for _, installation := range sentMessage.Spec.Installations {
installationID := installation.ID
shouldNotify, err := c.shouldNotifyOn(publicKey, installationID, messageID)
if err != nil {
return err
}
if shouldNotify {
2020-07-14 14:07:19 +00:00
anyActionableMessage = true
installationIDs = append(installationIDs, installation.ID)
}
}
}
// Is there anything we should be notifying on?
2020-07-14 14:07:19 +00:00
if !anyActionableMessage {
c.config.Logger.Info("no actionable installation IDs")
return nil
}
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("actionable messages", zap.Any("message-ids", trackedMessageIDs), zap.Any("installation-ids", installationIDs))
// Check if we queried recently
queriedAt, err := c.persistence.GetQueriedAt(publicKey)
if err != nil {
return err
}
// Naively query again if too much time has passed.
// Here it might not be necessary
if time.Now().Unix()-queriedAt > staleQueryTimeInSeconds {
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("querying info")
err := c.QueryPushNotificationInfo(publicKey)
if err != nil {
2020-07-14 14:07:19 +00:00
c.config.Logger.Error("could not query pn info", zap.Error(err))
return err
}
// This is just horrible, but for now will do,
// the issue is that we don't really know how long it will
// take to reply, as there might be multiple servers
// replying to us.
// The only time we are 100% certain that we can proceed is
// when we have non-stale info for each device, but
// most devices are not going to be registered, so we'd still
// have to wait teh maximum amount of time allowed.
time.Sleep(3 * time.Second)
}
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("queried info")
// Retrieve infos
info, err := c.GetPushNotificationInfo(publicKey, installationIDs)
if err != nil {
2020-07-14 14:07:19 +00:00
c.config.Logger.Error("could not get pn info", zap.Error(err))
return err
}
// Naively dispatch to the first server for now
// This wait for an acknowledgement and try a different server after a timeout
// Also we sent a single notification for multiple message ids, need to check with UI what's the desired behavior
// Sort by server so we tend to hit the same one
sort.Slice(info, func(i, j int) bool {
return info[i].ServerPublicKey.X.Cmp(info[j].ServerPublicKey.X) <= 0
})
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("retrieved info")
installationIDsMap := make(map[string]bool)
// One info per installation id, grouped by server
actionableInfos := make(map[string][]*PushNotificationInfo)
for _, i := range info {
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("queried info", zap.String("id", i.InstallationID))
if !installationIDsMap[i.InstallationID] {
serverKey := hex.EncodeToString(crypto.CompressPubkey(i.ServerPublicKey))
actionableInfos[serverKey] = append(actionableInfos[serverKey], i)
installationIDsMap[i.InstallationID] = true
}
}
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("actionable info", zap.Int("count", len(actionableInfos)))
for _, infos := range actionableInfos {
var pushNotifications []*protobuf.PushNotification
for _, i := range infos {
// TODO: Add ChatID, message, public_key
pushNotifications = append(pushNotifications, &protobuf.PushNotification{
AccessToken: i.AccessToken,
PublicKey: common.HashPublicKey(publicKey),
InstallationId: i.InstallationID,
})
}
request := &protobuf.PushNotificationRequest{
2020-07-14 14:07:19 +00:00
MessageId: trackedMessageIDs[0],
Requests: pushNotifications,
}
serverPublicKey := infos[0].ServerPublicKey
payload, err := proto.Marshal(request)
if err != nil {
return err
}
rawMessage := &common.RawMessage{
Payload: payload,
MessageType: protobuf.ApplicationMetadataMessage_PUSH_NOTIFICATION_REQUEST,
}
// TODO: We should use the messageID for the response
_, err = c.messageProcessor.SendPrivate(context.Background(), serverPublicKey, rawMessage)
if err != nil {
return err
}
2020-07-14 14:07:19 +00:00
// Mark message as sent, this is at-most-once semantic
// for all messageIDs
for _, i := range infos {
for _, messageID := range trackedMessageIDs {
c.config.Logger.Info("marking as sent ", zap.Binary("mid", messageID), zap.String("id", i.InstallationID))
if err := c.notifiedOn(publicKey, i.InstallationID, messageID); err != nil {
return err
}
}
}
}
2020-06-30 07:50:59 +00:00
return nil
}
// NotifyOnMessageID keeps track of the message to make sure we notify on it
func (c *Client) NotifyOnMessageID(chatID string, messageID []byte) error {
return c.persistence.TrackPushNotification(chatID, messageID)
}
func (c *Client) shouldNotifyOn(publicKey *ecdsa.PublicKey, installationID string, messageID []byte) (bool, error) {
2020-07-14 14:07:19 +00:00
if len(installationID) == 0 {
return c.persistence.ShouldSendNotificationToAllInstallationIDs(publicKey, messageID)
} else {
return c.persistence.ShouldSendNotificationFor(publicKey, installationID, messageID)
}
2020-06-30 07:50:59 +00:00
}
func (c *Client) notifiedOn(publicKey *ecdsa.PublicKey, installationID string, messageID []byte) error {
return c.persistence.NotifiedOn(publicKey, installationID, messageID)
}
func (p *Client) mutedChatIDsHashes(chatIDs []string) [][]byte {
2020-06-30 07:50:59 +00:00
var mutedChatListHashes [][]byte
for _, chatID := range chatIDs {
mutedChatListHashes = append(mutedChatListHashes, common.Shake256([]byte(chatID)))
2020-06-30 07:50:59 +00:00
}
return mutedChatListHashes
}
2020-07-01 08:37:54 +00:00
func (p *Client) encryptToken(publicKey *ecdsa.PublicKey, token []byte) ([]byte, error) {
2020-06-30 07:50:59 +00:00
sharedKey, err := ecies.ImportECDSA(p.config.Identity).GenerateShared(
ecies.ImportECDSAPublic(publicKey),
accessTokenKeyLength,
accessTokenKeyLength,
)
if err != nil {
return nil, err
}
encryptedToken, err := encryptAccessToken(token, sharedKey, p.reader)
if err != nil {
return nil, err
}
2020-07-01 08:37:54 +00:00
return encryptedToken, nil
2020-06-30 07:50:59 +00:00
}
func (p *Client) allowedUserList(token []byte, contactIDs []*ecdsa.PublicKey) ([][]byte, error) {
2020-07-01 08:37:54 +00:00
var encryptedTokens [][]byte
for _, publicKey := range contactIDs {
2020-07-01 08:37:54 +00:00
encryptedToken, err := p.encryptToken(publicKey, token)
2020-06-30 07:50:59 +00:00
if err != nil {
return nil, err
}
2020-07-01 08:37:54 +00:00
encryptedTokens = append(encryptedTokens, encryptedToken)
2020-06-30 07:50:59 +00:00
}
2020-07-01 08:37:54 +00:00
return encryptedTokens, nil
2020-06-30 07:50:59 +00:00
}
func (p *Client) buildPushNotificationRegistrationMessage(contactIDs []*ecdsa.PublicKey, mutedChatIDs []string) (*protobuf.PushNotificationRegistration, error) {
2020-07-01 08:37:54 +00:00
token := uuid.New().String()
allowedUserList, err := p.allowedUserList([]byte(token), contactIDs)
2020-06-30 07:50:59 +00:00
if err != nil {
return nil, err
}
options := &protobuf.PushNotificationRegistration{
2020-07-01 08:37:54 +00:00
AccessToken: token,
TokenType: p.config.TokenType,
2020-07-01 08:37:54 +00:00
Version: p.lastPushNotificationVersion + 1,
2020-06-30 07:50:59 +00:00
InstallationId: p.config.InstallationID,
Token: p.DeviceToken,
Enabled: p.config.RemoteNotificationsEnabled,
BlockedChatList: p.mutedChatIDsHashes(mutedChatIDs),
2020-06-30 07:50:59 +00:00
AllowedUserList: allowedUserList,
}
return options, nil
}
2020-07-10 07:45:40 +00:00
func (c *Client) Register(deviceToken string, contactIDs []*ecdsa.PublicKey, mutedChatIDs []string) ([]*PushNotificationServer, error) {
c.DeviceToken = deviceToken
servers, err := c.persistence.GetServers()
if err != nil {
2020-07-09 16:52:26 +00:00
return nil, err
}
if len(servers) == 0 {
2020-07-09 16:52:26 +00:00
return nil, errors.New("no servers to register with")
}
registration, err := c.buildPushNotificationRegistrationMessage(contactIDs, mutedChatIDs)
if err != nil {
2020-07-09 16:52:26 +00:00
return nil, err
}
2020-07-10 07:45:40 +00:00
var serverPublicKeys []*ecdsa.PublicKey
for _, server := range servers {
2020-07-10 07:45:40 +00:00
// Reset server registration data
server.Registered = false
server.RegisteredAt = 0
server.AccessToken = registration.AccessToken
serverPublicKeys = append(serverPublicKeys, server.PublicKey)
if err := c.persistence.UpsertServer(server); err != nil {
return nil, err
}
2020-07-13 08:53:13 +00:00
grant, err := c.buildGrantSignature(server.PublicKey, registration.AccessToken)
if err != nil {
c.config.Logger.Error("failed to build grant", zap.Error(err))
return nil, err
}
c.config.Logger.Info("GRANT2", zap.Binary("GRANT", grant))
registration.Grant = grant
marshaledRegistration, err := proto.Marshal(registration)
if err != nil {
return nil, err
}
2020-07-10 07:45:40 +00:00
// Dispatch message
encryptedRegistration, err := c.encryptRegistration(server.PublicKey, marshaledRegistration)
if err != nil {
2020-07-09 16:52:26 +00:00
return nil, err
}
rawMessage := &common.RawMessage{
Payload: encryptedRegistration,
MessageType: protobuf.ApplicationMetadataMessage_PUSH_NOTIFICATION_REGISTRATION,
}
2020-07-10 07:45:40 +00:00
_, err = c.messageProcessor.SendPrivate(context.Background(), server.PublicKey, rawMessage)
2020-07-10 07:45:40 +00:00
if err != nil {
return nil, err
}
}
2020-07-10 07:45:40 +00:00
ctx, cancel := context.WithTimeout(context.Background(), 5*time.Second)
// This code polls the database for server registrations, giving up
// after 5 seconds
for {
select {
case <-c.quit:
2020-07-10 07:45:40 +00:00
return servers, nil
case <-ctx.Done():
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("Context done")
2020-07-10 07:45:40 +00:00
return servers, nil
case <-time.After(200 * time.Millisecond):
servers, err = c.persistence.GetServersByPublicKey(serverPublicKeys)
if err != nil {
return nil, err
}
allRegistered := true
for _, server := range servers {
allRegistered = allRegistered && server.Registered
}
// If any of the servers we haven't registered yet, continue
if !allRegistered {
continue
}
// all have registered,cancel context and return
cancel()
return servers, nil
}
}
2020-06-30 07:50:59 +00:00
}
// HandlePushNotificationRegistrationResponse should check whether the response was successful or not, retry if necessary otherwise store the result in the database
2020-07-10 07:45:40 +00:00
func (c *Client) HandlePushNotificationRegistrationResponse(publicKey *ecdsa.PublicKey, response protobuf.PushNotificationRegistrationResponse) error {
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("received push notification registration response", zap.Any("response", response))
2020-07-10 07:45:40 +00:00
// TODO: handle non successful response and match request id
// Not successful ignore for now
if !response.Success {
return errors.New("response was not successful")
2020-07-09 16:52:26 +00:00
}
2020-07-10 07:45:40 +00:00
servers, err := c.persistence.GetServersByPublicKey([]*ecdsa.PublicKey{publicKey})
if err != nil {
return err
}
// We haven't registered with this server
if len(servers) != 1 {
return errors.New("not registered with this server, ignoring")
}
server := servers[0]
server.Registered = true
server.RegisteredAt = time.Now().Unix()
return c.persistence.UpsertServer(server)
2020-06-30 07:50:59 +00:00
}
// HandlePushNotificationAdvertisement should store any info related to push notifications
func (p *Client) HandlePushNotificationAdvertisement(info *protobuf.PushNotificationAdvertisementInfo) error {
2020-06-30 07:50:59 +00:00
return nil
}
2020-07-13 08:53:13 +00:00
// buildGrantSignatureMaterial builds a grant for a specific server.
// We use 3 components:
// 1) The client public key. Not sure this applies to our signature scheme, but best to be conservative. https://crypto.stackexchange.com/questions/15538/given-a-message-and-signature-find-a-public-key-that-makes-the-signature-valid
// 2) The server public key
// 3) The access token
// By verifying this signature, a client can trust the server was instructed to store this access token.
func (c *Client) buildGrantSignatureMaterial(clientPublicKey *ecdsa.PublicKey, serverPublicKey *ecdsa.PublicKey, accessToken string) []byte {
var signatureMaterial []byte
signatureMaterial = append(signatureMaterial, crypto.CompressPubkey(clientPublicKey)...)
signatureMaterial = append(signatureMaterial, crypto.CompressPubkey(serverPublicKey)...)
signatureMaterial = append(signatureMaterial, []byte(accessToken)...)
return crypto.Keccak256(signatureMaterial)
}
func (c *Client) buildGrantSignature(serverPublicKey *ecdsa.PublicKey, accessToken string) ([]byte, error) {
signatureMaterial := c.buildGrantSignatureMaterial(&c.config.Identity.PublicKey, serverPublicKey, accessToken)
return crypto.Sign(signatureMaterial, c.config.Identity)
}
func (c *Client) handleGrant(clientPublicKey *ecdsa.PublicKey, serverPublicKey *ecdsa.PublicKey, grant []byte, accessToken string) error {
signatureMaterial := c.buildGrantSignatureMaterial(clientPublicKey, serverPublicKey, accessToken)
c.config.Logger.Info("GRANT", zap.Binary("GRANT", grant))
extractedPublicKey, err := crypto.SigToPub(signatureMaterial, grant)
if err != nil {
return err
}
if !common.IsPubKeyEqual(clientPublicKey, extractedPublicKey) {
return errors.New("invalid grant")
}
return nil
}
2020-06-30 07:50:59 +00:00
// HandlePushNotificationQueryResponse should update the data in the database for a given user
func (c *Client) HandlePushNotificationQueryResponse(serverPublicKey *ecdsa.PublicKey, response protobuf.PushNotificationQueryResponse) error {
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("received push notification query response", zap.Any("response", response))
if len(response.Info) == 0 {
return errors.New("empty response from the server")
}
publicKey, err := c.persistence.GetQueryPublicKey(response.MessageId)
if err != nil {
return err
}
if publicKey == nil {
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("query not found")
return nil
}
var pushNotificationInfo []*PushNotificationInfo
for _, info := range response.Info {
if bytes.Compare(info.PublicKey, common.HashPublicKey(publicKey)) != 0 {
c.config.Logger.Warn("reply for different key, ignoring")
continue
}
2020-07-13 08:53:13 +00:00
// We check the user has allowed this server to store this particular
// access token, otherwise anyone could reply with a fake token
// and receive notifications for a user
if err := c.handleGrant(publicKey, serverPublicKey, info.Grant, info.AccessToken); err != nil {
c.config.Logger.Warn("grant verification failed, ignoring", zap.Error(err))
continue
}
pushNotificationInfo = append(pushNotificationInfo, &PushNotificationInfo{
PublicKey: publicKey,
ServerPublicKey: serverPublicKey,
AccessToken: info.AccessToken,
InstallationID: info.InstallationId,
RetrievedAt: time.Now().Unix(),
})
}
err = c.persistence.SavePushNotificationInfo(pushNotificationInfo)
if err != nil {
c.config.Logger.Error("failed to save push notifications", zap.Error(err))
return err
}
2020-06-30 07:50:59 +00:00
return nil
}
2020-07-03 08:26:35 +00:00
// HandlePushNotificationResponse should set the request as processed
func (p *Client) HandlePushNotificationResponse(ack *protobuf.PushNotificationResponse) error {
2020-06-30 07:50:59 +00:00
return nil
}
func (c *Client) AddPushNotificationServer(publicKey *ecdsa.PublicKey) error {
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("adding push notification server", zap.Any("public-key", publicKey))
currentServers, err := c.persistence.GetServers()
if err != nil {
return err
}
for _, server := range currentServers {
2020-07-10 07:45:40 +00:00
if common.IsPubKeyEqual(server.PublicKey, publicKey) {
return errors.New("push notification server already added")
}
}
return c.persistence.UpsertServer(&PushNotificationServer{
2020-07-10 07:45:40 +00:00
PublicKey: publicKey,
})
2020-06-30 07:50:59 +00:00
}
func (c *Client) QueryPushNotificationInfo(publicKey *ecdsa.PublicKey) error {
2020-07-09 16:52:26 +00:00
hashedPublicKey := common.HashPublicKey(publicKey)
query := &protobuf.PushNotificationQuery{
PublicKeys: [][]byte{hashedPublicKey},
}
encodedMessage, err := proto.Marshal(query)
if err != nil {
return err
2020-07-09 16:52:26 +00:00
}
rawMessage := &common.RawMessage{
Payload: encodedMessage,
MessageType: protobuf.ApplicationMetadataMessage_PUSH_NOTIFICATION_QUERY,
}
encodedPublicKey := hex.EncodeToString(hashedPublicKey)
2020-07-14 14:07:19 +00:00
c.config.Logger.Info("sending query")
2020-07-09 16:52:26 +00:00
messageID, err := c.messageProcessor.SendPublic(context.Background(), encodedPublicKey, rawMessage)
if err != nil {
return err
}
2020-07-09 16:52:26 +00:00
return c.persistence.SavePushNotificationQuery(publicKey, messageID)
}
2020-07-09 16:52:26 +00:00
func (c *Client) GetPushNotificationInfo(publicKey *ecdsa.PublicKey, installationIDs []string) ([]*PushNotificationInfo, error) {
2020-07-14 14:07:19 +00:00
if len(installationIDs) == 0 {
return c.persistence.GetPushNotificationInfoByPublicKey(publicKey)
} else {
return c.persistence.GetPushNotificationInfo(publicKey, installationIDs)
}
2020-07-09 16:52:26 +00:00
}
func (c *Client) listenToPublicKeyQueryTopic(hashedPublicKey []byte) error {
2020-07-09 16:52:26 +00:00
encodedPublicKey := hex.EncodeToString(hashedPublicKey)
return c.messageProcessor.JoinPublic(encodedPublicKey)
2020-06-30 07:50:59 +00:00
}
func encryptAccessToken(plaintext []byte, key []byte, reader io.Reader) ([]byte, error) {
c, err := aes.NewCipher(key)
if err != nil {
return nil, err
}
gcm, err := cipher.NewGCM(c)
if err != nil {
return nil, err
}
nonce := make([]byte, gcm.NonceSize())
if _, err = io.ReadFull(reader, nonce); err != nil {
return nil, err
}
return gcm.Seal(nonce, nonce, plaintext, nil), nil
}
func (c *Client) encryptRegistration(publicKey *ecdsa.PublicKey, payload []byte) ([]byte, error) {
sharedKey, err := c.generateSharedKey(publicKey)
if err != nil {
return nil, err
}
return common.Encrypt(payload, sharedKey, c.reader)
}
func (c *Client) generateSharedKey(publicKey *ecdsa.PublicKey) ([]byte, error) {
return ecies.ImportECDSA(c.config.Identity).GenerateShared(
ecies.ImportECDSAPublic(publicKey),
encryptedPayloadKeyLength,
encryptedPayloadKeyLength,
)
2020-06-30 07:50:59 +00:00
}