1
0
mirror of https://github.com/bitwarden/browser synced 2025-12-14 07:13:32 +00:00

feat(inactive-user-server-notification): [PM-25130] Inactive User Server Notify (#16151)

* feat(inactive-user-server-notification): [PM-25130] Inactive User Server Notify - Adds in tests and feature for notifying inactive users.

* feat(inactive-user-server-notification): [PM-25130] Inactive User Server Notify - Added feature flag.

* fix(inactive-user-server-notification): [PM-25130] Inactive User Server Notify - Implemented trackedMerge.
This commit is contained in:
Patrick-Pimentel-Bitwarden
2025-09-03 17:01:45 -04:00
committed by GitHub
parent 363d6bea44
commit 281918a7b9
5 changed files with 482 additions and 25 deletions

View File

@@ -50,6 +50,7 @@ export enum FeatureFlag {
/* Platform */ /* Platform */
IpcChannelFramework = "ipc-channel-framework", IpcChannelFramework = "ipc-channel-framework",
InactiveUserServerNotification = "pm-25130-receive-push-notifications-for-inactive-users",
PushNotificationsWhenLocked = "pm-19388-push-notifications-when-locked", PushNotificationsWhenLocked = "pm-19388-push-notifications-when-locked",
} }
@@ -107,6 +108,7 @@ export const DefaultFeatureFlagValue = {
/* Platform */ /* Platform */
[FeatureFlag.IpcChannelFramework]: FALSE, [FeatureFlag.IpcChannelFramework]: FALSE,
[FeatureFlag.InactiveUserServerNotification]: FALSE,
[FeatureFlag.PushNotificationsWhenLocked]: FALSE, [FeatureFlag.PushNotificationsWhenLocked]: FALSE,
} satisfies Record<FeatureFlag, AllowedFeatureFlagTypes>; } satisfies Record<FeatureFlag, AllowedFeatureFlagTypes>;

View File

@@ -1,4 +1,4 @@
import { map } from "rxjs"; import { map, Observable, OperatorFunction, Subscription } from "rxjs";
/** /**
* An rxjs operator that extracts an object by ID from an array of objects. * An rxjs operator that extracts an object by ID from an array of objects.
@@ -19,3 +19,90 @@ export const getByIds = <TId, T extends { id: TId }>(ids: TId[]) => {
return objects.filter((o) => o.id && idSet.has(o.id)); return objects.filter((o) => o.id && idSet.has(o.id));
}); });
}; };
/**
* A merge-like operator that takes a Set of primitives and tracks if they've been
* seen before.
*
* An emitted set that looks like `["1", "2"]` will call selector and subscribe to the resulting
* observable for both `"1"` and `"2"` but if the next emission contains just `["1"]` then the
* subscription created for `"2"` will be unsubscribed from and the observable for `"1"` will be
* left alone. If the following emission a set like `["1", "2", "3"]` then the subscription for
* `"1"` is still left alone, `"2"` has a selector called for it again, and `"3"` has a selector
* called for it the first time. If an empty set is emitted then all items are unsubscribed from.
*
* Since this operator will keep track of an observable for `n` number of items given to it. It is
* smartest to only use this on sets that you know will only get so large.
*
* *IMPORTANT NOTE*
* This observable may not be super friendly to very quick emissions/near parallel execution.
*/
export function trackedMerge<T extends PropertyKey, E>(
selector: (value: T) => Observable<E>,
): OperatorFunction<Set<T>, E> {
return (source: Observable<Set<T>>) => {
// Setup a Map to track all inner subscriptions
const tracked: Map<T, Subscription> = new Map();
const cleanupTracked = () => {
for (const [, trackedSub] of tracked.entries()) {
trackedSub.unsubscribe();
}
tracked.clear();
};
return new Observable<E>((subscriber) => {
const sourceSub = source.subscribe({
next: (values) => {
// Loop through the subscriptions we are tracking, if the new list
// doesn't have any of those values, we should clean them up.
for (const value of tracked.keys()) {
if (!values.has(value)) {
// Tracked item is no longer in the list, cleanup
tracked.get(value)?.unsubscribe();
tracked.delete(value);
continue;
}
// We are already tracking something for this key, remove it
values.delete(value);
}
for (const newKey of values.keys()) {
// These are new entries, create and track subscription for them
tracked.set(
newKey,
/* eslint-disable-next-line rxjs/no-nested-subscribe */
selector(newKey).subscribe({
next: (innerValue) => {
subscriber.next(innerValue);
},
error: (err: unknown) => {
// TODO: Do I need to call cleanupTracked or will calling error run my teardown logic below?
subscriber.error(err);
},
complete: () => {
tracked.delete(newKey);
},
}),
);
}
},
error: (err: unknown) => {
// TODO: Do I need to call cleanupTracked or will calling error run my teardown logic below?
subscriber.error(err);
},
complete: () => {
// TODO: Do I need to call cleanupTracked or will calling complete run my teardown logic below?
cleanupTracked();
subscriber.complete();
},
});
return () => {
cleanupTracked();
sourceSub.unsubscribe();
};
});
};
}

