hydrogen-web/src/matrix/room/Room.js

733 lines
28 KiB
JavaScript
Raw Normal View History

2020-08-05 22:08:55 +05:30
/*
Copyright 2020 Bruno Windels <bruno@windels.cloud>
Licensed under the Apache License, Version 2.0 (the "License");
you may not use this file except in compliance with the License.
You may obtain a copy of the License at
http://www.apache.org/licenses/LICENSE-2.0
Unless required by applicable law or agreed to in writing, software
distributed under the License is distributed on an "AS IS" BASIS,
WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
See the License for the specific language governing permissions and
limitations under the License.
*/
2020-04-21 01:05:53 +05:30
import {EventEmitter} from "../../utils/EventEmitter.js";
2020-09-23 21:29:42 +05:30
import {RoomSummary} from "./RoomSummary.js";
import {SyncWriter} from "./timeline/persistence/SyncWriter.js";
import {GapWriter} from "./timeline/persistence/GapWriter.js";
import {Timeline} from "./timeline/Timeline.js";
import {FragmentIdComparer} from "./timeline/FragmentIdComparer.js";
import {SendQueue} from "./sending/SendQueue.js";
import {WrappedError} from "../error.js"
2020-08-19 20:28:19 +05:30
import {fetchOrLoadMembers} from "./members/load.js";
2020-08-19 19:59:54 +05:30
import {MemberList} from "./members/MemberList.js";
import {Heroes} from "./members/Heroes.js";
import {EventEntry} from "./timeline/entries/EventEntry.js";
import {ObservedEventMap} from "./ObservedEventMap.js";
import {AttachmentUpload} from "./AttachmentUpload.js";
import {DecryptionSource} from "../e2ee/common.js";
const EVENT_ENCRYPTED_TYPE = "m.room.encrypted";
2018-12-21 19:05:24 +05:30
export class Room extends EventEmitter {
constructor({roomId, storage, hsApi, mediaRepository, emitCollectionChange, pendingEvents, user, createRoomEncryption, getSyncToken, platform}) {
2019-02-21 04:18:16 +05:30
super();
this._roomId = roomId;
this._storage = storage;
this._hsApi = hsApi;
this._mediaRepository = mediaRepository;
2020-09-23 21:52:51 +05:30
this._summary = new RoomSummary(roomId);
this._fragmentIdComparer = new FragmentIdComparer([]);
2020-09-23 21:52:51 +05:30
this._syncWriter = new SyncWriter({roomId, fragmentIdComparer: this._fragmentIdComparer});
2019-02-21 04:18:16 +05:30
this._emitCollectionChange = emitCollectionChange;
this._sendQueue = new SendQueue({roomId, storage, hsApi, pendingEvents});
this._timeline = null;
this._user = user;
this._changedMembersDuringSync = null;
2020-08-31 12:24:27 +05:30
this._memberList = null;
2020-09-03 19:06:17 +05:30
this._createRoomEncryption = createRoomEncryption;
this._roomEncryption = null;
this._getSyncToken = getSyncToken;
this._platform = platform;
this._observedEvents = null;
2020-09-23 21:52:51 +05:30
}
2018-12-21 19:05:24 +05:30
2021-03-02 19:59:35 +05:30
async _getRetryDecryptEntriesForKey(roomKey, txn) {
const retryEventIds = await this._roomEncryption.getEventIdsForMissingKey(roomKey, txn);
const retryEntries = [];
if (retryEventIds) {
for (const eventId of retryEventIds) {
const storageEntry = await txn.timelineEvents.getByEventId(this._roomId, eventId);
if (storageEntry) {
retryEntries.push(new EventEntry(storageEntry, this._fragmentIdComparer));
}
}
}
2021-03-02 19:59:35 +05:30
return retryEntries;
2020-09-22 21:52:37 +05:30
}
2021-03-02 19:59:35 +05:30
/**
* Used for keys received from other sources than sync, like key backup.
* @internal
* @param {RoomKey} roomKey
* @return {Promise}
*/
async notifyRoomKey(roomKey) {
if (!this._roomEncryption) {
return;
}
2021-03-02 19:59:35 +05:30
const txn = this._storage.readTxn([
this._storage.storeNames.timelineEvents,
this._storage.storeNames.inboundGroupSessions,
2021-03-02 19:59:35 +05:30
]);
const retryEntries = this._getRetryDecryptEntriesForKey(roomKey, txn);
if (retryEntries.length) {
const decryptRequest = this._decryptEntries(DecryptionSource.Retry, retryEntries, txn);
// this will close txn while awaiting decryption
await decryptRequest.complete();
this._timeline?.replaceEntries(retryEntries);
// we would ideally write the room summary in the same txn as the groupSessionDecryptions in the
// _decryptEntries entries and could even know which events have been decrypted for the first
// time from DecryptionChanges.write and only pass those to the summary. As timeline changes
// are not essential to the room summary, it's fine to write this in a separate txn for now.
const changes = this._summary.data.applyTimelineEntries(retryEntries, false, false);
if (await this._summary.writeAndApplyData(changes, this._storage)) {
this._emitUpdate();
}
}
}
_setEncryption(roomEncryption) {
if (roomEncryption && !this._roomEncryption) {
this._roomEncryption = roomEncryption;
this._sendQueue.enableEncryption(this._roomEncryption);
2020-09-04 19:57:39 +05:30
if (this._timeline) {
this._timeline.enableEncryption(this._decryptEntries.bind(this, DecryptionSource.Timeline));
2020-09-04 19:57:39 +05:30
}
}
}
/**
* Used for decrypting when loading/filling the timeline, and retrying decryption,
* not during sync, where it is split up during the multiple phases.
*/
2020-09-10 20:10:30 +05:30
_decryptEntries(source, entries, inboundSessionTxn = null) {
const request = new DecryptionRequest(async r => {
if (!inboundSessionTxn) {
inboundSessionTxn = this._storage.readTxn([this._storage.storeNames.inboundGroupSessions]);
2020-09-10 20:10:30 +05:30
}
if (r.cancelled) return;
const events = entries.filter(entry => {
return entry.eventType === EVENT_ENCRYPTED_TYPE;
}).map(entry => entry.event);
r.preparation = await this._roomEncryption.prepareDecryptAll(events, null, source, inboundSessionTxn);
2020-09-10 20:10:30 +05:30
if (r.cancelled) return;
const changes = await r.preparation.decrypt();
r.preparation = null;
if (r.cancelled) return;
const stores = [this._storage.storeNames.groupSessionDecryptions];
const isTimelineOpen = this._isTimelineOpen;
2020-09-10 20:10:30 +05:30
if (isTimelineOpen) {
// read to fetch devices if timeline is open
stores.push(this._storage.storeNames.deviceIdentities);
}
const writeTxn = this._storage.readWriteTxn(stores);
2020-09-10 20:10:30 +05:30
let decryption;
try {
decryption = await changes.write(writeTxn);
if (isTimelineOpen) {
await decryption.verifySenders(writeTxn);
}
2020-09-10 20:10:30 +05:30
} catch (err) {
writeTxn.abort();
throw err;
}
await writeTxn.complete();
2021-02-23 23:52:25 +05:30
// TODO: log decryption errors here
2020-09-10 20:10:30 +05:30
decryption.applyToEntries(entries);
if (this._observedEvents) {
this._observedEvents.updateEvents(entries);
}
2020-09-10 20:10:30 +05:30
});
return request;
}
async prepareSync(roomResponse, membership, newKeys, txn, log) {
2021-02-17 23:15:04 +05:30
log.set("id", this.id);
if (newKeys) {
log.set("newKeys", newKeys.length);
}
const summaryChanges = this._summary.data.applySyncResponse(roomResponse, membership)
let roomEncryption = this._roomEncryption;
// encryption is enabled in this sync
if (!roomEncryption && summaryChanges.encryption) {
2021-02-17 23:15:04 +05:30
log.set("enableEncryption", true);
roomEncryption = this._createRoomEncryption(this, summaryChanges.encryption);
}
let retryEntries;
let decryptPreparation;
if (roomEncryption) {
// also look for events in timeline here
let events = roomResponse?.timeline?.events || [];
2021-03-02 19:59:35 +05:30
// when new keys arrive, also see if any events that can now be retried to decrypt
if (newKeys) {
const entriesPerKey = await Promise.all(newKeys.map(key => this._getRetryDecryptEntriesForKey(key, txn)));
retryEntries = entriesPerKey.reduce((allEntries, entries) => allEntries.concat(entries), []);
// If we have the timeline open, see if there are more entries for the new keys
// as we only store missing session for synced and not backfilled events.
// We want to decrypt all events we can though if the user is looking
// at them given the timeline is open
if (this._timeline) {
let retryTimelineEntries = this._roomEncryption.filterEventEntriesForKeys(this._timeline.remoteEntries, newKeys);
// filter out any entries already in retryEntries so we don't decrypt them twice
const existingIds = new Set(retryEntries.map(e => e.id));
retryTimelineEntries = retryTimelineEntries.filter(e => !existingIds.has(e.id))
// make copies so we don't modify the original entry before the afterSync stage
retryEntries = retryTimelineEntries.map(e => e.clone());
}
if (retryEntries.length) {
log.set("retry", retryEntries.length);
events = events.concat(retryEntries.map(entry => entry.event));
}
}
const eventsToDecrypt = events.filter(event => {
return event?.type === EVENT_ENCRYPTED_TYPE;
});
if (eventsToDecrypt.length) {
decryptPreparation = await roomEncryption.prepareDecryptAll(
eventsToDecrypt, newKeys, DecryptionSource.Sync, txn);
}
}
return {
roomEncryption,
summaryChanges,
decryptPreparation,
decryptChanges: null,
retryEntries
};
}
2021-02-17 23:15:04 +05:30
async afterPrepareSync(preparation, parentLog) {
if (preparation.decryptPreparation) {
2021-03-02 19:59:35 +05:30
await parentLog.wrap("decrypt", async log => {
2021-02-17 23:15:04 +05:30
log.set("id", this.id);
preparation.decryptChanges = await preparation.decryptPreparation.decrypt();
preparation.decryptPreparation = null;
}, parentLog.level.Detail);
}
}
2020-08-19 20:28:28 +05:30
/** @package */
async writeSync(roomResponse, isInitialSync, {summaryChanges, decryptChanges, roomEncryption, retryEntries}, txn, log) {
2021-02-17 23:15:04 +05:30
log.set("id", this.id);
2020-09-23 21:52:51 +05:30
const {entries, newLiveKey, memberChanges} =
await log.wrap("syncWriter", log => this._syncWriter.writeSync(roomResponse, txn, log), log.level.Detail);
if (decryptChanges) {
const decryption = await decryptChanges.write(txn);
2021-03-03 01:59:32 +05:30
log.set("decryptionResults", decryption.results.size);
log.set("decryptionErrors", decryption.errors.size);
if (this._isTimelineOpen) {
await decryption.verifySenders(txn);
}
if (retryEntries?.length) {
2021-03-02 19:59:35 +05:30
// prepend the retried entries, as we know they are older
// (not that it should matter much for the summary)
entries.unshift(...retryEntries);
}
decryption.applyToEntries(entries);
}
2021-03-03 01:59:32 +05:30
log.set("entries", entries.length);
let shouldFlushKeyShares = false;
// pass member changes to device tracker
if (roomEncryption && this.isTrackingMembers && memberChanges?.size) {
shouldFlushKeyShares = await roomEncryption.writeMemberChanges(memberChanges, txn);
log.set("shouldFlushKeyShares", shouldFlushKeyShares);
}
// also apply (decrypted) timeline entries to the summary changes
summaryChanges = summaryChanges.applyTimelineEntries(
entries, isInitialSync, !this._isTimelineOpen, this._user.id);
// write summary changes, and unset if nothing was actually changed
summaryChanges = this._summary.writeData(summaryChanges, txn);
2021-03-03 01:59:32 +05:30
if (summaryChanges) {
log.set("summaryChanges", summaryChanges.diff(this._summary.data));
}
// fetch new members while we have txn open,
// but don't make any in-memory changes yet
let heroChanges;
if (summaryChanges?.needsHeroes) {
// room name disappeared, open heroes
if (!this._heroes) {
this._heroes = new Heroes(this._roomId);
}
heroChanges = await this._heroes.calculateChanges(summaryChanges.heroes, memberChanges, txn);
}
let removedPendingEvents;
if (Array.isArray(roomResponse.timeline?.events)) {
removedPendingEvents = this._sendQueue.removeRemoteEchos(roomResponse.timeline.events, txn, log);
}
return {
summaryChanges,
roomEncryption,
newAndUpdatedEntries: entries,
newLiveKey,
removedPendingEvents,
memberChanges,
heroChanges,
shouldFlushKeyShares,
};
}
2020-09-08 18:09:33 +05:30
/**
* @package
* Called with the changes returned from `writeSync` to apply them and emit changes.
* No storage or network operations should be done here.
*/
afterSync({summaryChanges, newAndUpdatedEntries, newLiveKey, removedPendingEvents, memberChanges, heroChanges, roomEncryption}, log) {
2021-02-17 23:15:04 +05:30
log.set("id", this.id);
2020-03-15 01:19:15 +05:30
this._syncWriter.afterSync(newLiveKey);
this._setEncryption(roomEncryption);
if (memberChanges.size) {
if (this._changedMembersDuringSync) {
for (const [userId, memberChange] of memberChanges.entries()) {
this._changedMembersDuringSync.set(userId, memberChange.member);
}
}
if (this._memberList) {
this._memberList.afterSync(memberChanges);
}
}
let emitChange = false;
if (summaryChanges) {
2020-06-27 02:56:24 +05:30
this._summary.applyChanges(summaryChanges);
if (!this._summary.data.needsHeroes) {
this._heroes = null;
}
emitChange = true;
}
if (this._heroes && heroChanges) {
const oldName = this.name;
this._heroes.applyChanges(heroChanges, this._summary.data);
if (oldName !== this.name) {
emitChange = true;
}
}
if (emitChange) {
2020-09-14 20:03:43 +05:30
this._emitUpdate();
2019-02-21 04:18:16 +05:30
}
if (this._timeline) {
this._timeline.appendLiveEntries(newAndUpdatedEntries);
}
if (this._observedEvents) {
this._observedEvents.updateEvents(newAndUpdatedEntries);
}
if (removedPendingEvents) {
this._sendQueue.emitRemovals(removedPendingEvents);
}
2020-09-23 21:52:51 +05:30
}
2018-12-21 19:05:24 +05:30
needsAfterSyncCompleted({shouldFlushKeyShares}) {
return shouldFlushKeyShares;
}
/**
* Only called if the result of writeSync had `needsAfterSyncCompleted` set.
* Can be used to do longer running operations that resulted from the last sync,
* like network operations.
*/
2021-02-17 23:15:04 +05:30
async afterSyncCompleted(changes, log) {
log.set("id", this.id);
if (this._roomEncryption) {
2021-02-23 23:52:25 +05:30
await this._roomEncryption.flushPendingRoomKeyShares(this._hsApi, null, log);
}
}
2020-08-19 20:28:28 +05:30
/** @package */
2021-02-23 23:52:25 +05:30
start(pendingOperations, parentLog) {
if (this._roomEncryption) {
2021-02-23 23:52:25 +05:30
const roomKeyShares = pendingOperations?.get("share_room_key");
if (roomKeyShares) {
// if we got interrupted last time sending keys to newly joined members
parentLog.wrapDetached("flush room keys", log => {
log.set("id", this.id);
return this._roomEncryption.flushPendingRoomKeyShares(this._hsApi, roomKeyShares, log);
});
}
}
2021-02-23 23:52:25 +05:30
this._sendQueue.resumeSending(parentLog);
2019-07-27 02:10:39 +05:30
}
2020-08-19 20:28:28 +05:30
/** @package */
2021-02-23 23:52:25 +05:30
async load(summary, txn, log) {
log.set("id", this.id);
try {
this._summary.load(summary);
if (this._summary.data.encryption) {
const roomEncryption = this._createRoomEncryption(this, this._summary.data.encryption);
this._setEncryption(roomEncryption);
2020-09-03 19:06:17 +05:30
}
// need to load members for name?
if (this._summary.data.needsHeroes) {
this._heroes = new Heroes(this._roomId);
const changes = await this._heroes.calculateChanges(this._summary.data.heroes, [], txn);
this._heroes.applyChanges(changes, this._summary.data);
}
2021-02-23 23:52:25 +05:30
return this._syncWriter.load(txn, log);
} catch (err) {
throw new WrappedError(`Could not load room ${this._roomId}`, err);
}
2020-09-23 21:52:51 +05:30
}
2019-02-27 03:15:58 +05:30
2020-08-19 20:28:28 +05:30
/** @public */
2021-02-23 23:52:59 +05:30
sendEvent(eventType, content, attachments, log = null) {
this._platform.logger.wrapOrRun(log, "send", log => {
log.set("id", this.id);
return this._sendQueue.enqueueEvent(eventType, content, attachments, log);
});
}
/** @public */
2021-02-23 23:52:59 +05:30
async ensureMessageKeyIsShared(log = null) {
if (!this._roomEncryption) {
return;
}
return this._platform.logger.wrapOrRun(log, "ensureMessageKeyIsShared", log => {
log.set("id", this.id);
return this._roomEncryption.ensureMessageKeyIsShared(this._hsApi, log);
});
2020-11-07 04:13:02 +05:30
}
2020-08-19 20:28:28 +05:30
/** @public */
2021-02-23 23:52:59 +05:30
async loadMemberList(log = null) {
if (this._memberList) {
2020-08-31 19:40:18 +05:30
// TODO: also await fetchOrLoadMembers promise here
this._memberList.retain();
return this._memberList;
} else {
2020-08-19 20:28:19 +05:30
const members = await fetchOrLoadMembers({
2020-08-19 20:14:09 +05:30
summary: this._summary,
roomId: this._roomId,
hsApi: this._hsApi,
storage: this._storage,
syncToken: this._getSyncToken(),
2020-08-19 20:14:09 +05:30
// to handle race between /members and /sync
setChangedMembersMap: map => this._changedMembersDuringSync = map,
2021-02-23 23:52:59 +05:30
log,
}, this._platform.logger);
this._memberList = new MemberList({
members,
closeCallback: () => { this._memberList = null; }
});
return this._memberList;
2020-06-27 02:56:24 +05:30
}
}
2020-03-22 04:10:40 +05:30
/** @public */
fillGap(fragmentEntry, amount, log = null) {
// TODO move some/all of this out of Room
return this._platform.logger.wrapOrRun(log, "fillGap", async log => {
2021-02-24 15:52:07 +05:30
log.set("id", this.id);
log.set("fragment", fragmentEntry.fragmentId);
log.set("dir", fragmentEntry.direction.asApiString());
if (fragmentEntry.edgeReached) {
2021-02-24 15:52:07 +05:30
log.set("edgeReached", true);
return;
}
const response = await this._hsApi.messages(this._roomId, {
from: fragmentEntry.token,
dir: fragmentEntry.direction.asApiString(),
limit: amount,
filter: {
lazy_load_members: true,
include_redundant_members: true,
}
}, {log}).response();
const txn = this._storage.readWriteTxn([
this._storage.storeNames.pendingEvents,
this._storage.storeNames.timelineEvents,
this._storage.storeNames.timelineFragments,
]);
let removedPendingEvents;
let gapResult;
try {
// detect remote echos of pending messages in the gap
removedPendingEvents = this._sendQueue.removeRemoteEchos(response.chunk, txn, log);
// write new events into gap
const gapWriter = new GapWriter({
roomId: this._roomId,
storage: this._storage,
fragmentIdComparer: this._fragmentIdComparer,
});
gapResult = await gapWriter.writeFragmentFill(fragmentEntry, response, txn, log);
} catch (err) {
txn.abort();
throw err;
}
await txn.complete();
if (this._roomEncryption) {
const decryptRequest = this._decryptEntries(DecryptionSource.Timeline, gapResult.entries);
await decryptRequest.complete();
}
// once txn is committed, update in-memory state & emit events
for (const fragment of gapResult.fragments) {
this._fragmentIdComparer.add(fragment);
}
if (removedPendingEvents) {
this._sendQueue.emitRemovals(removedPendingEvents);
}
if (this._timeline) {
this._timeline.addGapEntries(gapResult.entries);
}
});
2020-03-22 04:10:40 +05:30
}
2020-08-19 20:28:28 +05:30
/** @public */
2019-02-27 03:15:58 +05:30
get name() {
if (this._heroes) {
return this._heroes.roomName;
}
const summaryData = this._summary.data;
if (summaryData.name) {
return summaryData.name;
}
if (summaryData.canonicalAlias) {
return summaryData.canonicalAlias;
}
return null;
2019-02-27 03:15:58 +05:30
}
2020-08-19 20:28:28 +05:30
/** @public */
get id() {
return this._roomId;
}
2020-08-20 21:02:55 +05:30
get avatarUrl() {
if (this._summary.data.avatarUrl) {
return this._summary.data.avatarUrl;
} else if (this._heroes) {
return this._heroes.roomAvatarUrl;
}
return null;
2020-08-20 21:02:55 +05:30
}
2020-08-21 15:26:45 +05:30
get lastMessageTimestamp() {
return this._summary.data.lastMessageTimestamp;
2020-08-21 15:26:45 +05:30
}
get isUnread() {
return this._summary.data.isUnread;
2020-08-21 15:26:45 +05:30
}
get notificationCount() {
return this._summary.data.notificationCount;
2020-08-21 15:26:45 +05:30
}
2020-08-21 19:20:32 +05:30
get highlightCount() {
return this._summary.data.highlightCount;
2020-08-21 19:20:32 +05:30
}
2020-08-21 15:26:45 +05:30
2020-08-28 00:22:51 +05:30
get isLowPriority() {
const tags = this._summary.data.tags;
2020-08-28 00:22:51 +05:30
return !!(tags && tags['m.lowpriority']);
}
get isEncrypted() {
return !!this._summary.data.encryption;
}
get membership() {
return this._summary.data.membership;
}
enableSessionBackup(sessionBackup) {
this._roomEncryption?.enableSessionBackup(sessionBackup);
2021-03-03 02:00:00 +05:30
// TODO: do we really want to do this every time you open the app?
2021-03-02 19:59:35 +05:30
if (this._timeline) {
const timelineEvents = this._timeline.remoteEntries.filter(e => e.event).map(e => e.event);
this._roomEncryption.restoreMissingSessionsFromBackup(timelineEvents);
}
}
get isTrackingMembers() {
return this._summary.data.isTrackingMembers;
}
async _getLastEventId() {
const lastKey = this._syncWriter.lastMessageKey;
if (lastKey) {
const txn = this._storage.readTxn([
this._storage.storeNames.timelineEvents,
]);
const eventEntry = await txn.timelineEvents.get(this._roomId, lastKey);
return eventEntry?.event?.event_id;
}
}
get _isTimelineOpen() {
return !!this._timeline;
}
2020-09-14 20:03:43 +05:30
_emitUpdate() {
// once for event emitter listeners
this.emit("change");
// and once for collection listeners
this._emitCollectionChange(this);
}
2021-02-24 15:52:19 +05:30
async clearUnread(log = null) {
if (this.isUnread || this.notificationCount) {
2021-02-24 15:52:19 +05:30
return await this._platform.logger.wrapOrRun(log, "clearUnread", async log => {
log.set("id", this.id);
const txn = this._storage.readWriteTxn([
this._storage.storeNames.roomSummary,
]);
let data;
try {
data = this._summary.writeClearUnread(txn);
} catch (err) {
txn.abort();
throw err;
}
2021-02-24 15:52:19 +05:30
await txn.complete();
this._summary.applyChanges(data);
this._emitUpdate();
try {
const lastEventId = await this._getLastEventId();
if (lastEventId) {
await this._hsApi.receipt(this._roomId, "m.read", lastEventId);
}
} catch (err) {
// ignore ConnectionError
if (err.name !== "ConnectionError") {
throw err;
}
}
});
2020-08-21 15:26:10 +05:30
}
}
2020-08-19 20:28:28 +05:30
/** @public */
openTimeline(log = null) {
return this._platform.logger.wrapOrRun(log, "open timeline", async log => {
log.set("id", this.id);
if (this._timeline) {
throw new Error("not dealing with load race here for now");
}
this._timeline = new Timeline({
roomId: this.id,
storage: this._storage,
fragmentIdComparer: this._fragmentIdComparer,
pendingEvents: this._sendQueue.pendingEvents,
closeCallback: () => {
this._timeline = null;
if (this._roomEncryption) {
this._roomEncryption.notifyTimelineClosed();
}
},
user: this._user,
clock: this._platform.clock,
logger: this._platform.logger,
});
if (this._roomEncryption) {
this._timeline.enableEncryption(this._decryptEntries.bind(this, DecryptionSource.Timeline));
}
await this._timeline.load();
return this._timeline;
});
}
2020-05-09 23:32:08 +05:30
get mediaRepository() {
return this._mediaRepository;
2020-05-09 23:32:08 +05:30
}
/** @package */
writeIsTrackingMembers(value, txn) {
return this._summary.writeIsTrackingMembers(value, txn);
}
/** @package */
applyIsTrackingMembersChanges(changes) {
this._summary.applyChanges(changes);
}
2020-09-18 16:38:18 +05:30
observeEvent(eventId) {
if (!this._observedEvents) {
this._observedEvents = new ObservedEventMap(() => {
this._observedEvents = null;
});
}
let entry = null;
if (this._timeline) {
entry = this._timeline.getByEventId(eventId);
}
const observable = this._observedEvents.observe(eventId, entry);
if (!entry) {
// update in the background
this._readEventById(eventId).then(entry => {
observable.update(entry);
}).catch(err => {
console.warn(`could not load event ${eventId} from storage`, err);
});
}
return observable;
}
async _readEventById(eventId) {
let stores = [this._storage.storeNames.timelineEvents];
if (this.isEncrypted) {
stores.push(this._storage.storeNames.inboundGroupSessions);
}
const txn = this._storage.readTxn(stores);
const storageEntry = await txn.timelineEvents.getByEventId(this._roomId, eventId);
if (storageEntry) {
const entry = new EventEntry(storageEntry, this._fragmentIdComparer);
if (entry.eventType === EVENT_ENCRYPTED_TYPE) {
const request = this._decryptEntries(DecryptionSource.Timeline, [entry], txn);
await request.complete();
}
return entry;
}
}
2020-11-13 21:49:19 +05:30
createAttachment(blob, filename) {
return new AttachmentUpload({blob, filename, platform: this._platform});
}
2020-09-18 16:38:18 +05:30
dispose() {
this._roomEncryption?.dispose();
this._timeline?.dispose();
this._sendQueue.dispose();
2020-09-18 16:38:18 +05:30
}
2019-02-21 04:18:16 +05:30
}
2020-09-10 20:10:30 +05:30
class DecryptionRequest {
constructor(decryptFn) {
this._cancelled = false;
this.preparation = null;
this._promise = decryptFn(this);
}
complete() {
return this._promise;
}
get cancelled() {
return this._cancelled;
}
dispose() {
this._cancelled = true;
if (this.preparation) {
this.preparation.dispose();
}
}
}