/*
- Copyright (C) 2015-2021 AsamK and contributors
+ Copyright (C) 2015-2022 AsamK and contributors
This program is free software: you can redistribute it and/or modify
it under the terms of the GNU General Public License as published by
*/
package org.asamk.signal.manager;
-import org.asamk.signal.manager.actions.HandleAction;
+import org.asamk.signal.manager.api.AttachmentInvalidException;
import org.asamk.signal.manager.api.Configuration;
import org.asamk.signal.manager.api.Device;
import org.asamk.signal.manager.api.Group;
import org.asamk.signal.manager.api.Identity;
import org.asamk.signal.manager.api.InactiveGroupLinkException;
import org.asamk.signal.manager.api.InvalidDeviceLinkException;
+import org.asamk.signal.manager.api.InvalidStickerException;
import org.asamk.signal.manager.api.Message;
+import org.asamk.signal.manager.api.NotPrimaryDeviceException;
import org.asamk.signal.manager.api.Pair;
import org.asamk.signal.manager.api.RecipientIdentifier;
import org.asamk.signal.manager.api.SendGroupMessageResults;
import org.asamk.signal.manager.api.SendMessageResult;
import org.asamk.signal.manager.api.SendMessageResults;
+import org.asamk.signal.manager.api.StickerPack;
+import org.asamk.signal.manager.api.StickerPackId;
+import org.asamk.signal.manager.api.StickerPackInvalidException;
+import org.asamk.signal.manager.api.StickerPackUrl;
import org.asamk.signal.manager.api.TypingAction;
import org.asamk.signal.manager.api.UnregisteredRecipientException;
import org.asamk.signal.manager.api.UpdateGroup;
+import org.asamk.signal.manager.api.UpdateProfile;
+import org.asamk.signal.manager.api.UserStatus;
import org.asamk.signal.manager.config.ServiceEnvironmentConfig;
import org.asamk.signal.manager.groups.GroupId;
import org.asamk.signal.manager.groups.GroupInviteLinkUrl;
import org.asamk.signal.manager.groups.GroupSendingNotAllowedException;
import org.asamk.signal.manager.groups.LastGroupAdminException;
import org.asamk.signal.manager.groups.NotAGroupMemberException;
-import org.asamk.signal.manager.helper.AttachmentHelper;
-import org.asamk.signal.manager.helper.ContactHelper;
-import org.asamk.signal.manager.helper.GroupHelper;
-import org.asamk.signal.manager.helper.GroupV2Helper;
-import org.asamk.signal.manager.helper.IdentityHelper;
-import org.asamk.signal.manager.helper.IncomingMessageHandler;
-import org.asamk.signal.manager.helper.PinHelper;
-import org.asamk.signal.manager.helper.PreKeyHelper;
-import org.asamk.signal.manager.helper.ProfileHelper;
-import org.asamk.signal.manager.helper.RecipientHelper;
-import org.asamk.signal.manager.helper.SendHelper;
-import org.asamk.signal.manager.helper.StorageHelper;
-import org.asamk.signal.manager.helper.SyncHelper;
-import org.asamk.signal.manager.helper.UnidentifiedAccessHelper;
-import org.asamk.signal.manager.jobs.Context;
+import org.asamk.signal.manager.helper.AccountFileUpdater;
+import org.asamk.signal.manager.helper.Context;
import org.asamk.signal.manager.storage.SignalAccount;
import org.asamk.signal.manager.storage.groups.GroupInfo;
import org.asamk.signal.manager.storage.identities.IdentityInfo;
-import org.asamk.signal.manager.storage.messageCache.CachedMessage;
-import org.asamk.signal.manager.storage.recipients.Contact;
import org.asamk.signal.manager.storage.recipients.Profile;
-import org.asamk.signal.manager.storage.recipients.RecipientAddress;
+import org.asamk.signal.manager.storage.recipients.Recipient;
import org.asamk.signal.manager.storage.recipients.RecipientId;
+import org.asamk.signal.manager.storage.stickerPacks.JsonStickerPack;
+import org.asamk.signal.manager.storage.stickerPacks.StickerPackStore;
import org.asamk.signal.manager.storage.stickers.Sticker;
-import org.asamk.signal.manager.storage.stickers.StickerPackId;
+import org.asamk.signal.manager.util.AttachmentUtils;
import org.asamk.signal.manager.util.KeyUtils;
import org.asamk.signal.manager.util.StickerUtils;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
-import org.whispersystems.libsignal.InvalidKeyException;
-import org.whispersystems.libsignal.ecc.ECPublicKey;
-import org.whispersystems.libsignal.util.guava.Optional;
import org.whispersystems.signalservice.api.SignalSessionLock;
import org.whispersystems.signalservice.api.messages.SignalServiceDataMessage;
-import org.whispersystems.signalservice.api.messages.SignalServiceEnvelope;
+import org.whispersystems.signalservice.api.messages.SignalServicePreview;
import org.whispersystems.signalservice.api.messages.SignalServiceReceiptMessage;
import org.whispersystems.signalservice.api.messages.SignalServiceTypingMessage;
import org.whispersystems.signalservice.api.push.ACI;
-import org.whispersystems.signalservice.api.push.exceptions.AuthorizationFailedException;
import org.whispersystems.signalservice.api.util.DeviceNameUtil;
import org.whispersystems.signalservice.api.util.InvalidNumberException;
import org.whispersystems.signalservice.api.util.PhoneNumberFormatter;
-import org.whispersystems.signalservice.api.websocket.WebSocketConnectionState;
-import org.whispersystems.signalservice.api.websocket.WebSocketUnavailableException;
-import org.whispersystems.signalservice.internal.util.DynamicCredentialsProvider;
import org.whispersystems.signalservice.internal.util.Hex;
import org.whispersystems.signalservice.internal.util.Util;
import java.io.File;
import java.io.IOException;
import java.net.URI;
-import java.net.URISyntaxException;
-import java.net.URLEncoder;
-import java.nio.charset.StandardCharsets;
import java.time.Duration;
import java.util.ArrayList;
import java.util.Collection;
import java.util.HashSet;
import java.util.List;
import java.util.Map;
+import java.util.Objects;
+import java.util.Optional;
import java.util.Set;
-import java.util.UUID;
import java.util.concurrent.ExecutorService;
import java.util.concurrent.Executors;
-import java.util.concurrent.TimeUnit;
-import java.util.concurrent.TimeoutException;
+import java.util.concurrent.atomic.AtomicInteger;
import java.util.concurrent.locks.ReentrantLock;
+import java.util.function.Function;
import java.util.stream.Collectors;
import java.util.stream.Stream;
-import io.reactivex.rxjava3.core.Observable;
-import io.reactivex.rxjava3.schedulers.Schedulers;
+import io.reactivex.rxjava3.disposables.CompositeDisposable;
-import static org.asamk.signal.manager.config.ServiceConfig.capabilities;
-
-public class ManagerImpl implements Manager {
+class ManagerImpl implements Manager {
private final static Logger logger = LoggerFactory.getLogger(ManagerImpl.class);
- private final SignalDependencies dependencies;
-
private SignalAccount account;
+ private final SignalDependencies dependencies;
+ private final Context context;
private final ExecutorService executor = Executors.newCachedThreadPool();
- private final ProfileHelper profileHelper;
- private final PinHelper pinHelper;
- private final StorageHelper storageHelper;
- private final SendHelper sendHelper;
- private final SyncHelper syncHelper;
- private final AttachmentHelper attachmentHelper;
- private final GroupHelper groupHelper;
- private final ContactHelper contactHelper;
- private final IncomingMessageHandler incomingMessageHandler;
- private final PreKeyHelper preKeyHelper;
- private final IdentityHelper identityHelper;
- private final RecipientHelper recipientHelper;
-
- private final Context context;
- private boolean hasCaughtUpWithOldMessages = false;
- private boolean ignoreAttachments = false;
-
private Thread receiveThread;
+ private boolean isReceivingSynchronous;
private final Set<ReceiveMessageHandler> weakHandlers = new HashSet<>();
private final Set<ReceiveMessageHandler> messageHandlers = new HashSet<>();
private final List<Runnable> closedListeners = new ArrayList<>();
- private boolean isReceivingSynchronous;
- private boolean needsToRetryFailedMessages = false;
+ private final List<Runnable> addressChangedListeners = new ArrayList<>();
+ private final CompositeDisposable disposable = new CompositeDisposable();
ManagerImpl(
SignalAccount account,
PathConfig pathConfig,
+ AccountFileUpdater accountFileUpdater,
ServiceEnvironmentConfig serviceEnvironmentConfig,
String userAgent
) {
this.account = account;
- final var credentialsProvider = new DynamicCredentialsProvider(account.getAci(),
- account.getAccount(),
- account.getPassword(),
- account.getDeviceId());
final var sessionLock = new SignalSessionLock() {
private final ReentrantLock LEGACY_LOCK = new ReentrantLock();
};
this.dependencies = new SignalDependencies(serviceEnvironmentConfig,
userAgent,
- credentialsProvider,
- account.getSignalProtocolStore(),
+ account.getCredentialsProvider(),
+ account.getSignalServiceDataStore(),
executor,
sessionLock);
final var avatarStore = new AvatarStore(pathConfig.avatarsPath());
final var attachmentStore = new AttachmentStore(pathConfig.attachmentsPath());
final var stickerPackStore = new StickerPackStore(pathConfig.stickerPacksPath());
- this.attachmentHelper = new AttachmentHelper(dependencies, attachmentStore);
- this.pinHelper = new PinHelper(dependencies.getKeyBackupService());
- final var unidentifiedAccessHelper = new UnidentifiedAccessHelper(account,
- dependencies,
- account::getProfileKey,
- this::getRecipientProfile);
- this.recipientHelper = new RecipientHelper(account, dependencies, serviceEnvironmentConfig);
- this.profileHelper = new ProfileHelper(account,
- dependencies,
- avatarStore,
- unidentifiedAccessHelper::getAccessFor,
- recipientHelper::resolveSignalServiceAddress);
- final GroupV2Helper groupV2Helper = new GroupV2Helper(profileHelper,
- account::getSelfRecipientId,
- dependencies.getGroupsV2Operations(),
- dependencies.getGroupsV2Api(),
- recipientHelper::resolveSignalServiceAddress);
- this.sendHelper = new SendHelper(account,
- dependencies,
- unidentifiedAccessHelper,
- recipientHelper::resolveSignalServiceAddress,
- account.getRecipientStore(),
- this::handleIdentityFailure,
- this::getGroupInfo,
- profileHelper,
- recipientHelper::refreshRegisteredUser);
- this.groupHelper = new GroupHelper(account,
- dependencies,
- attachmentHelper,
- sendHelper,
- groupV2Helper,
- avatarStore,
- recipientHelper::resolveSignalServiceAddress,
- account.getRecipientStore());
- this.storageHelper = new StorageHelper(account, dependencies, groupHelper, profileHelper);
- this.contactHelper = new ContactHelper(account);
- this.syncHelper = new SyncHelper(account,
- attachmentHelper,
- sendHelper,
- groupHelper,
- avatarStore,
- recipientHelper::resolveSignalServiceAddress);
- preKeyHelper = new PreKeyHelper(account, dependencies);
-
- this.context = new Context(account,
- dependencies,
- stickerPackStore,
- sendHelper,
- groupHelper,
- syncHelper,
- profileHelper,
- storageHelper,
- preKeyHelper);
- var jobExecutor = new JobExecutor(context);
-
- this.incomingMessageHandler = new IncomingMessageHandler(account,
- dependencies,
- account.getRecipientStore(),
- recipientHelper::resolveSignalServiceAddress,
- groupHelper,
- contactHelper,
- attachmentHelper,
- syncHelper,
- profileHelper::getRecipientProfile,
- jobExecutor);
- this.identityHelper = new IdentityHelper(account,
- dependencies,
- recipientHelper::resolveSignalServiceAddress,
- syncHelper,
- profileHelper);
+ this.context = new Context(account, new AccountFileUpdater() {
+ @Override
+ public void updateAccountIdentifiers(final String number, final ACI aci) {
+ accountFileUpdater.updateAccountIdentifiers(number, aci);
+ synchronized (addressChangedListeners) {
+ addressChangedListeners.forEach(Runnable::run);
+ }
+ }
+
+ @Override
+ public void removeAccount() {
+ accountFileUpdater.removeAccount();
+ }
+ }, dependencies, avatarStore, attachmentStore, stickerPackStore);
+ this.context.getAccountHelper().setUnregisteredListener(this::close);
+ this.context.getReceiveHelper().setAuthenticationFailureListener(this::close);
+ this.context.getReceiveHelper().setCaughtUpWithOldMessagesListener(() -> {
+ synchronized (this) {
+ this.notifyAll();
+ }
+ });
+ disposable.add(account.getIdentityKeyStore().getIdentityChanges().subscribe(recipientId -> {
+ logger.trace("Archiving old sessions for {}", recipientId);
+ account.getSessionStore().archiveSessions(recipientId);
+ account.getSenderKeyStore().deleteSharedWith(recipientId);
+ final var profile = account.getProfileStore().getProfile(recipientId);
+ if (profile != null) {
+ account.getProfileStore()
+ .storeProfile(recipientId,
+ Profile.newBuilder(profile)
+ .withUnidentifiedAccessMode(Profile.UnidentifiedAccessMode.UNKNOWN)
+ .withLastUpdateTimestamp(0)
+ .build());
+ }
+ }));
}
@Override
public String getSelfNumber() {
- return account.getAccount();
+ return account.getNumber();
}
- @Override
- public void checkAccountState() throws IOException {
- if (account.getLastReceiveTimestamp() == 0) {
- logger.info("The Signal protocol expects that incoming messages are regularly received.");
- } else {
- var diffInMilliseconds = System.currentTimeMillis() - account.getLastReceiveTimestamp();
- long days = TimeUnit.DAYS.convert(diffInMilliseconds, TimeUnit.MILLISECONDS);
- if (days > 7) {
- logger.warn(
- "Messages have been last received {} days ago. The Signal protocol expects that incoming messages are regularly received.",
- days);
- }
- }
- try {
- preKeyHelper.refreshPreKeysIfNecessary();
- if (account.getAci() == null) {
- account.setAci(ACI.parseOrNull(dependencies.getAccountManager().getWhoAmI().getAci()));
- }
- updateAccountAttributes(null);
- } catch (AuthorizationFailedException e) {
- account.setRegistered(false);
- throw e;
- }
+ void checkAccountState() throws IOException {
+ context.getAccountHelper().checkAccountState();
}
- /**
- * This is used for checking a set of phone numbers for registration on Signal
- *
- * @param numbers The set of phone number in question
- * @return A map of numbers to canonicalized number and uuid. If a number is not registered the uuid is null.
- * @throws IOException if it's unable to get the contacts to check if they're registered
- */
@Override
- public Map<String, Pair<String, UUID>> areUsersRegistered(Set<String> numbers) throws IOException {
+ public Map<String, UserStatus> getUserStatus(Set<String> numbers) throws IOException {
final var canonicalizedNumbers = numbers.stream().collect(Collectors.toMap(n -> n, n -> {
try {
- final var canonicalizedNumber = PhoneNumberFormatter.formatNumber(n, account.getAccount());
+ final var canonicalizedNumber = PhoneNumberFormatter.formatNumber(n, account.getNumber());
if (!canonicalizedNumber.equals(n)) {
logger.debug("Normalized number {} to {}.", n, canonicalizedNumber);
}
.stream()
.filter(s -> !s.isEmpty())
.collect(Collectors.toSet());
- final var registeredUsers = recipientHelper.getRegisteredUsers(canonicalizedNumbersSet);
+ final var registeredUsers = context.getRecipientHelper().getRegisteredUsers(canonicalizedNumbersSet);
return numbers.stream().collect(Collectors.toMap(n -> n, n -> {
final var number = canonicalizedNumbers.get(n);
final var aci = registeredUsers.get(number);
- return new Pair<>(number.isEmpty() ? null : number, aci == null ? null : aci.uuid());
+ final var profile = aci == null
+ ? null
+ : context.getProfileHelper()
+ .getRecipientProfile(account.getRecipientResolver().resolveRecipient(aci));
+ return new UserStatus(number.isEmpty() ? null : number,
+ aci == null ? null : aci.uuid(),
+ profile != null
+ && profile.getUnidentifiedAccessMode() == Profile.UnidentifiedAccessMode.UNRESTRICTED);
}));
}
@Override
public void updateAccountAttributes(String deviceName) throws IOException {
- final String encryptedDeviceName;
- if (deviceName == null) {
- encryptedDeviceName = account.getEncryptedDeviceName();
- } else {
- final var privateKey = account.getIdentityKeyPair().getPrivateKey();
- encryptedDeviceName = DeviceNameUtil.encryptDeviceName(deviceName, privateKey);
- account.setEncryptedDeviceName(encryptedDeviceName);
+ if (deviceName != null) {
+ context.getAccountHelper().setDeviceName(deviceName);
}
- dependencies.getAccountManager()
- .setAccountAttributes(encryptedDeviceName,
- null,
- account.getLocalRegistrationId(),
- true,
- null,
- account.getPinMasterKey() == null ? null : account.getPinMasterKey().deriveRegistrationLock(),
- account.getSelfUnidentifiedAccessKey(),
- account.isUnrestrictedUnidentifiedAccess(),
- capabilities,
- account.isDiscoverableByPhoneNumber());
+ context.getAccountHelper().updateAccountAttributes();
}
@Override
public Configuration getConfiguration() {
final var configurationStore = account.getConfigurationStore();
- return new Configuration(java.util.Optional.ofNullable(configurationStore.getReadReceipts()),
- java.util.Optional.ofNullable(configurationStore.getUnidentifiedDeliveryIndicators()),
- java.util.Optional.ofNullable(configurationStore.getTypingIndicators()),
- java.util.Optional.ofNullable(configurationStore.getLinkPreviews()));
+ return Configuration.from(configurationStore);
}
@Override
public void updateConfiguration(
Configuration configuration
- ) throws IOException, NotMasterDeviceException {
- if (!account.isMasterDevice()) {
- throw new NotMasterDeviceException();
+ ) throws NotPrimaryDeviceException {
+ if (!account.isPrimaryDevice()) {
+ throw new NotPrimaryDeviceException();
}
final var configurationStore = account.getConfigurationStore();
if (configuration.linkPreviews().isPresent()) {
configurationStore.setLinkPreviews(configuration.linkPreviews().get());
}
- syncHelper.sendConfigurationMessage();
+ context.getSyncHelper().sendConfigurationMessage();
}
- /**
- * @param givenName if null, the previous givenName will be kept
- * @param familyName if null, the previous familyName will be kept
- * @param about if null, the previous about text will be kept
- * @param aboutEmoji if null, the previous about emoji will be kept
- * @param avatar if avatar is null the image from the local avatar store is used (if present),
- */
@Override
- public void setProfile(
- String givenName, final String familyName, String about, String aboutEmoji, java.util.Optional<File> avatar
- ) throws IOException {
- profileHelper.setProfile(givenName,
- familyName,
- about,
- aboutEmoji,
- avatar == null ? null : Optional.fromNullable(avatar.orElse(null)));
- syncHelper.sendSyncFetchProfileMessage();
+ public void updateProfile(UpdateProfile updateProfile) throws IOException {
+ context.getProfileHelper()
+ .setProfile(updateProfile.getGivenName(),
+ updateProfile.getFamilyName(),
+ updateProfile.getAbout(),
+ updateProfile.getAboutEmoji(),
+ updateProfile.isDeleteAvatar()
+ ? Optional.empty()
+ : updateProfile.getAvatar() == null ? null : Optional.of(updateProfile.getAvatar()),
+ updateProfile.getMobileCoinAddress());
+ context.getSyncHelper().sendSyncFetchProfileMessage();
}
@Override
public void unregister() throws IOException {
- // When setting an empty GCM id, the Signal-Server also sets the fetchesMessages property to false.
- // If this is the master device, other users can't send messages to this number anymore.
- // If this is a linked device, other users can still send messages, but this device doesn't receive them anymore.
- dependencies.getAccountManager().setGcmId(Optional.absent());
-
- account.setRegistered(false);
- close();
+ context.getAccountHelper().unregister();
}
@Override
public void deleteAccount() throws IOException {
- try {
- pinHelper.removeRegistrationLockPin();
- } catch (IOException e) {
- logger.warn("Failed to remove registration lock pin");
- }
- account.setRegistrationLockPin(null, null);
-
- dependencies.getAccountManager().deleteAccount();
-
- account.setRegistered(false);
- close();
+ context.getAccountHelper().deleteAccount();
}
@Override
public List<Device> getLinkedDevices() throws IOException {
var devices = dependencies.getAccountManager().getDevices();
account.setMultiDevice(devices.size() > 1);
- var identityKey = account.getIdentityKeyPair().getPrivateKey();
+ var identityKey = account.getAciIdentityKeyPair().getPrivateKey();
return devices.stream().map(d -> {
String deviceName = d.getName();
if (deviceName != null) {
}
@Override
- public void removeLinkedDevices(long deviceId) throws IOException {
- dependencies.getAccountManager().removeDevice(deviceId);
- var devices = dependencies.getAccountManager().getDevices();
- account.setMultiDevice(devices.size() > 1);
+ public void removeLinkedDevices(int deviceId) throws IOException {
+ context.getAccountHelper().removeLinkedDevices(deviceId);
}
@Override
public void addDeviceLink(URI linkUri) throws IOException, InvalidDeviceLinkException {
- var info = DeviceLinkInfo.parseDeviceLinkUri(linkUri);
-
- addDevice(info.deviceIdentifier(), info.deviceKey());
- }
-
- private void addDevice(
- String deviceIdentifier, ECPublicKey deviceKey
- ) throws IOException, InvalidDeviceLinkException {
- var identityKeyPair = account.getIdentityKeyPair();
- var verificationCode = dependencies.getAccountManager().getNewDeviceVerificationCode();
-
- try {
- dependencies.getAccountManager()
- .addDevice(deviceIdentifier,
- deviceKey,
- identityKeyPair,
- Optional.of(account.getProfileKey().serialize()),
- verificationCode);
- } catch (InvalidKeyException e) {
- throw new InvalidDeviceLinkException("Invalid device link", e);
- }
- account.setMultiDevice(true);
+ var deviceLinkInfo = DeviceLinkInfo.parseDeviceLinkUri(linkUri);
+ context.getAccountHelper().addDevice(deviceLinkInfo);
}
@Override
- public void setRegistrationLockPin(java.util.Optional<String> pin) throws IOException {
- if (!account.isMasterDevice()) {
- throw new RuntimeException("Only master device can set a PIN");
+ public void setRegistrationLockPin(Optional<String> pin) throws IOException, NotPrimaryDeviceException {
+ if (!account.isPrimaryDevice()) {
+ throw new NotPrimaryDeviceException();
}
if (pin.isPresent()) {
- final var masterKey = account.getPinMasterKey() != null
- ? account.getPinMasterKey()
- : KeyUtils.createMasterKey();
-
- pinHelper.setRegistrationLockPin(pin.get(), masterKey);
-
- account.setRegistrationLockPin(pin.get(), masterKey);
+ context.getAccountHelper().setRegistrationPin(pin.get());
} else {
- // Remove KBS Pin
- pinHelper.removeRegistrationLockPin();
-
- account.setRegistrationLockPin(null, null);
+ context.getAccountHelper().removeRegistrationPin();
}
}
void refreshPreKeys() throws IOException {
- preKeyHelper.refreshPreKeys();
+ context.getPreKeyHelper().refreshPreKeys();
}
@Override
- public Profile getRecipientProfile(RecipientIdentifier.Single recipient) throws IOException, UnregisteredRecipientException {
- return profileHelper.getRecipientProfile(recipientHelper.resolveRecipient(recipient));
- }
-
- private Profile getRecipientProfile(RecipientId recipientId) {
- return profileHelper.getRecipientProfile(recipientId);
+ public Profile getRecipientProfile(RecipientIdentifier.Single recipient) throws UnregisteredRecipientException {
+ return context.getProfileHelper().getRecipientProfile(context.getRecipientHelper().resolveRecipient(recipient));
}
@Override
return null;
}
- return new Group(groupInfo.getGroupId(),
- groupInfo.getTitle(),
- groupInfo.getDescription(),
- groupInfo.getGroupInviteLink(),
- groupInfo.getMembers()
- .stream()
- .map(account.getRecipientStore()::resolveRecipientAddress)
- .collect(Collectors.toSet()),
- groupInfo.getPendingMembers()
- .stream()
- .map(account.getRecipientStore()::resolveRecipientAddress)
- .collect(Collectors.toSet()),
- groupInfo.getRequestingMembers()
- .stream()
- .map(account.getRecipientStore()::resolveRecipientAddress)
- .collect(Collectors.toSet()),
- groupInfo.getAdminMembers()
- .stream()
- .map(account.getRecipientStore()::resolveRecipientAddress)
- .collect(Collectors.toSet()),
- groupInfo.isBlocked(),
- groupInfo.getMessageExpirationTimer(),
- groupInfo.getPermissionAddMember(),
- groupInfo.getPermissionEditDetails(),
- groupInfo.getPermissionSendMessage(),
- groupInfo.isMember(account.getSelfRecipientId()),
- groupInfo.isAdmin(account.getSelfRecipientId()));
+ return Group.from(groupInfo, account.getRecipientAddressResolver(), account.getSelfRecipientId());
}
@Override
public SendGroupMessageResults quitGroup(
GroupId groupId, Set<RecipientIdentifier.Single> groupAdmins
) throws GroupNotFoundException, IOException, NotAGroupMemberException, LastGroupAdminException, UnregisteredRecipientException {
- final var newAdmins = recipientHelper.resolveRecipients(groupAdmins);
- return groupHelper.quitGroup(groupId, newAdmins);
+ final var newAdmins = context.getRecipientHelper().resolveRecipients(groupAdmins);
+ return context.getGroupHelper().quitGroup(groupId, newAdmins);
}
@Override
public void deleteGroup(GroupId groupId) throws IOException {
- groupHelper.deleteGroup(groupId);
+ final var group = context.getGroupHelper().getGroup(groupId);
+ if (group.isMember(account.getSelfRecipientId())) {
+ throw new IOException(
+ "The local group information cannot be removed, as the user is still a member of the group");
+ }
+ context.getGroupHelper().deleteGroup(groupId);
}
@Override
public Pair<GroupId, SendGroupMessageResults> createGroup(
String name, Set<RecipientIdentifier.Single> members, File avatarFile
) throws IOException, AttachmentInvalidException, UnregisteredRecipientException {
- return groupHelper.createGroup(name,
- members == null ? null : recipientHelper.resolveRecipients(members),
- avatarFile);
+ return context.getGroupHelper()
+ .createGroup(name,
+ members == null ? null : context.getRecipientHelper().resolveRecipients(members),
+ avatarFile);
}
@Override
public SendGroupMessageResults updateGroup(
final GroupId groupId, final UpdateGroup updateGroup
) throws IOException, GroupNotFoundException, AttachmentInvalidException, NotAGroupMemberException, GroupSendingNotAllowedException, UnregisteredRecipientException {
- return groupHelper.updateGroup(groupId,
- updateGroup.getName(),
- updateGroup.getDescription(),
- updateGroup.getMembers() == null ? null : recipientHelper.resolveRecipients(updateGroup.getMembers()),
- updateGroup.getRemoveMembers() == null
- ? null
- : recipientHelper.resolveRecipients(updateGroup.getRemoveMembers()),
- updateGroup.getAdmins() == null ? null : recipientHelper.resolveRecipients(updateGroup.getAdmins()),
- updateGroup.getRemoveAdmins() == null
- ? null
- : recipientHelper.resolveRecipients(updateGroup.getRemoveAdmins()),
- updateGroup.isResetGroupLink(),
- updateGroup.getGroupLinkState(),
- updateGroup.getAddMemberPermission(),
- updateGroup.getEditDetailsPermission(),
- updateGroup.getAvatarFile(),
- updateGroup.getExpirationTimer(),
- updateGroup.getIsAnnouncementGroup());
+ return context.getGroupHelper()
+ .updateGroup(groupId,
+ updateGroup.getName(),
+ updateGroup.getDescription(),
+ updateGroup.getMembers() == null
+ ? null
+ : context.getRecipientHelper().resolveRecipients(updateGroup.getMembers()),
+ updateGroup.getRemoveMembers() == null
+ ? null
+ : context.getRecipientHelper().resolveRecipients(updateGroup.getRemoveMembers()),
+ updateGroup.getAdmins() == null
+ ? null
+ : context.getRecipientHelper().resolveRecipients(updateGroup.getAdmins()),
+ updateGroup.getRemoveAdmins() == null
+ ? null
+ : context.getRecipientHelper().resolveRecipients(updateGroup.getRemoveAdmins()),
+ updateGroup.getBanMembers() == null
+ ? null
+ : context.getRecipientHelper().resolveRecipients(updateGroup.getBanMembers()),
+ updateGroup.getUnbanMembers() == null
+ ? null
+ : context.getRecipientHelper().resolveRecipients(updateGroup.getUnbanMembers()),
+ updateGroup.isResetGroupLink(),
+ updateGroup.getGroupLinkState(),
+ updateGroup.getAddMemberPermission(),
+ updateGroup.getEditDetailsPermission(),
+ updateGroup.getAvatarFile(),
+ updateGroup.getExpirationTimer(),
+ updateGroup.getIsAnnouncementGroup());
}
@Override
public Pair<GroupId, SendGroupMessageResults> joinGroup(
GroupInviteLinkUrl inviteLinkUrl
) throws IOException, InactiveGroupLinkException {
- return groupHelper.joinGroup(inviteLinkUrl);
+ return context.getGroupHelper().joinGroup(inviteLinkUrl);
}
private SendMessageResults sendMessage(
for (final var recipient : recipients) {
if (recipient instanceof RecipientIdentifier.Single single) {
try {
- final var recipientId = recipientHelper.resolveRecipient(single);
- final var result = sendHelper.sendMessage(messageBuilder, recipientId);
- results.put(recipient,
- List.of(SendMessageResult.from(result,
- account.getRecipientStore(),
- account.getRecipientStore()::resolveRecipientAddress)));
+ final var recipientId = context.getRecipientHelper().resolveRecipient(single);
+ final var result = context.getSendHelper().sendMessage(messageBuilder, recipientId);
+ results.put(recipient, List.of(toSendMessageResult(result)));
} catch (UnregisteredRecipientException e) {
results.put(recipient,
List.of(SendMessageResult.unregisteredFailure(single.toPartialRecipientAddress())));
}
} else if (recipient instanceof RecipientIdentifier.NoteToSelf) {
- final var result = sendHelper.sendSelfMessage(messageBuilder);
- results.put(recipient,
- List.of(SendMessageResult.from(result,
- account.getRecipientStore(),
- account.getRecipientStore()::resolveRecipientAddress)));
+ final var result = context.getSendHelper().sendSelfMessage(messageBuilder);
+ results.put(recipient, List.of(toSendMessageResult(result)));
} else if (recipient instanceof RecipientIdentifier.Group group) {
- final var result = sendHelper.sendAsGroupMessage(messageBuilder, group.groupId());
- results.put(recipient,
- result.stream()
- .map(sendMessageResult -> SendMessageResult.from(sendMessageResult,
- account.getRecipientStore(),
- account.getRecipientStore()::resolveRecipientAddress))
- .toList());
+ final var result = context.getSendHelper().sendAsGroupMessage(messageBuilder, group.groupId());
+ results.put(recipient, result.stream().map(this::toSendMessageResult).toList());
}
}
return new SendMessageResults(timestamp, results);
}
+ private SendMessageResult toSendMessageResult(final org.whispersystems.signalservice.api.messages.SendMessageResult result) {
+ return SendMessageResult.from(result, account.getRecipientResolver(), account.getRecipientAddressResolver());
+ }
+
private SendMessageResults sendTypingMessage(
SignalServiceTypingMessage.Action action, Set<RecipientIdentifier> recipients
) throws IOException, NotAGroupMemberException, GroupNotFoundException, GroupSendingNotAllowedException {
final var timestamp = System.currentTimeMillis();
for (var recipient : recipients) {
if (recipient instanceof RecipientIdentifier.Single single) {
- final var message = new SignalServiceTypingMessage(action, timestamp, Optional.absent());
+ final var message = new SignalServiceTypingMessage(action, timestamp, Optional.empty());
try {
- final var recipientId = recipientHelper.resolveRecipient(single);
- final var result = sendHelper.sendTypingMessage(message, recipientId);
- results.put(recipient,
- List.of(SendMessageResult.from(result,
- account.getRecipientStore(),
- account.getRecipientStore()::resolveRecipientAddress)));
+ final var recipientId = context.getRecipientHelper().resolveRecipient(single);
+ final var result = context.getSendHelper().sendTypingMessage(message, recipientId);
+ results.put(recipient, List.of(toSendMessageResult(result)));
} catch (UnregisteredRecipientException e) {
results.put(recipient,
List.of(SendMessageResult.unregisteredFailure(single.toPartialRecipientAddress())));
} else if (recipient instanceof RecipientIdentifier.Group) {
final var groupId = ((RecipientIdentifier.Group) recipient).groupId();
final var message = new SignalServiceTypingMessage(action, timestamp, Optional.of(groupId.serialize()));
- final var result = sendHelper.sendGroupTypingMessage(message, groupId);
- results.put(recipient,
- result.stream()
- .map(r -> SendMessageResult.from(r,
- account.getRecipientStore(),
- account.getRecipientStore()::resolveRecipientAddress))
- .toList());
+ final var result = context.getSendHelper().sendGroupTypingMessage(message, groupId);
+ results.put(recipient, result.stream().map(this::toSendMessageResult).toList());
}
}
return new SendMessageResults(timestamp, results);
@Override
public SendMessageResults sendReadReceipt(
RecipientIdentifier.Single sender, List<Long> messageIds
- ) throws IOException {
+ ) {
final var timestamp = System.currentTimeMillis();
var receiptMessage = new SignalServiceReceiptMessage(SignalServiceReceiptMessage.Type.READ,
messageIds,
@Override
public SendMessageResults sendViewedReceipt(
RecipientIdentifier.Single sender, List<Long> messageIds
- ) throws IOException {
+ ) {
final var timestamp = System.currentTimeMillis();
var receiptMessage = new SignalServiceReceiptMessage(SignalServiceReceiptMessage.Type.VIEWED,
messageIds,
final RecipientIdentifier.Single sender,
final long timestamp,
final SignalServiceReceiptMessage receiptMessage
- ) throws IOException {
+ ) {
try {
- final var result = sendHelper.sendReceiptMessage(receiptMessage, recipientHelper.resolveRecipient(sender));
- return new SendMessageResults(timestamp,
- Map.of(sender,
- List.of(SendMessageResult.from(result,
- account.getRecipientStore(),
- account.getRecipientStore()::resolveRecipientAddress))));
+ final var result = context.getSendHelper()
+ .sendReceiptMessage(receiptMessage, context.getRecipientHelper().resolveRecipient(sender));
+ return new SendMessageResults(timestamp, Map.of(sender, List.of(toSendMessageResult(result))));
} catch (UnregisteredRecipientException e) {
return new SendMessageResults(timestamp,
Map.of(sender, List.of(SendMessageResult.unregisteredFailure(sender.toPartialRecipientAddress()))));
@Override
public SendMessageResults sendMessage(
Message message, Set<RecipientIdentifier> recipients
- ) throws IOException, AttachmentInvalidException, NotAGroupMemberException, GroupNotFoundException, GroupSendingNotAllowedException, UnregisteredRecipientException {
+ ) throws IOException, AttachmentInvalidException, NotAGroupMemberException, GroupNotFoundException, GroupSendingNotAllowedException, UnregisteredRecipientException, InvalidStickerException {
+ final var selfProfile = context.getProfileHelper().getSelfProfile();
+ if (selfProfile == null || selfProfile.getDisplayName().isEmpty()) {
+ logger.warn(
+ "No profile name set. When sending a message it's recommended to set a profile name wit the updateProfile command. This may become mandatory in the future.");
+ }
final var messageBuilder = SignalServiceDataMessage.newBuilder();
applyMessage(messageBuilder, message);
return sendMessage(messageBuilder, recipients);
private void applyMessage(
final SignalServiceDataMessage.Builder messageBuilder, final Message message
- ) throws AttachmentInvalidException, IOException, UnregisteredRecipientException {
+ ) throws AttachmentInvalidException, IOException, UnregisteredRecipientException, InvalidStickerException {
messageBuilder.withBody(message.messageText());
- final var attachments = message.attachments();
- if (attachments != null) {
- messageBuilder.withAttachments(attachmentHelper.uploadAttachments(attachments));
+ if (message.attachments().size() > 0) {
+ messageBuilder.withAttachments(context.getAttachmentHelper().uploadAttachments(message.attachments()));
}
if (message.mentions().size() > 0) {
messageBuilder.withMentions(resolveMentions(message.mentions()));
if (message.quote().isPresent()) {
final var quote = message.quote().get();
messageBuilder.withQuote(new SignalServiceDataMessage.Quote(quote.timestamp(),
- recipientHelper.resolveSignalServiceAddress(recipientHelper.resolveRecipient(quote.author())),
+ context.getRecipientHelper()
+ .resolveSignalServiceAddress(context.getRecipientHelper().resolveRecipient(quote.author())),
quote.message(),
List.of(),
- resolveMentions(quote.mentions())));
+ resolveMentions(quote.mentions()),
+ SignalServiceDataMessage.Quote.Type.NORMAL));
+ }
+ if (message.sticker().isPresent()) {
+ final var sticker = message.sticker().get();
+ final var packId = StickerPackId.deserialize(sticker.packId());
+ final var stickerId = sticker.stickerId();
+
+ final var stickerPack = context.getAccount().getStickerStore().getStickerPack(packId);
+ if (stickerPack == null) {
+ throw new InvalidStickerException("Sticker pack not found");
+ }
+ final var manifest = context.getStickerHelper().getOrRetrieveStickerPack(packId, stickerPack.getPackKey());
+ if (manifest.stickers().size() <= stickerId) {
+ throw new InvalidStickerException("Sticker id not part of this pack");
+ }
+ final var manifestSticker = manifest.stickers().get(stickerId);
+ final var streamDetails = context.getStickerPackStore().retrieveSticker(packId, stickerId);
+ if (streamDetails == null) {
+ throw new InvalidStickerException("Missing local sticker file");
+ }
+ messageBuilder.withSticker(new SignalServiceDataMessage.Sticker(packId.serialize(),
+ stickerPack.getPackKey(),
+ stickerId,
+ manifestSticker.emoji(),
+ AttachmentUtils.createAttachmentStream(streamDetails, Optional.empty())));
+ }
+ if (message.previews().size() > 0) {
+ final var previews = new ArrayList<SignalServicePreview>(message.previews().size());
+ for (final var p : message.previews()) {
+ final var image = p.image().isPresent() ? context.getAttachmentHelper()
+ .uploadAttachment(p.image().get()) : null;
+ previews.add(new SignalServicePreview(p.url(),
+ p.title(),
+ p.description(),
+ 0,
+ Optional.ofNullable(image)));
+ }
+ messageBuilder.withPreviews(previews);
}
}
- private ArrayList<SignalServiceDataMessage.Mention> resolveMentions(final List<Message.Mention> mentionList) throws IOException, UnregisteredRecipientException {
+ private ArrayList<SignalServiceDataMessage.Mention> resolveMentions(final List<Message.Mention> mentionList) throws UnregisteredRecipientException {
final var mentions = new ArrayList<SignalServiceDataMessage.Mention>();
for (final var m : mentionList) {
- final var recipientId = recipientHelper.resolveRecipient(m.recipient());
- mentions.add(new SignalServiceDataMessage.Mention(recipientHelper.resolveSignalServiceAddress(recipientId)
- .getAci(), m.start(), m.length()));
+ final var recipientId = context.getRecipientHelper().resolveRecipient(m.recipient());
+ mentions.add(new SignalServiceDataMessage.Mention(context.getRecipientHelper()
+ .resolveSignalServiceAddress(recipientId)
+ .getServiceId(), m.start(), m.length()));
}
return mentions;
}
) throws IOException, NotAGroupMemberException, GroupNotFoundException, GroupSendingNotAllowedException {
var delete = new SignalServiceDataMessage.RemoteDelete(targetSentTimestamp);
final var messageBuilder = SignalServiceDataMessage.newBuilder().withRemoteDelete(delete);
+ for (final var recipient : recipients) {
+ if (recipient instanceof RecipientIdentifier.Single r) {
+ try {
+ final var recipientId = context.getRecipientHelper().resolveRecipient(r);
+ account.getMessageSendLogStore().deleteEntryForRecipientNonGroup(targetSentTimestamp, recipientId);
+ } catch (UnregisteredRecipientException ignored) {
+ }
+ } else if (recipient instanceof RecipientIdentifier.Group r) {
+ account.getMessageSendLogStore().deleteEntryForGroup(targetSentTimestamp, r.groupId());
+ }
+ }
return sendMessage(messageBuilder, recipients);
}
long targetSentTimestamp,
Set<RecipientIdentifier> recipients
) throws IOException, NotAGroupMemberException, GroupNotFoundException, GroupSendingNotAllowedException, UnregisteredRecipientException {
- var targetAuthorRecipientId = recipientHelper.resolveRecipient(targetAuthor);
+ var targetAuthorRecipientId = context.getRecipientHelper().resolveRecipient(targetAuthor);
var reaction = new SignalServiceDataMessage.Reaction(emoji,
remove,
- recipientHelper.resolveSignalServiceAddress(targetAuthorRecipientId),
+ context.getRecipientHelper().resolveSignalServiceAddress(targetAuthorRecipientId),
targetSentTimestamp);
final var messageBuilder = SignalServiceDataMessage.newBuilder().withReaction(reaction);
return sendMessage(messageBuilder, recipients);
}
+ @Override
+ public SendMessageResults sendPaymentNotificationMessage(
+ byte[] receipt, String note, RecipientIdentifier.Single recipient
+ ) throws IOException {
+ final var paymentNotification = new SignalServiceDataMessage.PaymentNotification(receipt, note);
+ final var payment = new SignalServiceDataMessage.Payment(paymentNotification);
+ final var messageBuilder = SignalServiceDataMessage.newBuilder().withPayment(payment);
+ try {
+ return sendMessage(messageBuilder, Set.of(recipient));
+ } catch (NotAGroupMemberException | GroupNotFoundException | GroupSendingNotAllowedException e) {
+ throw new AssertionError(e);
+ }
+ }
+
@Override
public SendMessageResults sendEndSessionMessage(Set<RecipientIdentifier.Single> recipients) throws IOException {
var messageBuilder = SignalServiceDataMessage.newBuilder().asEndSessionMessage();
for (var recipient : recipients) {
final RecipientId recipientId;
try {
- recipientId = recipientHelper.resolveRecipient(recipient);
+ recipientId = context.getRecipientHelper().resolveRecipient(recipient);
} catch (UnregisteredRecipientException e) {
continue;
}
@Override
public void deleteRecipient(final RecipientIdentifier.Single recipient) {
- account.removeRecipient(account.getRecipientStore().resolveRecipient(recipient.toPartialRecipientAddress()));
+ account.removeRecipient(account.getRecipientResolver().resolveRecipient(recipient.toPartialRecipientAddress()));
}
@Override
public void deleteContact(final RecipientIdentifier.Single recipient) {
account.getContactStore()
- .deleteContact(account.getRecipientStore().resolveRecipient(recipient.toPartialRecipientAddress()));
+ .deleteContact(account.getRecipientResolver().resolveRecipient(recipient.toPartialRecipientAddress()));
}
@Override
public void setContactName(
RecipientIdentifier.Single recipient, String name
- ) throws NotMasterDeviceException, IOException, UnregisteredRecipientException {
- if (!account.isMasterDevice()) {
- throw new NotMasterDeviceException();
+ ) throws NotPrimaryDeviceException, UnregisteredRecipientException {
+ if (!account.isPrimaryDevice()) {
+ throw new NotPrimaryDeviceException();
}
- contactHelper.setContactName(recipientHelper.resolveRecipient(recipient), name);
+ context.getContactHelper().setContactName(context.getRecipientHelper().resolveRecipient(recipient), name);
}
@Override
- public void setContactBlocked(
- RecipientIdentifier.Single recipient, boolean blocked
- ) throws NotMasterDeviceException, IOException, UnregisteredRecipientException {
- if (!account.isMasterDevice()) {
- throw new NotMasterDeviceException();
+ public void setContactsBlocked(
+ Collection<RecipientIdentifier.Single> recipients, boolean blocked
+ ) throws NotPrimaryDeviceException, IOException, UnregisteredRecipientException {
+ if (!account.isPrimaryDevice()) {
+ throw new NotPrimaryDeviceException();
+ }
+ if (recipients.size() == 0) {
+ return;
}
- contactHelper.setContactBlocked(recipientHelper.resolveRecipient(recipient), blocked);
- // TODO cycle our profile key, if we're not together in a group with recipient
- syncHelper.sendBlockedList();
+ final var recipientIds = context.getRecipientHelper().resolveRecipients(recipients);
+ final var selfRecipientId = account.getSelfRecipientId();
+ boolean shouldRotateProfileKey = false;
+ for (final var recipientId : recipientIds) {
+ if (context.getContactHelper().isContactBlocked(recipientId) == blocked) {
+ continue;
+ }
+ context.getContactHelper().setContactBlocked(recipientId, blocked);
+ // if we don't have a common group with the blocked contact we need to rotate the profile key
+ shouldRotateProfileKey = blocked && (
+ shouldRotateProfileKey || account.getGroupStore()
+ .getGroups()
+ .stream()
+ .noneMatch(g -> g.isMember(selfRecipientId) && g.isMember(recipientId))
+ );
+ }
+ if (shouldRotateProfileKey) {
+ context.getProfileHelper().rotateProfileKey();
+ }
+ context.getSyncHelper().sendBlockedList();
}
@Override
- public void setGroupBlocked(
- final GroupId groupId, final boolean blocked
- ) throws GroupNotFoundException, IOException, NotMasterDeviceException {
- if (!account.isMasterDevice()) {
- throw new NotMasterDeviceException();
+ public void setGroupsBlocked(
+ final Collection<GroupId> groupIds, final boolean blocked
+ ) throws GroupNotFoundException, NotPrimaryDeviceException, IOException {
+ if (!account.isPrimaryDevice()) {
+ throw new NotPrimaryDeviceException();
}
- groupHelper.setGroupBlocked(groupId, blocked);
- // TODO cycle our profile key
- syncHelper.sendBlockedList();
+ if (groupIds.size() == 0) {
+ return;
+ }
+ boolean shouldRotateProfileKey = false;
+ for (final var groupId : groupIds) {
+ if (context.getGroupHelper().isGroupBlocked(groupId) == blocked) {
+ continue;
+ }
+ context.getGroupHelper().setGroupBlocked(groupId, blocked);
+ shouldRotateProfileKey = blocked;
+ }
+ if (shouldRotateProfileKey) {
+ context.getProfileHelper().rotateProfileKey();
+ }
+ context.getSyncHelper().sendBlockedList();
}
- /**
- * Change the expiration timer for a contact
- */
@Override
public void setExpirationTimer(
RecipientIdentifier.Single recipient, int messageExpirationTimer
) throws IOException, UnregisteredRecipientException {
- var recipientId = recipientHelper.resolveRecipient(recipient);
- contactHelper.setExpirationTimer(recipientId, messageExpirationTimer);
+ var recipientId = context.getRecipientHelper().resolveRecipient(recipient);
+ context.getContactHelper().setExpirationTimer(recipientId, messageExpirationTimer);
final var messageBuilder = SignalServiceDataMessage.newBuilder().asExpirationUpdate();
try {
sendMessage(messageBuilder, Set.of(recipient));
}
}
- /**
- * Upload the sticker pack from path.
- *
- * @param path Path can be a path to a manifest.json file or to a zip file that contains a manifest.json file
- * @return if successful, returns the URL to install the sticker pack in the signal app
- */
@Override
- public URI uploadStickerPack(File path) throws IOException, StickerPackInvalidException {
+ public StickerPackUrl uploadStickerPack(File path) throws IOException, StickerPackInvalidException {
var manifest = StickerUtils.getSignalServiceStickerManifestUpload(path);
var messageSender = dependencies.getMessageSender();
var sticker = new Sticker(packId, packKey);
account.getStickerStore().updateSticker(sticker);
- try {
- return new URI("https",
- "signal.art",
- "/addstickers/",
- "pack_id="
- + URLEncoder.encode(Hex.toStringCondensed(packId.serialize()), StandardCharsets.UTF_8)
- + "&pack_key="
- + URLEncoder.encode(Hex.toStringCondensed(packKey), StandardCharsets.UTF_8));
- } catch (URISyntaxException e) {
- throw new AssertionError(e);
- }
+ return new StickerPackUrl(packId, packKey);
+ }
+
+ @Override
+ public List<StickerPack> getStickerPacks() {
+ final var stickerPackStore = context.getStickerPackStore();
+ return account.getStickerStore().getStickerPacks().stream().map(pack -> {
+ if (stickerPackStore.existsStickerPack(pack.getPackId())) {
+ try {
+ final var manifest = stickerPackStore.retrieveManifest(pack.getPackId());
+ return new StickerPack(pack.getPackId(),
+ new StickerPackUrl(pack.getPackId(), pack.getPackKey()),
+ pack.isInstalled(),
+ manifest.title(),
+ manifest.author(),
+ Optional.ofNullable(manifest.cover() == null ? null : manifest.cover().toApi()),
+ manifest.stickers().stream().map(JsonStickerPack.JsonSticker::toApi).toList());
+ } catch (Exception e) {
+ logger.warn("Failed to read local sticker pack manifest: {}", e.getMessage(), e);
+ }
+ }
+
+ return new StickerPack(pack.getPackId(), pack.getPackKey(), pack.isInstalled());
+ }).toList();
}
@Override
public void requestAllSyncData() throws IOException {
- syncHelper.requestAllSyncData();
+ context.getSyncHelper().requestAllSyncData();
retrieveRemoteStorage();
}
void retrieveRemoteStorage() throws IOException {
if (account.getStorageKey() != null) {
- storageHelper.readDataFromStorage();
- }
- }
-
- private void retryFailedReceivedMessages(ReceiveMessageHandler handler) {
- Set<HandleAction> queuedActions = new HashSet<>();
- for (var cachedMessage : account.getMessageCache().getCachedMessages()) {
- var actions = retryFailedReceivedMessage(handler, cachedMessage);
- if (actions != null) {
- queuedActions.addAll(actions);
- }
+ context.getStorageHelper().readDataFromStorage();
}
- handleQueuedActions(queuedActions);
- }
-
- private List<HandleAction> retryFailedReceivedMessage(
- final ReceiveMessageHandler handler, final CachedMessage cachedMessage
- ) {
- var envelope = cachedMessage.loadEnvelope();
- if (envelope == null) {
- cachedMessage.delete();
- return null;
- }
-
- final var result = incomingMessageHandler.handleRetryEnvelope(envelope, ignoreAttachments, handler);
- final var actions = result.first();
- final var exception = result.second();
-
- if (exception instanceof UntrustedIdentityException) {
- if (System.currentTimeMillis() - envelope.getServerDeliveredTimestamp() > 1000L * 60 * 60 * 24 * 30) {
- // Envelope is more than a month old, cleaning up.
- cachedMessage.delete();
- return null;
- }
- if (!envelope.hasSourceUuid()) {
- final var identifier = ((UntrustedIdentityException) exception).getSender();
- final var recipientId = account.getRecipientStore().resolveRecipient(identifier);
- try {
- account.getMessageCache().replaceSender(cachedMessage, recipientId);
- } catch (IOException ioException) {
- logger.warn("Failed to move cached message to recipient folder: {}", ioException.getMessage());
- }
- }
- return null;
- }
-
- // If successful and for all other errors that are not recoverable, delete the cached message
- cachedMessage.delete();
- return actions;
}
@Override
}
}
+ private static final AtomicInteger threadNumber = new AtomicInteger(0);
+
private void startReceiveThreadIfRequired() {
if (receiveThread != null) {
return;
}
receiveThread = new Thread(() -> {
logger.debug("Starting receiving messages");
- while (!Thread.interrupted()) {
- try {
- receiveMessagesInternal(Duration.ofMinutes(1), false, (envelope, e) -> {
- synchronized (messageHandlers) {
- Stream.concat(messageHandlers.stream(), weakHandlers.stream()).forEach(h -> {
- try {
- h.handleMessage(envelope, e);
- } catch (Exception ex) {
- logger.warn("Message handler failed, ignoring", ex);
- }
- });
+ context.getReceiveHelper().receiveMessagesContinuously((envelope, e) -> {
+ synchronized (messageHandlers) {
+ Stream.concat(messageHandlers.stream(), weakHandlers.stream()).forEach(h -> {
+ try {
+ h.handleMessage(envelope, e);
+ } catch (Throwable ex) {
+ logger.warn("Message handler failed, ignoring", ex);
}
});
- break;
- } catch (IOException e) {
- logger.warn("Receiving messages failed, retrying", e);
}
- }
+ });
logger.debug("Finished receiving messages");
- hasCaughtUpWithOldMessages = false;
synchronized (messageHandlers) {
receiveThread = null;
}
}
});
+ receiveThread.setName("receive-" + threadNumber.getAndIncrement());
receiveThread.start();
}
}
private void stopReceiveThread(final Thread thread) {
- thread.interrupt();
+ if (context.getReceiveHelper().requestStopReceiveMessages()) {
+ logger.debug("Receive stop requested, interrupting read from server.");
+ thread.interrupt();
+ }
try {
thread.join();
} catch (InterruptedException ignored) {
isReceivingSynchronous = true;
receiveThread = Thread.currentThread();
try {
- receiveMessagesInternal(timeout, returnOnTimeout, handler);
+ context.getReceiveHelper().receiveMessages(timeout, returnOnTimeout, handler);
} finally {
receiveThread = null;
- hasCaughtUpWithOldMessages = false;
isReceivingSynchronous = false;
}
}
- private void receiveMessagesInternal(
- Duration timeout, boolean returnOnTimeout, ReceiveMessageHandler handler
- ) throws IOException {
- needsToRetryFailedMessages = true;
-
- // Use a Map here because java Set doesn't have a get method ...
- Map<HandleAction, HandleAction> queuedActions = new HashMap<>();
-
- final var signalWebSocket = dependencies.getSignalWebSocket();
- final var webSocketStateDisposable = Observable.merge(signalWebSocket.getUnidentifiedWebSocketState(),
- signalWebSocket.getWebSocketState())
- .subscribeOn(Schedulers.computation())
- .observeOn(Schedulers.computation())
- .distinctUntilChanged()
- .subscribe(this::onWebSocketStateChange);
- signalWebSocket.connect();
-
- hasCaughtUpWithOldMessages = false;
- var backOffCounter = 0;
- final var MAX_BACKOFF_COUNTER = 9;
-
- while (!Thread.interrupted()) {
- if (needsToRetryFailedMessages) {
- retryFailedReceivedMessages(handler);
- needsToRetryFailedMessages = false;
- }
- SignalServiceEnvelope envelope;
- final CachedMessage[] cachedMessage = {null};
- final var nowMillis = System.currentTimeMillis();
- if (nowMillis - account.getLastReceiveTimestamp() > 60000) {
- account.setLastReceiveTimestamp(nowMillis);
- }
- logger.debug("Checking for new message from server");
- try {
- var result = signalWebSocket.readOrEmpty(timeout.toMillis(), envelope1 -> {
- final var recipientId = envelope1.hasSourceUuid() ? account.getRecipientStore()
- .resolveRecipient(envelope1.getSourceAddress()) : null;
- // store message on disk, before acknowledging receipt to the server
- cachedMessage[0] = account.getMessageCache().cacheMessage(envelope1, recipientId);
- });
- backOffCounter = 0;
-
- if (result.isPresent()) {
- envelope = result.get();
- logger.debug("New message received from server");
- } else {
- logger.debug("Received indicator that server queue is empty");
- handleQueuedActions(queuedActions.keySet());
- queuedActions.clear();
-
- hasCaughtUpWithOldMessages = true;
- synchronized (this) {
- this.notifyAll();
- }
-
- // Continue to wait another timeout for new messages
- continue;
- }
- } catch (AssertionError e) {
- if (e.getCause() instanceof InterruptedException) {
- Thread.currentThread().interrupt();
- break;
- } else {
- throw e;
- }
- } catch (IOException e) {
- logger.debug("Pipe unexpectedly unavailable: {}", e.getMessage());
- if (e instanceof WebSocketUnavailableException || "Connection closed!".equals(e.getMessage())) {
- final var sleepMilliseconds = 100 * (long) Math.pow(2, backOffCounter);
- backOffCounter = Math.min(backOffCounter + 1, MAX_BACKOFF_COUNTER);
- logger.warn("Connection closed unexpectedly, reconnecting in {} ms", sleepMilliseconds);
- try {
- Thread.sleep(sleepMilliseconds);
- } catch (InterruptedException interruptedException) {
- return;
- }
- hasCaughtUpWithOldMessages = false;
- signalWebSocket.connect();
- continue;
- }
- throw e;
- } catch (TimeoutException e) {
- backOffCounter = 0;
- if (returnOnTimeout) return;
- continue;
- }
-
- final var result = incomingMessageHandler.handleEnvelope(envelope, ignoreAttachments, handler);
- for (final var h : result.first()) {
- final var existingAction = queuedActions.get(h);
- if (existingAction == null) {
- queuedActions.put(h, h);
- } else {
- existingAction.mergeOther(h);
- }
- }
- final var exception = result.second();
-
- if (hasCaughtUpWithOldMessages) {
- handleQueuedActions(queuedActions.keySet());
- queuedActions.clear();
- }
- if (cachedMessage[0] != null) {
- if (exception instanceof UntrustedIdentityException) {
- logger.debug("Keeping message with untrusted identity in message cache");
- final var address = ((UntrustedIdentityException) exception).getSender();
- final var recipientId = account.getRecipientStore().resolveRecipient(address);
- if (!envelope.hasSourceUuid()) {
- try {
- cachedMessage[0] = account.getMessageCache().replaceSender(cachedMessage[0], recipientId);
- } catch (IOException ioException) {
- logger.warn("Failed to move cached message to recipient folder: {}",
- ioException.getMessage());
- }
- }
- } else {
- cachedMessage[0].delete();
- }
- }
- }
- handleQueuedActions(queuedActions.keySet());
- queuedActions.clear();
- dependencies.getSignalWebSocket().disconnect();
- webSocketStateDisposable.dispose();
- }
-
- private void onWebSocketStateChange(final WebSocketConnectionState s) {
- if (s.equals(WebSocketConnectionState.AUTHENTICATION_FAILED)) {
- account.setRegistered(false);
- try {
- close();
- } catch (IOException e) {
- e.printStackTrace();
- }
- }
- }
-
@Override
public void setIgnoreAttachments(final boolean ignoreAttachments) {
- this.ignoreAttachments = ignoreAttachments;
+ context.getReceiveHelper().setIgnoreAttachments(ignoreAttachments);
}
@Override
public boolean hasCaughtUpWithOldMessages() {
- return hasCaughtUpWithOldMessages;
- }
-
- private void handleQueuedActions(final Collection<HandleAction> queuedActions) {
- logger.debug("Handling message actions");
- var interrupted = false;
- for (var action : queuedActions) {
- logger.debug("Executing action {}", action.getClass().getSimpleName());
- try {
- action.execute(context);
- } catch (Throwable e) {
- if ((e instanceof AssertionError || e instanceof RuntimeException)
- && e.getCause() instanceof InterruptedException) {
- interrupted = true;
- continue;
- }
- logger.warn("Message action failed.", e);
- }
- }
- if (interrupted) {
- Thread.currentThread().interrupt();
- }
+ return context.getReceiveHelper().hasCaughtUpWithOldMessages();
}
@Override
public boolean isContactBlocked(final RecipientIdentifier.Single recipient) {
final RecipientId recipientId;
try {
- recipientId = recipientHelper.resolveRecipient(recipient);
- } catch (IOException | UnregisteredRecipientException e) {
+ recipientId = context.getRecipientHelper().resolveRecipient(recipient);
+ } catch (UnregisteredRecipientException e) {
return false;
}
- return contactHelper.isContactBlocked(recipientId);
+ return context.getContactHelper().isContactBlocked(recipientId);
}
@Override
public void sendContacts() throws IOException {
- syncHelper.sendContacts();
+ context.getSyncHelper().sendContacts();
}
@Override
- public List<Pair<RecipientAddress, Contact>> getContacts() {
- return account.getContactStore()
- .getContacts()
- .stream()
- .map(p -> new Pair<>(account.getRecipientStore().resolveRecipientAddress(p.first()), p.second()))
- .toList();
+ public List<Recipient> getRecipients(
+ boolean onlyContacts,
+ Optional<Boolean> blocked,
+ Collection<RecipientIdentifier.Single> recipients,
+ Optional<String> name
+ ) {
+ final var recipientIds = recipients.stream().map(a -> {
+ try {
+ return context.getRecipientHelper().resolveRecipient(a);
+ } catch (UnregisteredRecipientException e) {
+ return null;
+ }
+ }).filter(Objects::nonNull).collect(Collectors.toSet());
+ // refresh profiles of explicitly given recipients
+ context.getProfileHelper().refreshRecipientProfiles(recipientIds);
+ return account.getRecipientStore().getRecipients(onlyContacts, blocked, recipientIds, name);
}
@Override
public String getContactOrProfileName(RecipientIdentifier.Single recipient) {
final RecipientId recipientId;
try {
- recipientId = recipientHelper.resolveRecipient(recipient);
- } catch (IOException | UnregisteredRecipientException e) {
+ recipientId = context.getRecipientHelper().resolveRecipient(recipient);
+ } catch (UnregisteredRecipientException e) {
return null;
}
return contact.getName();
}
- final var profile = profileHelper.getRecipientProfile(recipientId);
+ final var profile = context.getProfileHelper().getRecipientProfile(recipientId);
if (profile != null) {
return profile.getDisplayName();
}
@Override
public Group getGroup(GroupId groupId) {
- return toGroup(groupHelper.getGroup(groupId));
- }
-
- private GroupInfo getGroupInfo(GroupId groupId) {
- return groupHelper.getGroup(groupId);
+ return toGroup(context.getGroupHelper().getGroup(groupId));
}
@Override
return null;
}
- final var address = account.getRecipientStore().resolveRecipientAddress(identityInfo.getRecipientId());
- final var scannableFingerprint = identityHelper.computeSafetyNumberForScanning(identityInfo.getRecipientId(),
- identityInfo.getIdentityKey());
+ final var address = account.getRecipientAddressResolver()
+ .resolveRecipientAddress(identityInfo.getRecipientId());
+ final var scannableFingerprint = context.getIdentityHelper()
+ .computeSafetyNumberForScanning(identityInfo.getRecipientId(), identityInfo.getIdentityKey());
return new Identity(address,
identityInfo.getIdentityKey(),
- identityHelper.computeSafetyNumber(identityInfo.getRecipientId(), identityInfo.getIdentityKey()),
+ context.getIdentityHelper()
+ .computeSafetyNumber(identityInfo.getRecipientId(), identityInfo.getIdentityKey()),
scannableFingerprint == null ? null : scannableFingerprint.getSerialized(),
identityInfo.getTrustLevel(),
identityInfo.getDateAdded());
public List<Identity> getIdentities(RecipientIdentifier.Single recipient) {
IdentityInfo identity;
try {
- identity = account.getIdentityKeyStore().getIdentity(recipientHelper.resolveRecipient(recipient));
- } catch (IOException | UnregisteredRecipientException e) {
+ identity = account.getIdentityKeyStore()
+ .getIdentity(context.getRecipientHelper().resolveRecipient(recipient));
+ } catch (UnregisteredRecipientException e) {
identity = null;
}
return identity == null ? List.of() : List.of(toIdentity(identity));
}
- /**
- * Trust this the identity with this fingerprint
- *
- * @param recipient account of the identity
- * @param fingerprint Fingerprint
- */
@Override
public boolean trustIdentityVerified(
RecipientIdentifier.Single recipient, byte[] fingerprint
) throws UnregisteredRecipientException {
- RecipientId recipientId;
- try {
- recipientId = recipientHelper.resolveRecipient(recipient);
- } catch (IOException e) {
- return false;
- }
- final var updated = identityHelper.trustIdentityVerified(recipientId, fingerprint);
- if (updated && this.isReceiving()) {
- needsToRetryFailedMessages = true;
- }
- return updated;
+ return trustIdentity(recipient, r -> context.getIdentityHelper().trustIdentityVerified(r, fingerprint));
}
- /**
- * Trust this the identity with this safety number
- *
- * @param recipient account of the identity
- * @param safetyNumber Safety number
- */
@Override
public boolean trustIdentityVerifiedSafetyNumber(
RecipientIdentifier.Single recipient, String safetyNumber
) throws UnregisteredRecipientException {
- RecipientId recipientId;
- try {
- recipientId = recipientHelper.resolveRecipient(recipient);
- } catch (IOException e) {
- return false;
- }
- final var updated = identityHelper.trustIdentityVerifiedSafetyNumber(recipientId, safetyNumber);
- if (updated && this.isReceiving()) {
- needsToRetryFailedMessages = true;
- }
- return updated;
+ return trustIdentity(recipient,
+ r -> context.getIdentityHelper().trustIdentityVerifiedSafetyNumber(r, safetyNumber));
}
- /**
- * Trust this the identity with this scannable safety number
- *
- * @param recipient account of the identity
- * @param safetyNumber Scannable safety number
- */
@Override
public boolean trustIdentityVerifiedSafetyNumber(
RecipientIdentifier.Single recipient, byte[] safetyNumber
) throws UnregisteredRecipientException {
- RecipientId recipientId;
- try {
- recipientId = recipientHelper.resolveRecipient(recipient);
- } catch (IOException e) {
- return false;
- }
- final var updated = identityHelper.trustIdentityVerifiedSafetyNumber(recipientId, safetyNumber);
- if (updated && this.isReceiving()) {
- needsToRetryFailedMessages = true;
- }
- return updated;
+ return trustIdentity(recipient,
+ r -> context.getIdentityHelper().trustIdentityVerifiedSafetyNumber(r, safetyNumber));
}
- /**
- * Trust all keys of this identity without verification
- *
- * @param recipient account of the identity
- */
@Override
public boolean trustIdentityAllKeys(RecipientIdentifier.Single recipient) throws UnregisteredRecipientException {
- RecipientId recipientId;
- try {
- recipientId = recipientHelper.resolveRecipient(recipient);
- } catch (IOException e) {
- return false;
- }
- final var updated = identityHelper.trustIdentityAllKeys(recipientId);
+ return trustIdentity(recipient, r -> context.getIdentityHelper().trustIdentityAllKeys(r));
+ }
+
+ private boolean trustIdentity(
+ RecipientIdentifier.Single recipient, Function<RecipientId, Boolean> trustMethod
+ ) throws UnregisteredRecipientException {
+ final var recipientId = context.getRecipientHelper().resolveRecipient(recipient);
+ final var updated = trustMethod.apply(recipientId);
if (updated && this.isReceiving()) {
- needsToRetryFailedMessages = true;
+ context.getReceiveHelper().setNeedsToRetryFailedMessages(true);
}
return updated;
}
+ @Override
+ public void addAddressChangedListener(final Runnable listener) {
+ synchronized (addressChangedListeners) {
+ addressChangedListeners.add(listener);
+ }
+ }
+
@Override
public void addClosedListener(final Runnable listener) {
synchronized (closedListeners) {
}
}
- private void handleIdentityFailure(
- final RecipientId recipientId,
- final org.whispersystems.signalservice.api.messages.SendMessageResult.IdentityFailure identityFailure
- ) {
- this.identityHelper.handleIdentityFailure(recipientId, identityFailure);
- }
-
@Override
- public void close() throws IOException {
+ public void close() {
Thread thread;
synchronized (messageHandlers) {
weakHandlers.clear();
executor.shutdown();
dependencies.getSignalWebSocket().disconnect();
+ disposable.dispose();
+
+ if (account != null) {
+ account.close();
+ }
synchronized (closedListeners) {
closedListeners.forEach(Runnable::run);
closedListeners.clear();
}
- if (account != null) {
- account.close();
- }
account = null;
}
}