View File

@@ -0,0 +1,313 @@
import { mock, MockProxy } from "jest-mock-extended";
import { BehaviorSubject, bufferCount, firstValueFrom, Subject, ObservedValueOf } from "rxjs";
// eslint-disable-next-line no-restricted-imports
import { LogoutReason } from "@bitwarden/auth/common";
import { AuthRequestAnsweringServiceAbstraction } from "@bitwarden/common/auth/abstractions/auth-request-answering/auth-request-answering.service.abstraction";
import { FeatureFlag } from "@bitwarden/common/enums/feature-flag.enum";
import { AccountService } from "../../../auth/abstractions/account.service";
import { AuthService } from "../../../auth/abstractions/auth.service";
import { AuthenticationStatus } from "../../../auth/enums/authentication-status";
import { NotificationType } from "../../../enums";
import { NotificationResponse } from "../../../models/response/notification.response";
import { UserId } from "../../../types/guid";
import { AppIdService } from "../../abstractions/app-id.service";
import { ConfigService } from "../../abstractions/config/config.service";
import { Environment, EnvironmentService } from "../../abstractions/environment.service";
import { LogService } from "../../abstractions/log.service";
import { MessagingService } from "../../abstractions/messaging.service";
import { DefaultServerNotificationsService } from "./default-server-notifications.service";
import { SignalRConnectionService } from "./signalr-connection.service";
import { WebPushConnectionService, WebPushConnector } from "./webpush-connection.service";
describe("DefaultServerNotificationsService (multi-user)", () => {
let syncService: any;
let appIdService: MockProxy<AppIdService>;
let environmentConfigurationService: MockProxy<EnvironmentService>;
let userLogoutCallback: jest.Mock<Promise<void>, [logoutReason: LogoutReason, userId: UserId]>;
let messagingService: MockProxy<MessagingService>;
let accountService: MockProxy<AccountService>;
let signalRNotificationConnectionService: MockProxy<SignalRConnectionService>;
let authService: MockProxy<AuthService>;
let webPushNotificationConnectionService: MockProxy<WebPushConnectionService>;
let authRequestAnsweringService: MockProxy<AuthRequestAnsweringServiceAbstraction>;
let configService: MockProxy<ConfigService>;
let activeUserAccount$: BehaviorSubject<ObservedValueOf<AccountService["activeAccount$"]>>;
let userAccounts$: BehaviorSubject<ObservedValueOf<AccountService["accounts$"]>>;
let environmentConfiguration$: BehaviorSubject<Environment>;
let authenticationStatusByUser: Map<UserId, BehaviorSubject<AuthenticationStatus>>;
let webPushSupportStatusByUser: Map<
UserId,
BehaviorSubject<
{ type: "supported"; service: WebPushConnector } | { type: "not-supported"; reason: string }
>
>;
let connectionSubjectByUser: Map<UserId, Subject<any>>;
let defaultServerNotificationsService: DefaultServerNotificationsService;
const mockUserId1 = "user1" as UserId;
const mockUserId2 = "user2" as UserId;
beforeEach(() => {
syncService = {
fullSync: jest.fn().mockResolvedValue(undefined),
syncUpsertCipher: jest.fn().mockResolvedValue(undefined),
syncDeleteCipher: jest.fn().mockResolvedValue(undefined),
syncUpsertFolder: jest.fn().mockResolvedValue(undefined),
syncDeleteFolder: jest.fn().mockResolvedValue(undefined),
syncUpsertSend: jest.fn().mockResolvedValue(undefined),
syncDeleteSend: jest.fn().mockResolvedValue(undefined),
};
appIdService = mock<AppIdService>();
appIdService.getAppId.mockResolvedValue("app-id");
environmentConfigurationService = mock<EnvironmentService>();
environmentConfiguration$ = new BehaviorSubject<Environment>({
getNotificationsUrl: () => "http://test.example.com",
} as Environment);
environmentConfigurationService.environment$ = environmentConfiguration$ as any;
// Ensure user-scoped environment lookups return the same test environment stream
environmentConfigurationService.getEnvironment$.mockImplementation(
(_userId: UserId) => environmentConfiguration$.asObservable() as any,
);
userLogoutCallback = jest.fn<Promise<void>, [LogoutReason, UserId]>();
messagingService = mock<MessagingService>();
accountService = mock<AccountService>();
activeUserAccount$ = new BehaviorSubject<ObservedValueOf<AccountService["activeAccount$"]>>(
null,
);
accountService.activeAccount$ = activeUserAccount$.asObservable();
userAccounts$ = new BehaviorSubject<ObservedValueOf<AccountService["accounts$"]>>({} as any);
accountService.accounts$ = userAccounts$.asObservable();
signalRNotificationConnectionService = mock<SignalRConnectionService>();
connectionSubjectByUser = new Map();
signalRNotificationConnectionService.connect$.mockImplementation(
(userId: UserId, _url: string) => {
if (!connectionSubjectByUser.has(userId)) {
connectionSubjectByUser.set(userId, new Subject<any>());
}
return connectionSubjectByUser.get(userId)!.asObservable();
},
);
authService = mock<AuthService>();
authenticationStatusByUser = new Map();
authService.authStatusFor$.mockImplementation((userId: UserId) => {
if (!authenticationStatusByUser.has(userId)) {
authenticationStatusByUser.set(
userId,
new BehaviorSubject<AuthenticationStatus>(AuthenticationStatus.LoggedOut),
);
}
return authenticationStatusByUser.get(userId)!.asObservable();
});
webPushNotificationConnectionService = mock<WebPushConnectionService>();
webPushSupportStatusByUser = new Map();
webPushNotificationConnectionService.supportStatus$.mockImplementation((userId: UserId) => {
if (!webPushSupportStatusByUser.has(userId)) {
webPushSupportStatusByUser.set(
userId,
new BehaviorSubject({ type: "not-supported", reason: "init" } as any),
);
}
return webPushSupportStatusByUser.get(userId)!.asObservable();
});
authRequestAnsweringService = mock<AuthRequestAnsweringServiceAbstraction>();
configService = mock<ConfigService>();
configService.getFeatureFlag$.mockImplementation((flag: FeatureFlag) => {
const flagValueByFlag: Partial<Record<FeatureFlag, boolean>> = {
[FeatureFlag.InactiveUserServerNotification]: true,
};
return new BehaviorSubject(flagValueByFlag[flag] ?? false) as any;
});
defaultServerNotificationsService = new DefaultServerNotificationsService(
mock<LogService>(),
syncService,
appIdService,
environmentConfigurationService,
userLogoutCallback,
messagingService,
accountService,
signalRNotificationConnectionService,
authService,
webPushNotificationConnectionService,
authRequestAnsweringService,
configService,
);
});
function setActiveUserAccount(userId: UserId | null) {
if (userId == null) {
activeUserAccount$.next(null);
} else {
activeUserAccount$.next({
id: userId,
email: "email",
name: "Test Name",
emailVerified: true,
});
}
}
function addUserAccount(userId: UserId) {
const currentAccounts = (userAccounts$.getValue() as Record<string, any>) ?? {};
userAccounts$.next({
...currentAccounts,
[userId]: { email: "email", name: "Test Name", emailVerified: true },
} as any);
}
function setUserUnlocked(userId: UserId) {
if (!authenticationStatusByUser.has(userId)) {
authenticationStatusByUser.set(
userId,
new BehaviorSubject<AuthenticationStatus>(AuthenticationStatus.LoggedOut),
);
}
authenticationStatusByUser.get(userId)!.next(AuthenticationStatus.Unlocked);
}
function setWebPushConnectorForUser(userId: UserId) {
const webPushConnector = mock<WebPushConnector>();
const notificationSubject = new Subject<NotificationResponse>();
webPushConnector.notifications$ = notificationSubject.asObservable();
if (!webPushSupportStatusByUser.has(userId)) {
webPushSupportStatusByUser.set(
userId,
new BehaviorSubject({ type: "supported", service: webPushConnector } as any),
);
} else {
webPushSupportStatusByUser
.get(userId)!
.next({ type: "supported", service: webPushConnector } as any);
}
return { webPushConnector, notificationSubject } as const;
}
it("merges notification streams from multiple users", async () => {
addUserAccount(mockUserId1);
addUserAccount(mockUserId2);
setUserUnlocked(mockUserId1);
setUserUnlocked(mockUserId2);
setActiveUserAccount(mockUserId1);
const user1WebPush = setWebPushConnectorForUser(mockUserId1);
const user2WebPush = setWebPushConnectorForUser(mockUserId2);
const twoNotifications = firstValueFrom(
defaultServerNotificationsService.notifications$.pipe(bufferCount(2)),
);
user1WebPush.notificationSubject.next(
new NotificationResponse({ type: NotificationType.SyncFolderCreate }),
);
user2WebPush.notificationSubject.next(
new NotificationResponse({ type: NotificationType.SyncFolderDelete }),
);
const notificationResults = await twoNotifications;
expect(notificationResults.length).toBe(2);
const [notification1, userA] = notificationResults[0];
const [notification2, userB] = notificationResults[1];
expect(userA === mockUserId1 || userA === mockUserId2).toBe(true);
expect(userB === mockUserId1 || userB === mockUserId2).toBe(true);
expect([NotificationType.SyncFolderCreate, NotificationType.SyncFolderDelete]).toContain(
notification1.type,
);
expect([NotificationType.SyncFolderCreate, NotificationType.SyncFolderDelete]).toContain(
notification2.type,
);
});
it("processes allowed multi-user notifications for non-active users (AuthRequest)", async () => {
addUserAccount(mockUserId1);
addUserAccount(mockUserId2);
setUserUnlocked(mockUserId1);
setUserUnlocked(mockUserId2);
setActiveUserAccount(mockUserId1);
// Force SignalR path for user2
if (!webPushSupportStatusByUser.has(mockUserId2)) {
webPushSupportStatusByUser.set(
mockUserId2,
new BehaviorSubject({ type: "not-supported", reason: "test" } as any),
);
} else {
webPushSupportStatusByUser
.get(mockUserId2)!
.next({ type: "not-supported", reason: "test" } as any);
}
// TODO: When PM-14943 goes in, uncomment
// authRequestAnsweringService.receivedPendingAuthRequest.mockResolvedValue(undefined as any);
const subscription = defaultServerNotificationsService.startListening();
// Emit via SignalR connect$ for user2
connectionSubjectByUser.get(mockUserId2)!.next({
type: "ReceiveMessage",
message: new NotificationResponse({
type: NotificationType.AuthRequest,
payload: { id: "auth-id-2", userId: mockUserId2 },
}),
});
// allow async queue to drain
await new Promise((resolve) => setTimeout(resolve, 0));
expect(messagingService.send).toHaveBeenCalledWith("openLoginApproval", {
notificationId: "auth-id-2",
});
// TODO: When PM-14943 goes in, uncomment
// expect(authRequestAnsweringService.receivedPendingAuthRequest).toHaveBeenCalledWith(
// mockUserId2,
// "auth-id-2",
// );
subscription.unsubscribe();
});
it("does not process restricted notification types for non-active users", async () => {
addUserAccount(mockUserId1);
addUserAccount(mockUserId2);
setUserUnlocked(mockUserId1);
setUserUnlocked(mockUserId2);
setActiveUserAccount(mockUserId1);
const user1WebPush = setWebPushConnectorForUser(mockUserId1);
const user2WebPush = setWebPushConnectorForUser(mockUserId2);
const subscription = defaultServerNotificationsService.startListening();
// Emit a folder create for non-active user (should be ignored)
user2WebPush.notificationSubject.next(
new NotificationResponse({ type: NotificationType.SyncFolderCreate }),
);
// Emit a folder create for active user (should be processed)
user1WebPush.notificationSubject.next(
new NotificationResponse({ type: NotificationType.SyncFolderCreate }),
);
await new Promise((resolve) => setTimeout(resolve, 0));
expect(syncService.syncUpsertFolder).toHaveBeenCalledTimes(1);
subscription.unsubscribe();
});
});

