feat: add a hidden flag for convos and use it with the contactswrapper

pull/2620/head
Audric Ackermann 2 years ago
parent c4217cb564
commit 3c58f9c1e4

@ -164,11 +164,12 @@ const setupTheme = async () => {
// Do this only if we created a new Session ID, or if we already received the initial configuration message
const triggerSyncIfNeeded = async () => {
const us = UserUtils.getOurPubKeyStrFromCache();
await getConversationController()
.get(UserUtils.getOurPubKeyStrFromCache())
.get(us)
.setDidApproveMe(true, true);
await getConversationController()
.get(UserUtils.getOurPubKeyStrFromCache())
.get(us)
.setIsApproved(true, true);
const didWeHandleAConfigurationMessageAlready =
(await Data.getItemById(hasSyncedInitialConfigurationItem))?.value || false;

@ -63,8 +63,12 @@ export const OverlayMessage = () => {
);
// we now want to show a conversation we just started on the leftpane, even if we did not send a message to it yet
if (!convo.isActive() || !convo.isApproved()) {
convo.set({ active_at: Date.now(), isApproved: true });
if (!convo.isActive() || !convo.isApproved() || convo.isHidden()) {
// bump the timestamp only if we were not active before
if (!convo.isActive()) {
convo.set({ active_at: Date.now(), isApproved: true, hidden: false });
}
convo.set({ isApproved: true, hidden: false });
await convo.commit();
}

@ -7,9 +7,11 @@ import { ConversationCollection, ConversationModel } from '../models/conversatio
import { ConversationAttributes } from '../models/conversationAttributes';
import { MessageCollection, MessageModel } from '../models/message';
import { MessageAttributes, MessageDirection } from '../models/messageType';
import { StorageItem } from '../node/storage_item';
import { HexKeyPair } from '../receiver/keypairs';
import { getSodiumRenderer } from '../session/crypto';
import { PubKey } from '../session/types';
import { fromArrayBufferToBase64, fromBase64ToArrayBuffer } from '../session/utils/String';
import {
AsyncWrapper,
MsgDuplicateSearchOpenGroup,
@ -20,8 +22,6 @@ import { ExpirationTimerOptions } from '../util/expiringMessages';
import { Storage } from '../util/storage';
import { channels } from './channels';
import * as dataInit from './dataInit';
import { StorageItem } from '../node/storage_item';
import { fromArrayBufferToBase64, fromBase64ToArrayBuffer } from '../session/utils/String';
import { cleanData } from './dataUtils';
const ERASE_SQL_KEY = 'erase-sql-key';
@ -142,7 +142,7 @@ async function removeAllClosedGroupEncryptionKeyPairs(groupPublicKey: string): P
// Conversation
async function saveConversation(data: ConversationAttributes): Promise<void> {
const cleaned = cleanData(data);
const cleaned = cleanData(data) as ConversationAttributes;
/**
* Merging two conversations in `handleMessageRequestResponse` introduced a bug where we would mark conversation active_at to be -Infinity.
* The root issue has been fixed, but just to make sure those INVALID DATE does not show up, update those -Infinity active_at conversations to be now(), once.,
@ -150,6 +150,7 @@ async function saveConversation(data: ConversationAttributes): Promise<void> {
if (cleaned.active_at === -Infinity) {
cleaned.active_at = Date.now();
}
await channels.saveConversation(cleaned);
}

@ -102,14 +102,14 @@ export async function unblockConvoById(conversationId: string) {
if (!conversation) {
// we assume it's a block contact and not group.
// this is to be able to unlock a contact we don't have a conversation with.
await BlockedNumberController.unblock(conversationId);
await BlockedNumberController.unblockAll([conversationId]);
ToastUtils.pushToastSuccess('unblocked', window.i18n('unblocked'));
return;
}
if (!conversation.id || conversation.isPublic()) {
return;
}
await BlockedNumberController.unblock(conversationId);
await BlockedNumberController.unblockAll([conversationId]);
ToastUtils.pushToastSuccess('unblocked', window.i18n('unblocked'));
await conversation.commit();
}

@ -258,6 +258,10 @@ export class ConversationModel extends Backbone.Model<ConversationAttributes> {
return Boolean(this.get('active_at'));
}
public isHidden() {
return Boolean(this.get('hidden'));
}
public async cleanup() {
await deleteExternalFilesOfConversation(this.attributes);
}
@ -310,6 +314,7 @@ export class ConversationModel extends Backbone.Model<ConversationAttributes> {
id: this.id as string,
activeAt: this.get('active_at'),
type: this.get('type'),
isHidden: !!this.get('hidden'),
};
if (isPrivate) {
@ -562,6 +567,12 @@ export class ConversationModel extends Backbone.Model<ConversationAttributes> {
if (this.isPublic() && !this.isOpenGroupV2()) {
throw new Error('Only opengroupv2 are supported now');
}
// we are trying to send a message to someone. If that convo is hidden in the list, make sure it is not
if (this.isHidden()) {
this.set({ hidden: false });
await this.commit();
}
// an OpenGroupV2 message is just a visible message
const chatMessageParams: VisibleMessageParams = {
body,
@ -1682,7 +1693,7 @@ export class ConversationModel extends Backbone.Model<ConversationAttributes> {
* profileKey MUST be a hex string
* @param profileKey MUST be a hex string
*/
public async setProfileKey(profileKey?: Uint8Array, autoCommit = true) {
public async setProfileKey(profileKey?: Uint8Array, shouldCommit = true) {
if (!profileKey) {
return;
}
@ -1695,7 +1706,7 @@ export class ConversationModel extends Backbone.Model<ConversationAttributes> {
profileKey: profileKeyHex,
});
if (autoCommit) {
if (shouldCommit) {
await this.commit();
}
}
@ -2198,6 +2209,8 @@ export async function commitConversationAndRefreshWrapper(id: string) {
}
// write to DB
// TODO remove duplicates between db and wrapper (except nickname&name as we need them for search)
// TODO when deleting a contact from the ConversationController, we still need to keep it in the wrapper but mark it as hidden (and we might need to add an hidden convo model field for it)
await Data.saveConversation(convo.attributes);
const shouldBeSavedToWrapper = SessionUtilContact.filterContactsToStoreInContactsWrapper(convo);

@ -94,6 +94,8 @@ export interface ConversationAttributes {
* When we create a closed group v3 or get promoted to admim, we need to save the private key of that closed group.
*/
// identityPrivateKey?: string;
hidden: boolean;
}
/**
@ -129,5 +131,6 @@ export const fillConvoAttributesWithDefaults = (
mentionedUs: false,
isKickedFromGroup: false,
left: false,
hidden: true,
});
};

@ -78,6 +78,7 @@ const allowedKeysFormatRowOfConversation = [
'conversationIdOrigin',
'identityPrivateKey',
'markedAsUnread',
'hidden',
];
// tslint:disable: cyclomatic-complexity
export function formatRowOfConversation(row?: Record<string, any>): ConversationAttributes | null {
@ -134,6 +135,7 @@ export function formatRowOfConversation(row?: Record<string, any>): Conversation
convo.writeCapability = Boolean(convo.writeCapability);
convo.uploadCapability = Boolean(convo.uploadCapability);
convo.markedAsUnread = Boolean(convo.markedAsUnread);
convo.hidden = Boolean(convo.hidden);
if (!convo.conversationIdOrigin) {
convo.conversationIdOrigin = undefined;
@ -214,6 +216,7 @@ const allowedKeysOfConversationAttributes = [
'conversationIdOrigin',
'identityPrivateKey',
'markedAsUnread',
'hidden',
];
/**

@ -1,11 +1,19 @@
import * as BetterSqlite3 from 'better-sqlite3';
import { compact, map, pick } from 'lodash';
import { base64_variants, from_base64, to_hex } from 'libsodium-wrappers-sumo';
import { compact, isArray, isEmpty, map, pick } from 'lodash';
import {
ContactsConfigWrapperInsideWorker,
UserConfigWrapperInsideWorker,
} from 'session_util_wrapper';
import { ConversationAttributes } from '../../models/conversationAttributes';
import { fromHexToArray } from '../../session/utils/String';
import { CONFIG_DUMP_TABLE, getContactInfoFromDBValues } from '../../types/sqlSharedTypes';
import {
CLOSED_GROUP_V2_KEY_PAIRS_TABLE,
CONVERSATIONS_TABLE,
dropFtsAndTriggers,
GUARD_NODE_TABLE,
ITEMS_TABLE,
jsonToObject,
LAST_HASHES_TABLE,
MESSAGES_TABLE,
@ -13,6 +21,7 @@ import {
objectToJSON,
OPEN_GROUP_ROOMS_V2_TABLE,
rebuildFtsTable,
toSqliteBoolean,
} from '../database_utility';
import { sqlNode } from '../sql';
@ -1224,6 +1233,118 @@ function updateToSessionSchemaVersion30(currentVersion: number, db: BetterSqlite
console.log(`updateToSessionSchemaVersion${targetVersion}: success!`);
}
function getIdentityKeysDuringMigration(db: BetterSqlite3.Database) {
const row = db.prepare(`SELECT * FROM ${ITEMS_TABLE} WHERE id = $id;`).get({
id: 'identityKey',
});
if (!row) {
return null;
}
try {
const parsedIdentityKey = jsonToObject(row.json);
if (
!parsedIdentityKey?.value?.pubKey ||
!parsedIdentityKey?.value?.ed25519KeyPair?.privateKey
) {
return null;
}
const publicKeyBase64 = parsedIdentityKey?.value?.pubKey;
const publicKeyHex = to_hex(from_base64(publicKeyBase64, base64_variants.ORIGINAL));
const ed25519PrivateKeyUintArray = parsedIdentityKey?.value?.ed25519KeyPair?.privateKey;
// TODO migrate the ed25519KeyPair for all the users already logged in to a base64 representation
const privateEd25519 = new Uint8Array(Object.values(ed25519PrivateKeyUintArray));
if (!privateEd25519 || isEmpty(privateEd25519)) {
return null;
}
return {
publicKeyHex,
privateEd25519,
};
} catch (e) {
return null;
}
}
function insertContactIntoWrapper(
contact: any,
blockedNumbers: Array<string>,
contactsConfigWrapper: ContactsConfigWrapperInsideWorker
) {
const dbApproved = !!contact.isApproved || false;
const dbApprovedMe = !!contact.didApproveMe || false;
const dbBlocked = blockedNumbers.includes(contact.id);
const hidden = contact.hidden || false;
const isPinned = contact.isPinned;
const wrapperContact = getContactInfoFromDBValues({
id: contact.id,
dbApproved,
dbApprovedMe,
dbBlocked,
dbName: contact.displayNameInProfile || undefined,
dbNickname: contact.nickname || undefined,
dbProfileKey: contact.profileKey || undefined,
dbProfileUrl: contact.avatarPointer || undefined,
isPinned,
hidden,
});
try {
console.info('Inserting contact into wrapper: ', wrapperContact);
contactsConfigWrapper.set(wrapperContact);
} catch (e) {
console.error(
`contactsConfigWrapper.set during migration failed with ${e.message} for id: ${contact.id}`
);
// the wrapper did not like something. Try again with just the boolean fields as it's most likely the issue is with one of the strings (which could be recovered)
try {
console.info('Inserting edited contact into wrapper: ', contact.id);
contactsConfigWrapper.set(
getContactInfoFromDBValues({
id: contact.id,
dbApproved,
dbApprovedMe,
dbBlocked,
dbName: undefined,
dbNickname: undefined,
dbProfileKey: undefined,
dbProfileUrl: undefined,
isPinned: false,
hidden,
})
);
} catch (e) {
// there is nothing else we can do here
console.error(
`contactsConfigWrapper.set during migration failed with ${e.message} for id: ${contact.id}. Skipping contact entirely`
);
}
}
}
function getBlockedNumbersDuringMigration(db: BetterSqlite3.Database) {
try {
const blockedItem = sqlNode.getItemById('blocked', db);
if (!blockedItem) {
throw new Error('no blocked contacts at all');
}
const foundBlocked = blockedItem?.value;
console.warn('foundBlockedNumbers during migration', foundBlocked);
if (isArray(foundBlocked)) {
return foundBlocked;
}
return [];
} catch (e) {
console.warn('failed to read blocked numbers. Considering no blocked numbers', e.stack);
return [];
}
}
function updateToSessionSchemaVersion31(currentVersion: number, db: BetterSqlite3.Database) {
const targetVersion = 31;
if (currentVersion >= targetVersion) {
@ -1235,6 +1356,27 @@ function updateToSessionSchemaVersion31(currentVersion: number, db: BetterSqlite
* Create a table to store our sharedConfigMessage dumps
*/
db.transaction(() => {
// when deleting a contact we now mark it as 'hidden' rather than overriding the `active_at` field.
// by default, conversation are hidden
db.exec(
`ALTER TABLE ${CONVERSATIONS_TABLE} ADD COLUMN hidden INTEGER NOT NULL DEFAULT ${toSqliteBoolean(
true
)} ;`
);
// mark every "active" private chats as not hidden
db.prepare(
`UPDATE ${CONVERSATIONS_TABLE} SET
hidden = ${toSqliteBoolean(false)}
WHERE type = 'private' AND active_at > 0 AND (didApproveMe OR isApproved);`
).run({});
// mark every not private chats (groups or communities) as not hidden (even if a group was left or we were kicked, we want it visible in the app)
db.prepare(
`UPDATE ${CONVERSATIONS_TABLE} SET
hidden = ${toSqliteBoolean(false)}
WHERE type <> 'private' AND active_at > 0;`
).run({});
db.exec(`CREATE TABLE configDump(
variant TEXT NOT NULL,
publicKey TEXT NOT NULL,
@ -1244,6 +1386,116 @@ function updateToSessionSchemaVersion31(currentVersion: number, db: BetterSqlite
);
`);
try {
const keys = getIdentityKeysDuringMigration(db);
if (!keys || !keys.privateEd25519 || isEmpty(keys.privateEd25519)) {
throw new Error('privateEd25519 was empty. Considering no users are logged in');
}
const { privateEd25519, publicKeyHex } = keys;
const userProfileWrapper = new UserConfigWrapperInsideWorker(privateEd25519, null);
const contactsConfigWrapper = new ContactsConfigWrapperInsideWorker(privateEd25519, null);
/**
* Setup up the User profile wrapper with what is stored in our own conversation
*/
const ourConversation = sqlNode.getConversationById(publicKeyHex, db);
if (!ourConversation) {
throw new Error('Failed to find our logged in conversation while migrating');
}
// Insert the user profile into the userWrappoer
const ourDbName = ourConversation.displayNameInProfile || '';
const ourDbProfileUrl = ourConversation.avatarPointer || '';
const ourDbProfileKey = fromHexToArray(ourConversation.profileKey || '');
userProfileWrapper.setName(ourDbName);
if (ourDbProfileUrl && !isEmpty(ourDbProfileKey)) {
userProfileWrapper.setProfilePicture(ourDbProfileUrl, ourDbProfileKey);
} else {
userProfileWrapper.setProfilePicture('', new Uint8Array());
}
// dump the user wrapper content and save it to the DB
const userDump = userProfileWrapper.dump();
db.prepare(
`INSERT OR REPLACE INTO ${CONFIG_DUMP_TABLE} (
publicKey,
variant,
combinedMessageHashes,
data
) values (
$publicKey,
$variant,
$combinedMessageHashes,
$data
);`
).run({
publicKey: publicKeyHex,
variant: 'UserConfig',
combinedMessageHashes: JSON.stringify([]),
data: userDump,
});
/**
* Setup up the Contacts Wrapper with all the contact details which needs to be stored in it.
*/
const blockedNumbers = getBlockedNumbersDuringMigration(db);
// this filter is based on the `filterContactsToStoreInContactsWrapper` function.
const contactsToWriteInWrapper = db
.prepare(
`SELECT * FROM ${CONVERSATIONS_TABLE} WHERE type = 'private' AND active_at > 0 AND NOT hidden AND (didApproveMe OR isApproved) AND id <> $us AND id NOT LIKE '15%' ;`
)
.all({
us: publicKeyHex,
});
if (isArray(contactsToWriteInWrapper) && contactsToWriteInWrapper.length) {
console.warn(
'===================== Starting contact inserting into wrapper ======================='
);
console.info(
'Writing contacts to wrapper during migration. length: ',
contactsToWriteInWrapper?.length
);
contactsToWriteInWrapper.forEach(contact => {
insertContactIntoWrapper(contact, blockedNumbers, contactsConfigWrapper);
});
console.warn('===================== Done with contact inserting =======================');
}
const contactsDump = contactsConfigWrapper.dump();
db.prepare(
`INSERT OR REPLACE INTO ${CONFIG_DUMP_TABLE} (
publicKey,
variant,
combinedMessageHashes,
data
) values (
$publicKey,
$variant,
$combinedMessageHashes,
$data
);`
).run({
publicKey: publicKeyHex,
variant: 'ContactsConfig',
combinedMessageHashes: JSON.stringify([]),
data: contactsDump,
});
// TODO we've just created the initial dumps. We have to add an initial SyncJob to the database so it is run on the next app start/
// or find another way of adding one on the next start (store an another item in the DB and check for it on app start?)
} catch (e) {
console.error(`failed to create initial wrapper: `, e.stack);
}
// db.exec(`ALTER TABLE conversations
// ADD COLUMN lastReadTimestampMs INTEGER;
// ;

@ -292,8 +292,8 @@ function updateGuardNodes(nodes: Array<string>) {
function createOrUpdateItem(data: StorageItem, instance?: BetterSqlite3.Database) {
createOrUpdate(ITEMS_TABLE, data, instance);
}
function getItemById(id: string) {
return getById(ITEMS_TABLE, id);
function getItemById(id: string, instance?: BetterSqlite3.Database) {
return getById(ITEMS_TABLE, id, instance);
}
function getAllItems() {
const rows = assertGlobalInstance()
@ -443,6 +443,7 @@ function saveConversation(data: ConversationAttributes, instance?: BetterSqlite3
avatarInProfile,
displayNameInProfile,
conversationIdOrigin,
hidden,
// identityPrivateKey,
} = formatted;
@ -504,6 +505,7 @@ function saveConversation(data: ConversationAttributes, instance?: BetterSqlite3
displayNameInProfile,
conversationIdOrigin,
// identityPrivateKey,
hidden,
});
}
@ -527,8 +529,8 @@ function removeConversation(id: string | Array<string>) {
.run(id);
}
function getConversationById(id: string) {
const row = assertGlobalInstance()
function getConversationById(id: string, instance?: BetterSqlite3.Database) {
const row = assertGlobalInstanceOrInstance(instance)
.prepare(`SELECT * FROM ${CONVERSATIONS_TABLE} WHERE id = $id;`)
.get({
id,
@ -610,7 +612,7 @@ function searchConversations(query: string) {
(
displayNameInProfile LIKE $displayNameInProfile OR
nickname LIKE $nickname
) AND active_at IS NOT NULL AND active_at > 0
) AND active_at > 0
ORDER BY active_at DESC
LIMIT $limit`
)
@ -654,6 +656,10 @@ function searchMessages(query: string, limit: number) {
}));
}
/**
* Search for matching messages in a specific conversation.
* Currently unused but kept as we want to add it back at some point.
*/
function searchMessagesInConversation(query: string, conversationId: string, limit: number) {
const rows = assertGlobalInstance()
.prepare(

@ -36,10 +36,12 @@ async function mergeConfigsWithIncomingUpdates(
const toMerge = [incomingConfig.message.data];
const wrapperId = LibSessionUtil.kindToVariant(kind);
try {
window.log.warn(`${wrapperId} right before merge of ${toMerge.length} arrays`);
await GenericWrapperActions.merge(wrapperId, toMerge);
window.log.warn(`${wrapperId} right after merge.`);
const needsPush = await GenericWrapperActions.needsPush(wrapperId);
const needsDump = await GenericWrapperActions.needsDump(wrapperId);
console.info(`${wrapperId} needsPush:${needsPush} needsDump:${needsDump} `);
window.log.info(`${wrapperId} needsPush:${needsPush} needsDump:${needsDump} `);
const messageHashes = [incomingConfig.messageHash];
const latestSentTimestamp = incomingConfig.envelopeTimestamp;
@ -99,15 +101,13 @@ async function handleContactsUpdate(result: IncomingConfResult): Promise<Incomin
let changes = false;
// the display name set is handled in `updateProfileOfContact`
if (wrapperConvo.nickname !== existingConvo.getNickname()) {
await existingConvo.setNickname(wrapperConvo.nickname || null, false);
changes = true;
}
if (!wrapperConvo.hidden && !existingConvo.isActive()) {
// FIXME we need a field hidden rather than overriding the active_at here.
existingConvo.set('active_at', Date.now());
if (!wrapperConvo.hidden && !existingConvo.isHidden()) {
existingConvo.set({ hidden: false });
changes = true;
}
@ -429,7 +429,7 @@ const handleContactFromConfigLegacy = async (
}
await BlockedNumberController.block(contactConvo.id);
} else if (contactReceived.isBlocked === false) {
await BlockedNumberController.unblock(contactConvo.id);
await BlockedNumberController.unblockAll([contactConvo.id]);
}
await ProfileManager.updateProfileOfContact(

@ -621,7 +621,6 @@ async function handleMessageRequestResponse(
) {
const { isApproved } = messageRequestResponse;
if (!isApproved) {
window?.log?.error('handleMessageRequestResponse: isApproved is false -- dropping message.');
await removeFromCache(envelope);
return;
}
@ -649,6 +648,7 @@ async function handleMessageRequestResponse(
conversationToApprove.set({
active_at: mostRecentActiveAt,
hidden: false,
isApproved: true,
didApproveMe: true,
});
@ -708,10 +708,8 @@ async function handleMessageRequestResponse(
);
}
if (!conversationToApprove || conversationToApprove.didApproveMe() === isApproved) {
if (conversationToApprove) {
await conversationToApprove.commit();
}
if (!conversationToApprove || conversationToApprove.didApproveMe()) {
await conversationToApprove?.commit();
window?.log?.info(
'Conversation already contains the correct value for the didApproveMe field.'
);
@ -720,14 +718,12 @@ async function handleMessageRequestResponse(
return;
}
await conversationToApprove.setDidApproveMe(isApproved, true);
if (isApproved === true) {
// Conversation was not approved before so a sync is needed
await conversationToApprove.addIncomingApprovalMessage(
toNumber(envelope.timestamp),
unblindedConvoId
);
}
await conversationToApprove.setDidApproveMe(true, true);
// Conversation was not approved before so a sync is needed
await conversationToApprove.addIncomingApprovalMessage(
toNumber(envelope.timestamp),
unblindedConvoId
);
await removeFromCache(envelope);
}

@ -284,9 +284,14 @@ async function handleRegularMessage(
}
const conversationActiveAt = conversation.get('active_at');
if (!conversationActiveAt || (message.get('sent_at') || 0) > conversationActiveAt) {
if (
!conversationActiveAt ||
conversation.get('hidden') ||
(message.get('sent_at') || 0) > conversationActiveAt
) {
conversation.set({
active_at: message.get('sent_at'),
hidden: false, // a new message was received for that conversation. If it was not it should not be hidden anymore
lastMessage: message.getNotificationText(),
});
}

@ -208,6 +208,7 @@ export class OpenGroupManagerV2 {
displayNameInProfile: updatedRoom.roomName,
isApproved: true,
didApproveMe: true,
hidden: false,
isTrustedForAttachmentDownload: true, // we always trust attachments when sent to an opengroup
});
await conversation.commit();

@ -192,7 +192,8 @@ export class ConversationController {
// we remove the messages left in this convo. The caller has to merge them if needed
await deleteAllMessagesByConvoIdNoConfirmation(conversation.id);
conversation.set({ didApproveMe: false, isApproved: false });
await conversation.setIsApproved(false, false);
await conversation.setDidApproveMe(false, false);
await conversation.commit();
}
@ -241,11 +242,12 @@ export class ConversationController {
window.log.info(`deleteContact isPrivate, marking as inactive: ${id}`);
conversation.set({
active_at: undefined,
isApproved: false,
hidden: true,
});
// we currently do not wish to reset the approved/approvedMe state when marking a private conversation as hidden
// await conversation.setIsApproved(false, false);
await conversation.commit();
// the call above will mark it as hidden in the wrapper already
// TODO the call above won't mark the conversation as hidden in the wrapper, it will just stop being updated (which is a bad thing)
} else {
window.log.info(`deleteContact !isPrivate, removing convo from DB: ${id}`);
// not a private conversation, so not a contact for the ContactWrapper
@ -253,16 +255,17 @@ export class ConversationController {
window.log.info(`deleteContact !isPrivate, convo removed from DB: ${id}`);
// TODO remove group related entries from their corresponding wrappers here
this.conversations.remove(conversation);
if (window?.inboxStore) {
window.inboxStore?.dispatch(
conversationActions.conversationChanged({
id: conversation.id,
data: conversation.getConversationModelProps(),
})
);
window.inboxStore?.dispatch(conversationActions.conversationRemoved(conversation.id));
}
window?.inboxStore?.dispatch(
conversationActions.conversationChanged({
id: conversation.id,
data: conversation.getConversationModelProps(),
})
);
window.inboxStore?.dispatch(conversationActions.conversationRemoved(conversation.id));
window.log.info(`deleteContact !isPrivate, convo removed from store: ${id}`);
}
}

@ -252,6 +252,7 @@ export async function updateOrCreateClosedGroup(details: GroupInfo | GroupInfoV3
| 'active_at'
| 'left'
| 'lastJoinedTimestamp'
| 'hidden'
> = {
displayNameInProfile: details.name,
members: details.members,
@ -260,6 +261,7 @@ export async function updateOrCreateClosedGroup(details: GroupInfo | GroupInfoV3
active_at: details.activeAt ? details.activeAt : 0,
left: details.activeAt ? false : true,
lastJoinedTimestamp: details.activeAt && weWereJustAdded ? Date.now() : details.activeAt || 0,
hidden: false,
// identityPrivateKey: isV3(details) ? details.identityPrivateKey : undefined,
};
console.warn('updates', updates);

@ -503,6 +503,7 @@ export async function USER_callRecipient(recipient: string) {
window.log.info('Sending preOffer message to ', ed25519Str(recipient));
const calledConvo = getConversationController().get(recipient);
calledConvo.set('active_at', Date.now()); // addSingleOutgoingMessage does the commit for us on the convo
calledConvo.set('hidden', false);
weAreCallerOnCurrentCall = true;
await calledConvo?.addSingleOutgoingMessage({
@ -851,6 +852,7 @@ export async function USER_acceptIncomingCallRequest(fromSender: string) {
const networkTimestamp = GetNetworkTime.getNowWithNetworkOffset();
const callerConvo = getConversationController().get(fromSender);
callerConvo.set('active_at', networkTimestamp);
callerConvo.set('hidden', false);
await callerConvo?.addSingleIncomingMessage({
source: UserUtils.getOurPubKeyStrFromCache(),
sent_at: networkTimestamp,
@ -1185,8 +1187,9 @@ export async function handleMissedCall(
async function addMissedCallMessage(callerPubkey: string, sentAt: number) {
const incomingCallConversation = getConversationController().get(callerPubkey);
if (incomingCallConversation.isActive()) {
if (incomingCallConversation.isActive() || incomingCallConversation.isHidden()) {
incomingCallConversation.set('active_at', GetNetworkTime.getNowWithNetworkOffset());
incomingCallConversation.set('hidden', false);
}
await incomingCallConversation?.addSingleIncomingMessage({

@ -246,14 +246,14 @@ class AvatarDownloadJob extends PersistedJob<AvatarDownloadPersistedData> {
// make sure the settings which should already set to `true` are
if (
!conversation.get('isTrustedForAttachmentDownload') ||
!conversation.get('isApproved') ||
!conversation.get('didApproveMe')
!conversation.isApproved() ||
!conversation.didApproveMe()
) {
conversation.set({
isTrustedForAttachmentDownload: true,
isApproved: true,
didApproveMe: true,
});
await conversation.setDidApproveMe(true, false);
await conversation.setIsApproved(true, false);
changes = true;
}
}

@ -40,7 +40,9 @@ async function createConfigDumpsFromDbFirstStart(
): Promise<Array<ConfigWrapperObjectTypes>> {
const justCreated: Array<ConfigWrapperObjectTypes> = [];
try {
console.warn('createConfigDumpsFromDbFirstStart');
console.error(
'createConfigDumpsFromDbFirstStart should be removed as this would done in a migration'
);
// build the userconfig
await UserConfigWrapperActions.init(privateKeyEd25519, null);
@ -111,6 +113,10 @@ async function initializeLibSessionUtilWrappers() {
[...userVariantsBuildWithoutErrors.values()]
);
if (missingRequiredVariants.length) {
throw new Error(`missingRequiredVariants: ${JSON.stringify(missingRequiredVariants)}`);
}
for (let index = 0; index < missingRequiredVariants.length; index++) {
const missingVariant = missingRequiredVariants[index];
await GenericWrapperActions.init(missingVariant, privateKeyEd25519, null);

@ -1,11 +1,9 @@
import { isEmpty, isEqual } from 'lodash';
import { UserUtils } from '..';
import { ContactInfo } from 'session_util_wrapper';
import { ConversationModel } from '../../../models/conversation';
import { getContactInfoFromDBValues } from '../../../types/sqlSharedTypes';
import { ContactsWrapperActions } from '../../../webworker/workers/browser/libsession_worker_interface';
import { getConversationController } from '../../conversations';
import { PubKey } from '../../types';
import { fromHexToArray } from '../String';
import { ContactInfo } from 'session_util_wrapper';
/**
* This file is centralizing the management of data from the Contacts Wrapper of libsession.
@ -40,9 +38,7 @@ async function insertAllContactsIntoContactsWrapper() {
for (let index = 0; index < idsToInsert.length; index++) {
const id = idsToInsert[index];
console.warn(
`inserting into wrapper ${id}: ${getConversationController().get(id)?.attributes.nickname}`
);
await insertContactFromDBIntoWrapperAndRefresh(id);
}
}
@ -68,21 +64,13 @@ function filterContactsToStoreInContactsWrapper(convo: ConversationModel): boole
*/
// tslint:disable-next-line: cyclomatic-complexity
async function insertContactFromDBIntoWrapperAndRefresh(id: string): Promise<void> {
const us = UserUtils.getOurPubKeyStrFromCache();
if (id === us) {
window.log.info(
"The contact config wrapper does not handle the current user config, just his contacts'"
);
return;
}
const foundConvo = getConversationController().get(id);
if (!foundConvo) {
return;
}
if (!filterContactsToStoreInContactsWrapper(foundConvo)) {
window.log.info(`insertContactFromDBIntoWrapperAndRefresh: convo ${id} should not be saved`);
// window.log.info(`insertContactFromDBIntoWrapperAndRefresh: convo ${id} should not be saved. Skipping`);
return;
}
@ -95,36 +83,40 @@ async function insertContactFromDBIntoWrapperAndRefresh(id: string): Promise<voi
const dbApproved = !!foundConvo.get('isApproved') || false;
const dbApprovedMe = !!foundConvo.get('didApproveMe') || false;
const dbBlocked = !!foundConvo.isBlocked() || false;
const wrapperContact = await ContactsWrapperActions.getOrCreate(id);
const activeAt = foundConvo.get('active_at');
const hidden = foundConvo.get('hidden') || false;
const isPinned = foundConvo.get('isPinned');
// override the values with what we have in the DB. the library will do the diff
wrapperContact.approved = dbApproved;
wrapperContact.approvedMe = dbApprovedMe;
wrapperContact.blocked = dbBlocked;
wrapperContact.name = dbName;
wrapperContact.nickname = dbNickname;
wrapperContact.hidden = !activeAt || activeAt <= 0;
wrapperContact.priority = !!isPinned ? 1 : 0; // TODO the priority handling is not that simple
if (
wrapperContact.profilePicture?.url !== dbProfileUrl ||
!isEqual(wrapperContact.profilePicture?.key, dbProfileKey)
) {
wrapperContact.profilePicture = {
url: dbProfileUrl || null,
key: dbProfileKey && !isEmpty(dbProfileKey) ? fromHexToArray(dbProfileKey) : null,
};
const wrapperContact = getContactInfoFromDBValues({
id,
dbApproved,
dbApprovedMe,
dbBlocked,
dbName,
dbNickname,
dbProfileKey,
dbProfileUrl,
isPinned,
hidden,
});
try {
console.warn(`inserting into wrapper ${id}: `, wrapperContact);
await ContactsWrapperActions.set(wrapperContact);
} catch (e) {
window.log.warn(`ContactsWrapperActions.set of ${id} failed with ${e.message}`);
// we still let this go through
}
await ContactsWrapperActions.set(wrapperContact);
await refreshMappedValue(id);
console.timeEnd(`ContactsWrapperActions.set ${id}`);
}
/**
* refreshMappedValue is used to query the Contacts Wrapper for the details of that contact and update the cached in-memory entry representing its content.
* @param id the pubkey to re fresh the cached value from
* @param duringAppStart set this to true if we should just fetch the cached value but not trigger a UI refresh of the corresponding conversation
*/
async function refreshMappedValue(id: string, duringAppStart = false) {
const fromWrapper = await ContactsWrapperActions.get(id);
if (fromWrapper) {

@ -28,6 +28,8 @@ import { MessageRequestResponse } from '../../messages/outgoing/controlMessage/M
import { PubKey } from '../../types';
import { SnodeNamespaces } from '../../apis/snode_api/namespaces';
import { SharedConfigMessage } from '../../messages/outgoing/controlMessage/SharedConfigMessage';
import { ConfigurationDumpSync } from '../job_runners/jobs/ConfigurationSyncDumpJob';
import { ConfigurationSync } from '../job_runners/jobs/ConfigurationSyncJob';
const ITEM_ID_LAST_SYNC_TIMESTAMP = 'lastSyncedTimestamp';
@ -41,31 +43,36 @@ const writeLastSyncTimestampToDb = async (timestamp: number) =>
* Conditionally Syncs user configuration with other devices linked.
*/
export const syncConfigurationIfNeeded = async () => {
const lastSyncedTimestamp = (await getLastSyncTimestampFromDb()) || 0;
const now = Date.now();
if (!window.sessionFeatureFlags.useSharedUtilForUserConfig) {
const lastSyncedTimestamp = (await getLastSyncTimestampFromDb()) || 0;
const now = Date.now();
// if the last sync was less than 2 days before, return early.
if (Math.abs(now - lastSyncedTimestamp) < DURATION.DAYS * 2) {
return;
}
// if the last sync was less than 2 days before, return early.
if (Math.abs(now - lastSyncedTimestamp) < DURATION.DAYS * 2) {
return;
}
const allConvos = getConversationController().getConversations();
const configMessage = await getCurrentConfigurationMessage(allConvos);
try {
// window?.log?.info('syncConfigurationIfNeeded with', configMessage);
await getMessageQueue().sendSyncMessage({
namespace: SnodeNamespaces.UserMessages,
message: configMessage,
});
} catch (e) {
window?.log?.warn('Caught an error while sending our ConfigurationMessage:', e);
// we do return early so that next time we use the old timestamp again
// and so try again to trigger a sync
return;
const allConvos = getConversationController().getConversations();
const configMessage = await getCurrentConfigurationMessage(allConvos);
try {
// window?.log?.info('syncConfigurationIfNeeded with', configMessage);
await getMessageQueue().sendSyncMessage({
namespace: SnodeNamespaces.UserMessages,
message: configMessage,
});
} catch (e) {
window?.log?.warn('Caught an error while sending our ConfigurationMessage:', e);
// we do return early so that next time we use the old timestamp again
// and so try again to trigger a sync
return;
}
await writeLastSyncTimestampToDb(now);
} else {
await ConfigurationDumpSync.queueNewJobIfNeeded();
await ConfigurationSync.queueNewJobIfNeeded();
}
await writeLastSyncTimestampToDb(now);
};
export const forceSyncConfigurationNowIfNeeded = async (waitForMessageSent = false) =>

@ -249,6 +249,7 @@ export interface ReduxConversationType {
isTyping?: boolean;
isBlocked?: boolean;
isHidden: boolean;
isKickedFromGroup?: boolean;
subscriberCount?: number;
left?: boolean;

@ -1,14 +1,13 @@
import { Data } from '../../../ts/data/data';
import { AdvancedSearchOptions, SearchOptions } from '../../types/Search';
import { cleanSearchTerm } from '../../util/cleanSearchTerm';
import { Data } from '../../../ts/data/data';
import { ReduxConversationType } from './conversations';
import { PubKey } from '../../session/types';
import _ from 'lodash';
import { getConversationController } from '../../session/conversations';
import { MessageResultProps } from '../../components/search/MessageSearchResults';
import { UserUtils } from '../../session/utils';
import { ConversationTypeEnum } from '../../models/conversationAttributes';
import { PubKey } from '../../session/types';
import { UserUtils } from '../../session/utils';
import { ReduxConversationType } from './conversations';
// State
@ -236,14 +235,11 @@ async function queryConversationsAndContacts(providedQuery: string, options: Sea
}
// Inject synthetic Note to Self entry if query matches localized 'Note to Self'
if (noteToSelf.indexOf(providedQuery.toLowerCase()) !== -1) {
const ourConvo = getConversationController().get(ourNumber);
if (ourConvo && ourConvo.isActive()) {
// ensure that we don't have duplicates in our results
contacts = contacts.filter(id => id !== ourNumber);
conversations = conversations.filter(id => id !== ourNumber);
// ensure that we don't have duplicates in our results
contacts = contacts.filter(id => id !== ourNumber);
conversations = conversations.filter(id => id !== ourNumber);
contacts.unshift(ourNumber);
}
contacts.unshift(ourNumber);
}
return { conversations, contacts };

@ -354,7 +354,8 @@ export const _getLeftPaneLists = (
conversation.activeAt !== undefined &&
conversation.type === ConversationTypeEnum.PRIVATE &&
conversation.isApproved &&
!conversation.isBlocked
!conversation.isBlocked &&
!conversation.isHidden
) {
directConversations.push(conversation);
}

@ -41,6 +41,7 @@ describe('state/selectors/conversations', () => {
members: [],
expireTimer: 0,
isPinned: false,
isHidden: false,
},
id2: {
id: 'id2',
@ -70,6 +71,7 @@ describe('state/selectors/conversations', () => {
members: [],
expireTimer: 0,
isPinned: false,
isHidden: false,
},
id3: {
id: 'id3',
@ -99,6 +101,7 @@ describe('state/selectors/conversations', () => {
members: [],
expireTimer: 0,
isPinned: false,
isHidden: false,
},
id4: {
id: 'id4',
@ -128,6 +131,7 @@ describe('state/selectors/conversations', () => {
lastMessage: undefined,
members: [],
isPinned: false,
isHidden: false,
},
id5: {
id: 'id5',
@ -157,6 +161,7 @@ describe('state/selectors/conversations', () => {
lastMessage: undefined,
members: [],
isPinned: false,
isHidden: false,
},
};
const comparator = _getConversationComparator(i18n);
@ -203,6 +208,7 @@ describe('state/selectors/conversations', () => {
isPinned: false,
hasNickname: false,
isPublic: false,
isHidden: false,
},
id2: {
id: 'id2',
@ -233,6 +239,7 @@ describe('state/selectors/conversations', () => {
isPinned: false,
hasNickname: false,
isPublic: false,
isHidden: false,
},
id3: {
id: 'id3',
@ -263,6 +270,7 @@ describe('state/selectors/conversations', () => {
isPinned: true,
hasNickname: false,
isPublic: false,
isHidden: false,
},
id4: {
id: 'id4',
@ -292,6 +300,7 @@ describe('state/selectors/conversations', () => {
isPinned: true,
hasNickname: false,
isPublic: false,
isHidden: false,
},
id5: {
id: 'id5',
@ -322,6 +331,7 @@ describe('state/selectors/conversations', () => {
isPinned: false,
hasNickname: false,
isPublic: false,
isHidden: false,
},
};
const comparator = _getConversationComparator(i18n);

@ -11,7 +11,7 @@ describe('SyncUtils', () => {
});
describe('syncConfigurationIfNeeded', () => {
it('sync if last sync undefined', () => {
it.skip('sync if last sync undefined', () => {
// TestUtils.stubData('getItemById').resolves(undefined);
// sandbox.stub(ConversationController, 'getConversations').returns([]);
// const getCurrentConfigurationMessageSpy = sandbox.spy(MessageUtils, 'getCurrentConfigurationMessage');

@ -70,7 +70,7 @@ describe('BlockedNumberController', () => {
const primary = TestUtils.generateFakePubKey();
memoryDB.blocked = [primary.key];
await BlockedNumberController.unblock(primary);
await BlockedNumberController.unblockAll([primary.key]);
const blockedNumbers = BlockedNumberController.getBlockedNumbers();
expect(blockedNumbers).to.be.empty;
@ -82,7 +82,7 @@ describe('BlockedNumberController', () => {
const another = TestUtils.generateFakePubKey();
memoryDB.blocked = [pubKey.key, another.key];
await BlockedNumberController.unblock(pubKey);
await BlockedNumberController.unblockAll([pubKey.key]);
const blockedNumbers = BlockedNumberController.getBlockedNumbers();
expect(blockedNumbers).to.have.lengthOf(1);

@ -1,4 +1,7 @@
import { isEmpty, isEqual } from 'lodash';
import { ContactInfo } from 'session_util_wrapper';
import { OpenGroupRequestCommonType } from '../session/apis/open_group_api/opengroupV2/ApiUtil';
import { fromHexToArray } from '../session/utils/String';
import { ConfigWrapperObjectTypes } from '../webworker/workers/browser/libsession_worker_functions';
/**
@ -105,3 +108,54 @@ export type AttachmentDownloadMessageDetails = {
isOpenGroupV2: boolean;
openGroupV2Details: OpenGroupRequestCommonType | undefined;
};
/**
* This function returns a contactInfo for the wrapper to understand from the DB values.
* Created in this file so we can reuse it during the migration (node side), and from the renderer side
*/
export function getContactInfoFromDBValues({
id,
dbApproved,
dbApprovedMe,
dbBlocked,
dbName,
dbNickname,
hidden,
isPinned,
dbProfileUrl,
dbProfileKey,
}: {
id: string;
dbApproved: boolean;
dbApprovedMe: boolean;
dbBlocked: boolean;
hidden: boolean;
dbNickname: string | undefined;
dbName: string | undefined;
isPinned: boolean;
dbProfileUrl: string | undefined;
dbProfileKey: string | undefined;
}): ContactInfo {
const wrapperContact: ContactInfo = {
id,
approved: !!dbApproved,
approvedMe: !!dbApprovedMe,
blocked: !!dbBlocked,
hidden: !!hidden,
priority: !!isPinned ? 1 : 0, // TODO the priority handling is not that simple
nickname: dbNickname,
name: dbName,
};
if (
wrapperContact.profilePicture?.url !== dbProfileUrl ||
!isEqual(wrapperContact.profilePicture?.key, dbProfileKey)
) {
wrapperContact.profilePicture = {
url: dbProfileUrl || null,
key: dbProfileKey && !isEmpty(dbProfileKey) ? fromHexToArray(dbProfileKey) : null,
};
}
return wrapperContact;
}

@ -42,22 +42,6 @@ export class BlockedNumberController {
}
}
/**
* Unblock a user.
* This will only unblock the primary device of the user.
*
* @param user The user to unblock.
*/
public static async unblock(user: string | PubKey): Promise<void> {
await this.load();
const toUnblock = PubKey.cast(user);
if (this.blockedNumbers.has(toUnblock.key)) {
this.blockedNumbers.delete(toUnblock.key);
await this.saveToDB(BLOCKED_NUMBERS_ID, this.blockedNumbers);
}
}
/**
* Unblock all these users.
* This will only unblock the primary device of the user.
@ -97,7 +81,7 @@ export class BlockedNumberController {
if (blocked) {
return BlockedNumberController.block(user);
}
return BlockedNumberController.unblock(user);
return BlockedNumberController.unblockAll([PubKey.cast(user).key]);
}
public static getBlockedNumbers(): Array<string> {

Loading…
Cancel
Save