Publish "messages persisted" events
This commit is contained in:
parent
5aaf4cad20
commit
e536a40740
|
@ -58,6 +58,11 @@ public class PubSubClientEventManager extends RedisClusterPubSubAdapter<byte[],
|
||||||
.build()
|
.build()
|
||||||
.toByteArray();
|
.toByteArray();
|
||||||
|
|
||||||
|
private final byte[] MESSAGES_PERSISTED_EVENT_BYTES = ClientEvent.newBuilder()
|
||||||
|
.setMessagesPersisted(MessagesPersistedEvent.getDefaultInstance())
|
||||||
|
.build()
|
||||||
|
.toByteArray();
|
||||||
|
|
||||||
@Nullable
|
@Nullable
|
||||||
private FaultTolerantPubSubClusterConnection<byte[], byte[]> pubSubConnection;
|
private FaultTolerantPubSubClusterConnection<byte[], byte[]> pubSubConnection;
|
||||||
|
|
||||||
|
@ -240,10 +245,29 @@ public class PubSubClientEventManager extends RedisClusterPubSubAdapter<byte[],
|
||||||
}
|
}
|
||||||
|
|
||||||
return pubSubConnection.withPubSubConnection(connection ->
|
return pubSubConnection.withPubSubConnection(connection ->
|
||||||
connection.async().spublish(getClientPresenceKey(accountIdentifier, deviceId), NEW_MESSAGE_EVENT_BYTES))
|
connection.async().spublish(getClientPresenceKey(accountIdentifier, deviceId), NEW_MESSAGE_EVENT_BYTES))
|
||||||
.thenApply(listeners -> listeners > 0);
|
.thenApply(listeners -> listeners > 0);
|
||||||
}
|
}
|
||||||
|
|
||||||
|
/**
|
||||||
|
* Publishes an event notifying a specific device that messages have been persisted from short-term to long-term
|
||||||
|
* storage.
|
||||||
|
*
|
||||||
|
* @param accountIdentifier the account identifier for which messages have been persisted
|
||||||
|
* @param deviceId the ID of the device within the target account
|
||||||
|
*
|
||||||
|
* @return a future that completes when the event has been published
|
||||||
|
*/
|
||||||
|
public CompletionStage<Void> handleMessagesPersisted(final UUID accountIdentifier, final byte deviceId) {
|
||||||
|
if (pubSubConnection == null) {
|
||||||
|
throw new IllegalStateException("Presence manager not started");
|
||||||
|
}
|
||||||
|
|
||||||
|
return pubSubConnection.withPubSubConnection(connection ->
|
||||||
|
connection.async().spublish(getClientPresenceKey(accountIdentifier, deviceId), MESSAGES_PERSISTED_EVENT_BYTES))
|
||||||
|
.thenRun(Util.NOOP);
|
||||||
|
}
|
||||||
|
|
||||||
/**
|
/**
|
||||||
* Tests whether a client with the given account/device is connected to this presence manager instance.
|
* Tests whether a client with the given account/device is connected to this presence manager instance.
|
||||||
*
|
*
|
||||||
|
|
|
@ -22,6 +22,7 @@ import org.slf4j.Logger;
|
||||||
import org.slf4j.LoggerFactory;
|
import org.slf4j.LoggerFactory;
|
||||||
import org.whispersystems.textsecuregcm.configuration.dynamic.DynamicConfiguration;
|
import org.whispersystems.textsecuregcm.configuration.dynamic.DynamicConfiguration;
|
||||||
import org.whispersystems.textsecuregcm.entities.MessageProtos;
|
import org.whispersystems.textsecuregcm.entities.MessageProtos;
|
||||||
|
import org.whispersystems.textsecuregcm.push.PubSubClientEventManager;
|
||||||
import org.whispersystems.textsecuregcm.util.Util;
|
import org.whispersystems.textsecuregcm.util.Util;
|
||||||
import software.amazon.awssdk.services.dynamodb.model.ItemCollectionSizeLimitExceededException;
|
import software.amazon.awssdk.services.dynamodb.model.ItemCollectionSizeLimitExceededException;
|
||||||
|
|
||||||
|
@ -30,6 +31,7 @@ public class MessagePersister implements Managed {
|
||||||
private final MessagesCache messagesCache;
|
private final MessagesCache messagesCache;
|
||||||
private final MessagesManager messagesManager;
|
private final MessagesManager messagesManager;
|
||||||
private final AccountsManager accountsManager;
|
private final AccountsManager accountsManager;
|
||||||
|
private final PubSubClientEventManager pubSubClientEventManager;
|
||||||
|
|
||||||
private final Duration persistDelay;
|
private final Duration persistDelay;
|
||||||
|
|
||||||
|
@ -63,13 +65,16 @@ public class MessagePersister implements Managed {
|
||||||
|
|
||||||
public MessagePersister(final MessagesCache messagesCache, final MessagesManager messagesManager,
|
public MessagePersister(final MessagesCache messagesCache, final MessagesManager messagesManager,
|
||||||
final AccountsManager accountsManager,
|
final AccountsManager accountsManager,
|
||||||
final DynamicConfigurationManager<DynamicConfiguration> dynamicConfigurationManager, final Duration persistDelay,
|
final PubSubClientEventManager pubSubClientEventManager,
|
||||||
|
final DynamicConfigurationManager<DynamicConfiguration> dynamicConfigurationManager,
|
||||||
|
final Duration persistDelay,
|
||||||
final int dedicatedProcessWorkerThreadCount
|
final int dedicatedProcessWorkerThreadCount
|
||||||
) {
|
) {
|
||||||
|
|
||||||
this.messagesCache = messagesCache;
|
this.messagesCache = messagesCache;
|
||||||
this.messagesManager = messagesManager;
|
this.messagesManager = messagesManager;
|
||||||
this.accountsManager = accountsManager;
|
this.accountsManager = accountsManager;
|
||||||
|
this.pubSubClientEventManager = pubSubClientEventManager;
|
||||||
this.persistDelay = persistDelay;
|
this.persistDelay = persistDelay;
|
||||||
this.workerThreads = new Thread[dedicatedProcessWorkerThreadCount];
|
this.workerThreads = new Thread[dedicatedProcessWorkerThreadCount];
|
||||||
|
|
||||||
|
@ -206,6 +211,7 @@ public class MessagePersister implements Managed {
|
||||||
maybeUnlink(account, deviceId); // may throw, in which case we'll retry later by the usual mechanism
|
maybeUnlink(account, deviceId); // may throw, in which case we'll retry later by the usual mechanism
|
||||||
} finally {
|
} finally {
|
||||||
messagesCache.unlockQueueForPersistence(accountUuid, deviceId);
|
messagesCache.unlockQueueForPersistence(accountUuid, deviceId);
|
||||||
|
pubSubClientEventManager.handleMessagesPersisted(accountUuid, deviceId);
|
||||||
sample.stop(persistQueueTimer);
|
sample.stop(persistQueueTimer);
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -76,6 +76,7 @@ record CommandDependencies(
|
||||||
ReportMessageManager reportMessageManager,
|
ReportMessageManager reportMessageManager,
|
||||||
MessagesCache messagesCache,
|
MessagesCache messagesCache,
|
||||||
MessagesManager messagesManager,
|
MessagesManager messagesManager,
|
||||||
|
PubSubClientEventManager pubSubClientEventManager,
|
||||||
KeysManager keysManager,
|
KeysManager keysManager,
|
||||||
APNSender apnSender,
|
APNSender apnSender,
|
||||||
FcmSender fcmSender,
|
FcmSender fcmSender,
|
||||||
|
@ -271,6 +272,7 @@ record CommandDependencies(
|
||||||
reportMessageManager,
|
reportMessageManager,
|
||||||
messagesCache,
|
messagesCache,
|
||||||
messagesManager,
|
messagesManager,
|
||||||
|
pubSubClientEventManager,
|
||||||
keys,
|
keys,
|
||||||
apnSender,
|
apnSender,
|
||||||
fcmSender,
|
fcmSender,
|
||||||
|
|
|
@ -60,8 +60,11 @@ public class MessagePersisterServiceCommand extends ServerCommand<WhisperServerC
|
||||||
});
|
});
|
||||||
}
|
}
|
||||||
|
|
||||||
final MessagePersister messagePersister = new MessagePersister(deps.messagesCache(), deps.messagesManager(),
|
final MessagePersister messagePersister = new MessagePersister(deps.messagesCache(),
|
||||||
deps.accountsManager(), deps.dynamicConfigurationManager(),
|
deps.messagesManager(),
|
||||||
|
deps.accountsManager(),
|
||||||
|
deps.pubSubClientEventManager(),
|
||||||
|
deps.dynamicConfigurationManager(),
|
||||||
Duration.ofMinutes(configuration.getMessageCacheConfiguration().getPersistDelayMinutes()),
|
Duration.ofMinutes(configuration.getMessageCacheConfiguration().getPersistDelayMinutes()),
|
||||||
namespace.getInt(WORKER_COUNT));
|
namespace.getInt(WORKER_COUNT));
|
||||||
|
|
||||||
|
|
|
@ -20,8 +20,10 @@ import io.lettuce.core.cluster.pubsub.api.async.RedisClusterPubSubAsyncCommands;
|
||||||
import io.lettuce.core.cluster.pubsub.api.sync.RedisClusterPubSubCommands;
|
import io.lettuce.core.cluster.pubsub.api.sync.RedisClusterPubSubCommands;
|
||||||
import java.util.List;
|
import java.util.List;
|
||||||
import java.util.UUID;
|
import java.util.UUID;
|
||||||
|
import java.util.concurrent.CountDownLatch;
|
||||||
import java.util.concurrent.ExecutorService;
|
import java.util.concurrent.ExecutorService;
|
||||||
import java.util.concurrent.Executors;
|
import java.util.concurrent.Executors;
|
||||||
|
import java.util.concurrent.TimeUnit;
|
||||||
import java.util.concurrent.atomic.AtomicBoolean;
|
import java.util.concurrent.atomic.AtomicBoolean;
|
||||||
import java.util.stream.IntStream;
|
import java.util.stream.IntStream;
|
||||||
import org.junit.jupiter.api.AfterAll;
|
import org.junit.jupiter.api.AfterAll;
|
||||||
|
@ -97,8 +99,8 @@ class PubSubClientEventManagerTest {
|
||||||
final byte deviceId = Device.PRIMARY_ID;
|
final byte deviceId = Device.PRIMARY_ID;
|
||||||
|
|
||||||
final AtomicBoolean firstListenerDisplaced = new AtomicBoolean(false);
|
final AtomicBoolean firstListenerDisplaced = new AtomicBoolean(false);
|
||||||
final AtomicBoolean secondListenerDisplaced = new AtomicBoolean(false);
|
|
||||||
|
|
||||||
|
final AtomicBoolean secondListenerDisplaced = new AtomicBoolean(false);
|
||||||
final AtomicBoolean firstListenerConnectedElsewhere = new AtomicBoolean(false);
|
final AtomicBoolean firstListenerConnectedElsewhere = new AtomicBoolean(false);
|
||||||
|
|
||||||
localPresenceManager.handleClientConnected(accountIdentifier, deviceId, new ClientEventAdapter() {
|
localPresenceManager.handleClientConnected(accountIdentifier, deviceId, new ClientEventAdapter() {
|
||||||
|
@ -144,15 +146,12 @@ class PubSubClientEventManagerTest {
|
||||||
final UUID accountIdentifier = UUID.randomUUID();
|
final UUID accountIdentifier = UUID.randomUUID();
|
||||||
final byte deviceId = Device.PRIMARY_ID;
|
final byte deviceId = Device.PRIMARY_ID;
|
||||||
|
|
||||||
final AtomicBoolean messageReceived = new AtomicBoolean(false);
|
final CountDownLatch messageReceivedLatch = new CountDownLatch(1);
|
||||||
|
|
||||||
localPresenceManager.handleClientConnected(accountIdentifier, deviceId, new ClientEventAdapter() {
|
localPresenceManager.handleClientConnected(accountIdentifier, deviceId, new ClientEventAdapter() {
|
||||||
@Override
|
@Override
|
||||||
public void handleNewMessageAvailable() {
|
public void handleNewMessageAvailable() {
|
||||||
synchronized (messageReceived) {
|
messageReceivedLatch.countDown();
|
||||||
messageReceived.set(true);
|
|
||||||
messageReceived.notifyAll();
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
}).toCompletableFuture().join();
|
}).toCompletableFuture().join();
|
||||||
|
|
||||||
|
@ -161,13 +160,32 @@ class PubSubClientEventManagerTest {
|
||||||
|
|
||||||
assertTrue(messagePresenceManager.handleNewMessageAvailable(accountIdentifier, deviceId).toCompletableFuture().join());
|
assertTrue(messagePresenceManager.handleNewMessageAvailable(accountIdentifier, deviceId).toCompletableFuture().join());
|
||||||
|
|
||||||
synchronized (messageReceived) {
|
assertTrue(messageReceivedLatch.await(2, TimeUnit.SECONDS),
|
||||||
while (!messageReceived.get()) {
|
"Message not received within time limit");
|
||||||
messageReceived.wait();
|
}
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
assertTrue(messageReceived.get());
|
@ParameterizedTest
|
||||||
|
@ValueSource(booleans = {true, false})
|
||||||
|
void handleMessagesPersisted(final boolean messagesPersistedRemotely) throws InterruptedException {
|
||||||
|
final UUID accountIdentifier = UUID.randomUUID();
|
||||||
|
final byte deviceId = Device.PRIMARY_ID;
|
||||||
|
|
||||||
|
final CountDownLatch messagesPersistedLatch = new CountDownLatch(1);
|
||||||
|
|
||||||
|
localPresenceManager.handleClientConnected(accountIdentifier, deviceId, new ClientEventAdapter() {
|
||||||
|
@Override
|
||||||
|
public void handleMessagesPersistedPubSub() {
|
||||||
|
messagesPersistedLatch.countDown();
|
||||||
|
}
|
||||||
|
}).toCompletableFuture().join();
|
||||||
|
|
||||||
|
final PubSubClientEventManager persistingPresenceManager =
|
||||||
|
messagesPersistedRemotely ? remotePresenceManager : localPresenceManager;
|
||||||
|
|
||||||
|
persistingPresenceManager.handleMessagesPersisted(accountIdentifier, deviceId).toCompletableFuture().join();
|
||||||
|
|
||||||
|
assertTrue(messagesPersistedLatch.await(2, TimeUnit.SECONDS),
|
||||||
|
"Message persistence event not received within time limit");
|
||||||
}
|
}
|
||||||
|
|
||||||
@Test
|
@Test
|
||||||
|
|
|
@ -9,6 +9,7 @@ import static org.junit.jupiter.api.Assertions.assertEquals;
|
||||||
import static org.junit.jupiter.api.Assertions.assertTimeoutPreemptively;
|
import static org.junit.jupiter.api.Assertions.assertTimeoutPreemptively;
|
||||||
import static org.junit.jupiter.api.Assertions.fail;
|
import static org.junit.jupiter.api.Assertions.fail;
|
||||||
import static org.mockito.Mockito.mock;
|
import static org.mockito.Mockito.mock;
|
||||||
|
import static org.mockito.Mockito.verify;
|
||||||
import static org.mockito.Mockito.when;
|
import static org.mockito.Mockito.when;
|
||||||
|
|
||||||
import com.google.protobuf.ByteString;
|
import com.google.protobuf.ByteString;
|
||||||
|
@ -32,6 +33,7 @@ import org.junit.jupiter.api.Test;
|
||||||
import org.junit.jupiter.api.extension.RegisterExtension;
|
import org.junit.jupiter.api.extension.RegisterExtension;
|
||||||
import org.whispersystems.textsecuregcm.configuration.dynamic.DynamicConfiguration;
|
import org.whispersystems.textsecuregcm.configuration.dynamic.DynamicConfiguration;
|
||||||
import org.whispersystems.textsecuregcm.entities.MessageProtos;
|
import org.whispersystems.textsecuregcm.entities.MessageProtos;
|
||||||
|
import org.whispersystems.textsecuregcm.push.PubSubClientEventManager;
|
||||||
import org.whispersystems.textsecuregcm.redis.RedisClusterExtension;
|
import org.whispersystems.textsecuregcm.redis.RedisClusterExtension;
|
||||||
import org.whispersystems.textsecuregcm.storage.DynamoDbExtensionSchema.Tables;
|
import org.whispersystems.textsecuregcm.storage.DynamoDbExtensionSchema.Tables;
|
||||||
import org.whispersystems.textsecuregcm.tests.util.DevicesHelper;
|
import org.whispersystems.textsecuregcm.tests.util.DevicesHelper;
|
||||||
|
@ -53,6 +55,7 @@ class MessagePersisterIntegrationTest {
|
||||||
private ExecutorService messageDeletionExecutorService;
|
private ExecutorService messageDeletionExecutorService;
|
||||||
private MessagesCache messagesCache;
|
private MessagesCache messagesCache;
|
||||||
private MessagesManager messagesManager;
|
private MessagesManager messagesManager;
|
||||||
|
private PubSubClientEventManager pubSubClientEventManager;
|
||||||
private MessagePersister messagePersister;
|
private MessagePersister messagePersister;
|
||||||
private Account account;
|
private Account account;
|
||||||
|
|
||||||
|
@ -82,8 +85,10 @@ class MessagePersisterIntegrationTest {
|
||||||
messageDeliveryScheduler, messageDeletionExecutorService, Clock.systemUTC(), dynamicConfigurationManager);
|
messageDeliveryScheduler, messageDeletionExecutorService, Clock.systemUTC(), dynamicConfigurationManager);
|
||||||
messagesManager = new MessagesManager(messagesDynamoDb, messagesCache, mock(ReportMessageManager.class),
|
messagesManager = new MessagesManager(messagesDynamoDb, messagesCache, mock(ReportMessageManager.class),
|
||||||
messageDeletionExecutorService);
|
messageDeletionExecutorService);
|
||||||
|
pubSubClientEventManager = mock(PubSubClientEventManager.class);
|
||||||
|
|
||||||
messagePersister = new MessagePersister(messagesCache, messagesManager, accountsManager,
|
messagePersister = new MessagePersister(messagesCache, messagesManager, accountsManager,
|
||||||
dynamicConfigurationManager, PERSIST_DELAY, 1);
|
pubSubClientEventManager, dynamicConfigurationManager, PERSIST_DELAY, 1);
|
||||||
|
|
||||||
account = mock(Account.class);
|
account = mock(Account.class);
|
||||||
|
|
||||||
|
@ -178,6 +183,8 @@ class MessagePersisterIntegrationTest {
|
||||||
.toList();
|
.toList();
|
||||||
|
|
||||||
assertEquals(expectedMessages, persistedMessages);
|
assertEquals(expectedMessages, persistedMessages);
|
||||||
|
|
||||||
|
verify(pubSubClientEventManager).handleMessagesPersisted(account.getUuid(), Device.PRIMARY_ID);
|
||||||
});
|
});
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
|
@ -46,6 +46,7 @@ import org.mockito.ArgumentCaptor;
|
||||||
import org.mockito.stubbing.Answer;
|
import org.mockito.stubbing.Answer;
|
||||||
import org.whispersystems.textsecuregcm.configuration.dynamic.DynamicConfiguration;
|
import org.whispersystems.textsecuregcm.configuration.dynamic.DynamicConfiguration;
|
||||||
import org.whispersystems.textsecuregcm.entities.MessageProtos;
|
import org.whispersystems.textsecuregcm.entities.MessageProtos;
|
||||||
|
import org.whispersystems.textsecuregcm.push.PubSubClientEventManager;
|
||||||
import org.whispersystems.textsecuregcm.redis.RedisClusterExtension;
|
import org.whispersystems.textsecuregcm.redis.RedisClusterExtension;
|
||||||
import org.whispersystems.textsecuregcm.tests.util.DevicesHelper;
|
import org.whispersystems.textsecuregcm.tests.util.DevicesHelper;
|
||||||
import reactor.core.scheduler.Scheduler;
|
import reactor.core.scheduler.Scheduler;
|
||||||
|
@ -66,6 +67,7 @@ class MessagePersisterTest {
|
||||||
private MessagePersister messagePersister;
|
private MessagePersister messagePersister;
|
||||||
private AccountsManager accountsManager;
|
private AccountsManager accountsManager;
|
||||||
private MessagesManager messagesManager;
|
private MessagesManager messagesManager;
|
||||||
|
private PubSubClientEventManager pubSubClientEventManager;
|
||||||
private Account destinationAccount;
|
private Account destinationAccount;
|
||||||
|
|
||||||
private static final UUID DESTINATION_ACCOUNT_UUID = UUID.randomUUID();
|
private static final UUID DESTINATION_ACCOUNT_UUID = UUID.randomUUID();
|
||||||
|
@ -100,7 +102,8 @@ class MessagePersisterTest {
|
||||||
messageDeliveryScheduler = Schedulers.newBoundedElastic(10, 10_000, "messageDelivery");
|
messageDeliveryScheduler = Schedulers.newBoundedElastic(10, 10_000, "messageDelivery");
|
||||||
messagesCache = new MessagesCache(REDIS_CLUSTER_EXTENSION.getRedisCluster(), sharedExecutorService,
|
messagesCache = new MessagesCache(REDIS_CLUSTER_EXTENSION.getRedisCluster(), sharedExecutorService,
|
||||||
messageDeliveryScheduler, sharedExecutorService, Clock.systemUTC(), dynamicConfigurationManager);
|
messageDeliveryScheduler, sharedExecutorService, Clock.systemUTC(), dynamicConfigurationManager);
|
||||||
messagePersister = new MessagePersister(messagesCache, messagesManager, accountsManager,
|
pubSubClientEventManager = mock(PubSubClientEventManager.class);
|
||||||
|
messagePersister = new MessagePersister(messagesCache, messagesManager, accountsManager, pubSubClientEventManager,
|
||||||
dynamicConfigurationManager, PERSIST_DELAY, 1);
|
dynamicConfigurationManager, PERSIST_DELAY, 1);
|
||||||
|
|
||||||
when(messagesManager.clear(any(UUID.class), anyByte())).thenReturn(CompletableFuture.completedFuture(null));
|
when(messagesManager.clear(any(UUID.class), anyByte())).thenReturn(CompletableFuture.completedFuture(null));
|
||||||
|
@ -154,6 +157,8 @@ class MessagePersisterTest {
|
||||||
verify(messagesDynamoDb, atLeastOnce()).store(messagesCaptor.capture(), eq(DESTINATION_ACCOUNT_UUID),
|
verify(messagesDynamoDb, atLeastOnce()).store(messagesCaptor.capture(), eq(DESTINATION_ACCOUNT_UUID),
|
||||||
eq(DESTINATION_DEVICE));
|
eq(DESTINATION_DEVICE));
|
||||||
assertEquals(messageCount, messagesCaptor.getAllValues().stream().mapToInt(List::size).sum());
|
assertEquals(messageCount, messagesCaptor.getAllValues().stream().mapToInt(List::size).sum());
|
||||||
|
|
||||||
|
verify(pubSubClientEventManager).handleMessagesPersisted(DESTINATION_ACCOUNT_UUID, DESTINATION_DEVICE_ID);
|
||||||
}
|
}
|
||||||
|
|
||||||
@Test
|
@Test
|
||||||
|
@ -223,6 +228,8 @@ class MessagePersisterTest {
|
||||||
assertEquals(List.of(queueName),
|
assertEquals(List.of(queueName),
|
||||||
messagesCache.getQueuesToPersist(SlotHash.getSlot(queueName),
|
messagesCache.getQueuesToPersist(SlotHash.getSlot(queueName),
|
||||||
Instant.now().plus(messagePersister.getPersistDelay()), 1));
|
Instant.now().plus(messagePersister.getPersistDelay()), 1));
|
||||||
|
|
||||||
|
verify(pubSubClientEventManager).handleMessagesPersisted(DESTINATION_ACCOUNT_UUID, DESTINATION_DEVICE_ID);
|
||||||
}
|
}
|
||||||
|
|
||||||
@Test
|
@Test
|
||||||
|
@ -241,6 +248,8 @@ class MessagePersisterTest {
|
||||||
assertTimeoutPreemptively(Duration.ofSeconds(1), () ->
|
assertTimeoutPreemptively(Duration.ofSeconds(1), () ->
|
||||||
assertThrows(MessagePersistenceException.class,
|
assertThrows(MessagePersistenceException.class,
|
||||||
() -> messagePersister.persistQueue(destinationAccount, DESTINATION_DEVICE)));
|
() -> messagePersister.persistQueue(destinationAccount, DESTINATION_DEVICE)));
|
||||||
|
|
||||||
|
verify(pubSubClientEventManager).handleMessagesPersisted(DESTINATION_ACCOUNT_UUID, DESTINATION_DEVICE_ID);
|
||||||
}
|
}
|
||||||
|
|
||||||
@Test
|
@Test
|
||||||
|
|
|
@ -73,6 +73,7 @@ class FinishPushNotificationExperimentCommandTest {
|
||||||
null,
|
null,
|
||||||
null,
|
null,
|
||||||
null,
|
null,
|
||||||
|
null,
|
||||||
pushNotificationExperimentSamples,
|
pushNotificationExperimentSamples,
|
||||||
null,
|
null,
|
||||||
null,
|
null,
|
||||||
|
|
|
@ -66,6 +66,7 @@ class NotifyIdleDevicesCommandTest {
|
||||||
null,
|
null,
|
||||||
null,
|
null,
|
||||||
null,
|
null,
|
||||||
|
null,
|
||||||
null);
|
null);
|
||||||
|
|
||||||
this.idleDeviceNotificationScheduler = idleDeviceNotificationScheduler;
|
this.idleDeviceNotificationScheduler = idleDeviceNotificationScheduler;
|
||||||
|
|
|
@ -62,6 +62,7 @@ class StartPushNotificationExperimentCommandTest {
|
||||||
null,
|
null,
|
||||||
null,
|
null,
|
||||||
null,
|
null,
|
||||||
|
null,
|
||||||
pushNotificationExperimentSamples,
|
pushNotificationExperimentSamples,
|
||||||
null,
|
null,
|
||||||
null,
|
null,
|
||||||
|
|
Loading…
Reference in New Issue