View File

@@ -1,11 +1,10 @@
import { mock, MockProxy } from "jest-mock-extended"; import { mock, MockProxy } from "jest-mock-extended";
import { BehaviorSubject, bufferCount, firstValueFrom, ObservedValueOf, Subject } from "rxjs"; import { BehaviorSubject, bufferCount, firstValueFrom, ObservedValueOf, of, Subject } from "rxjs";
// This import has been flagged as unallowed for this class. It may be involved in a circular dependency loop. // This import has been flagged as unallowed for this class. It may be involved in a circular dependency loop.
// eslint-disable-next-line no-restricted-imports // eslint-disable-next-line no-restricted-imports
import { LogoutReason } from "@bitwarden/auth/common"; import { LogoutReason } from "@bitwarden/auth/common";
import { AuthRequestAnsweringServiceAbstraction } from "@bitwarden/common/auth/abstractions/auth-request-answering/auth-request-answering.service.abstraction"; import { AuthRequestAnsweringServiceAbstraction } from "@bitwarden/common/auth/abstractions/auth-request-answering/auth-request-answering.service.abstraction";
import { FeatureFlag } from "@bitwarden/common/enums/feature-flag.enum";
import { awaitAsync } from "../../../../spec"; import { awaitAsync } from "../../../../spec";
import { Matrix } from "../../../../spec/matrix"; import { Matrix } from "../../../../spec/matrix";
@@ -45,6 +44,7 @@ describe("NotificationsService", () => {
let configService: MockProxy<ConfigService>; let configService: MockProxy<ConfigService>;
let activeAccount: BehaviorSubject<ObservedValueOf<AccountService["activeAccount$"]>>; let activeAccount: BehaviorSubject<ObservedValueOf<AccountService["activeAccount$"]>>;
let accounts: BehaviorSubject<ObservedValueOf<AccountService["accounts$"]>>;
let environment: BehaviorSubject<ObservedValueOf<EnvironmentService["environment$"]>>; let environment: BehaviorSubject<ObservedValueOf<EnvironmentService["environment$"]>>;
@@ -73,21 +73,23 @@ describe("NotificationsService", () => {
configService = mock<ConfigService>(); configService = mock<ConfigService>();
// For these tests, use the active-user implementation (feature flag disabled) // For these tests, use the active-user implementation (feature flag disabled)
configService.getFeatureFlag$.mockImplementation((flag: FeatureFlag) => { configService.getFeatureFlag$.mockImplementation(() => of(true));
const flagValueByFlag: Partial<Record<FeatureFlag, boolean>> = {
[FeatureFlag.PushNotificationsWhenLocked]: true,
};
return new BehaviorSubject(flagValueByFlag[flag] ?? false) as any;
});
activeAccount = new BehaviorSubject<ObservedValueOf<AccountService["activeAccount$"]>>(null); activeAccount = new BehaviorSubject<ObservedValueOf<AccountService["activeAccount$"]>>(null);
accountService.activeAccount$ = activeAccount.asObservable(); accountService.activeAccount$ = activeAccount.asObservable();
accounts = new BehaviorSubject<ObservedValueOf<AccountService["accounts$"]>>({} as any);
accountService.accounts$ = accounts.asObservable();
environment = new BehaviorSubject<ObservedValueOf<EnvironmentService["environment$"]>>({ environment = new BehaviorSubject<ObservedValueOf<EnvironmentService["environment$"]>>({
getNotificationsUrl: () => "https://notifications.bitwarden.com", getNotificationsUrl: () => "https://notifications.bitwarden.com",
} as Environment); } as Environment);
environmentService.environment$ = environment; environmentService.environment$ = environment;
// Ensure user-scoped environment lookups return the same test environment stream
environmentService.getEnvironment$.mockImplementation(
(_userId: UserId) => environment.asObservable() as any,
);
authStatusGetter = Matrix.autoMockMethod( authStatusGetter = Matrix.autoMockMethod(
authService.authStatusFor$, authService.authStatusFor$,
@@ -130,8 +132,14 @@ describe("NotificationsService", () => {
function emitActiveUser(userId: UserId | null) { function emitActiveUser(userId: UserId | null) {
if (userId == null) { if (userId == null) {
activeAccount.next(null); activeAccount.next(null);
accounts.next({} as any);
} else { } else {
activeAccount.next({ id: userId, email: "email", name: "Test Name", emailVerified: true }); activeAccount.next({ id: userId, email: "email", name: "Test Name", emailVerified: true });
const current = (accounts.getValue() as Record<string, any>) ?? {};
accounts.next({
...current,
[userId]: { email: "email", name: "Test Name", emailVerified: true },
} as any);
} }
} }

View File

@@ -17,8 +17,9 @@ import {
import { LogoutReason } from "@bitwarden/auth/common"; import { LogoutReason } from "@bitwarden/auth/common";
import { AuthRequestAnsweringServiceAbstraction } from "@bitwarden/common/auth/abstractions/auth-request-answering/auth-request-answering.service.abstraction"; import { AuthRequestAnsweringServiceAbstraction } from "@bitwarden/common/auth/abstractions/auth-request-answering/auth-request-answering.service.abstraction";
import { FeatureFlag } from "@bitwarden/common/enums/feature-flag.enum"; import { FeatureFlag } from "@bitwarden/common/enums/feature-flag.enum";
import { trackedMerge } from "@bitwarden/common/platform/misc";
import { AccountService } from "../../../auth/abstractions/account.service"; import { AccountInfo, AccountService } from "../../../auth/abstractions/account.service";
import { AuthService } from "../../../auth/abstractions/auth.service"; import { AuthService } from "../../../auth/abstractions/auth.service";
import { AuthenticationStatus } from "../../../auth/enums/authentication-status"; import { AuthenticationStatus } from "../../../auth/enums/authentication-status";
import { NotificationType } from "../../../enums"; import { NotificationType } from "../../../enums";
@@ -43,6 +44,10 @@ import { WebPushConnectionService } from "./webpush-connection.service";
export const DISABLED_NOTIFICATIONS_URL = "http://-"; export const DISABLED_NOTIFICATIONS_URL = "http://-";
export const AllowedMultiUserNotificationTypes = new Set<NotificationType>([
NotificationType.AuthRequest,
]);
export class DefaultServerNotificationsService implements ServerNotificationsService { export class DefaultServerNotificationsService implements ServerNotificationsService {
notifications$: Observable<readonly [NotificationResponse, UserId]>; notifications$: Observable<readonly [NotificationResponse, UserId]>;
@@ -62,21 +67,48 @@ export class DefaultServerNotificationsService implements ServerNotificationsSer
private readonly authRequestAnsweringService: AuthRequestAnsweringServiceAbstraction, private readonly authRequestAnsweringService: AuthRequestAnsweringServiceAbstraction,
private readonly configService: ConfigService, private readonly configService: ConfigService,
) { ) {
this.notifications$ = this.accountService.activeAccount$.pipe( this.notifications$ = this.configService
map((account) => account?.id), .getFeatureFlag$(FeatureFlag.InactiveUserServerNotification)
distinctUntilChanged(), .pipe(
switchMap((activeAccountId) => { distinctUntilChanged(),
if (activeAccountId == null) { switchMap((inactiveUserServerNotificationEnabled) => {
// We don't emit server-notifications for inactive accounts currently if (inactiveUserServerNotificationEnabled) {
return EMPTY; return this.accountService.accounts$.pipe(
} map((accounts: Record<UserId, AccountInfo>): Set<UserId> => {
const validUserIds = Object.entries(accounts)
.filter(
([_, accountInfo]) => accountInfo.email !== "" || accountInfo.emailVerified,
)
.map(([userId, _]) => userId as UserId);
return new Set(validUserIds);
}),
trackedMerge((id: UserId) => {
return this.userNotifications$(id as UserId).pipe(
map(
(notification: NotificationResponse) => [notification, id as UserId] as const,
),
);
}),
);
}
return this.userNotifications$(activeAccountId).pipe( return this.accountService.activeAccount$.pipe(
map((notification) => [notification, activeAccountId] as const), map((account) => account?.id),
); distinctUntilChanged(),
}), switchMap((activeAccountId) => {
share(), // Multiple subscribers should only create a single connection to the server if (activeAccountId == null) {
); // We don't emit server-notifications for inactive accounts currently
return EMPTY;
}
return this.userNotifications$(activeAccountId).pipe(
map((notification) => [notification, activeAccountId] as const),
);
}),
);
}),
share(), // Multiple subscribers should only create a single connection to the server
);
} }
/** /**
@@ -84,7 +116,7 @@ export class DefaultServerNotificationsService implements ServerNotificationsSer
* @param userId The user id of the user to get the push server notifications for. * @param userId The user id of the user to get the push server notifications for.
*/ */
private userNotifications$(userId: UserId) { private userNotifications$(userId: UserId) {
return this.environmentService.environment$.pipe( return this.environmentService.getEnvironment$(userId).pipe(
map((env) => env.getNotificationsUrl()), map((env) => env.getNotificationsUrl()),
distinctUntilChanged(), distinctUntilChanged(),
switchMap((notificationsUrl) => { switchMap((notificationsUrl) => {
@@ -171,6 +203,21 @@ export class DefaultServerNotificationsService implements ServerNotificationsSer
return; return;
} }
if (
await firstValueFrom(
this.configService.getFeatureFlag$(FeatureFlag.InactiveUserServerNotification),
)
) {
const activeAccountId = await firstValueFrom(
this.accountService.activeAccount$.pipe(map((a) => a?.id)),
);
const isActiveUser = activeAccountId === userId;
if (!isActiveUser && !AllowedMultiUserNotificationTypes.has(notification.type)) {
return;
}
}
switch (notification.type) { switch (notification.type) {
case NotificationType.SyncCipherCreate: case NotificationType.SyncCipherCreate:
case NotificationType.SyncCipherUpdate: case NotificationType.SyncCipherUpdate: