Don't wake up destination transaction queue if they're not due for retry. (#16223)

This commit is contained in:
Erik Johnston 2023-09-04 17:14:09 +01:00 committed by GitHub
parent dcb2778341
commit d35bed8369
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
15 changed files with 228 additions and 90 deletions

View File

@ -0,0 +1 @@
Improve resource usage when sending data to a large number of remote hosts that are marked as "down".

View File

@ -49,7 +49,7 @@ from synapse.api.presence import UserPresenceState
from synapse.federation.sender import AbstractFederationSender, FederationSender from synapse.federation.sender import AbstractFederationSender, FederationSender
from synapse.metrics import LaterGauge from synapse.metrics import LaterGauge
from synapse.replication.tcp.streams.federation import FederationStream from synapse.replication.tcp.streams.federation import FederationStream
from synapse.types import JsonDict, ReadReceipt, RoomStreamToken from synapse.types import JsonDict, ReadReceipt, RoomStreamToken, StrCollection
from synapse.util.metrics import Measure from synapse.util.metrics import Measure
from .units import Edu from .units import Edu
@ -229,7 +229,7 @@ class FederationRemoteSendQueue(AbstractFederationSender):
""" """
# nothing to do here: the replication listener will handle it. # nothing to do here: the replication listener will handle it.
def send_presence_to_destinations( async def send_presence_to_destinations(
self, states: Iterable[UserPresenceState], destinations: Iterable[str] self, states: Iterable[UserPresenceState], destinations: Iterable[str]
) -> None: ) -> None:
"""As per FederationSender """As per FederationSender
@ -245,7 +245,9 @@ class FederationRemoteSendQueue(AbstractFederationSender):
self.notifier.on_new_replication_data() self.notifier.on_new_replication_data()
def send_device_messages(self, destination: str, immediate: bool = True) -> None: async def send_device_messages(
self, destinations: StrCollection, immediate: bool = True
) -> None:
"""As per FederationSender""" """As per FederationSender"""
# We don't need to replicate this as it gets sent down a different # We don't need to replicate this as it gets sent down a different
# stream. # stream.
@ -463,7 +465,7 @@ class ParsedFederationStreamData:
edus: Dict[str, List[Edu]] edus: Dict[str, List[Edu]]
def process_rows_for_federation( async def process_rows_for_federation(
transaction_queue: FederationSender, transaction_queue: FederationSender,
rows: List[FederationStream.FederationStreamRow], rows: List[FederationStream.FederationStreamRow],
) -> None: ) -> None:
@ -496,7 +498,7 @@ def process_rows_for_federation(
parsed_row.add_to_buffer(buff) parsed_row.add_to_buffer(buff)
for state, destinations in buff.presence_destinations: for state, destinations in buff.presence_destinations:
transaction_queue.send_presence_to_destinations( await transaction_queue.send_presence_to_destinations(
states=[state], destinations=destinations states=[state], destinations=destinations
) )

View File

@ -147,7 +147,10 @@ from twisted.internet import defer
import synapse.metrics import synapse.metrics
from synapse.api.presence import UserPresenceState from synapse.api.presence import UserPresenceState
from synapse.events import EventBase from synapse.events import EventBase
from synapse.federation.sender.per_destination_queue import PerDestinationQueue from synapse.federation.sender.per_destination_queue import (
CATCHUP_RETRY_INTERVAL,
PerDestinationQueue,
)
from synapse.federation.sender.transaction_manager import TransactionManager from synapse.federation.sender.transaction_manager import TransactionManager
from synapse.federation.units import Edu from synapse.federation.units import Edu
from synapse.logging.context import make_deferred_yieldable, run_in_background from synapse.logging.context import make_deferred_yieldable, run_in_background
@ -161,9 +164,10 @@ from synapse.metrics.background_process_metrics import (
run_as_background_process, run_as_background_process,
wrap_as_background_process, wrap_as_background_process,
) )
from synapse.types import JsonDict, ReadReceipt, RoomStreamToken from synapse.types import JsonDict, ReadReceipt, RoomStreamToken, StrCollection
from synapse.util import Clock from synapse.util import Clock
from synapse.util.metrics import Measure from synapse.util.metrics import Measure
from synapse.util.retryutils import filter_destinations_by_retry_limiter
if TYPE_CHECKING: if TYPE_CHECKING:
from synapse.events.presence_router import PresenceRouter from synapse.events.presence_router import PresenceRouter
@ -213,7 +217,7 @@ class AbstractFederationSender(metaclass=abc.ABCMeta):
raise NotImplementedError() raise NotImplementedError()
@abc.abstractmethod @abc.abstractmethod
def send_presence_to_destinations( async def send_presence_to_destinations(
self, states: Iterable[UserPresenceState], destinations: Iterable[str] self, states: Iterable[UserPresenceState], destinations: Iterable[str]
) -> None: ) -> None:
"""Send the given presence states to the given destinations. """Send the given presence states to the given destinations.
@ -242,9 +246,11 @@ class AbstractFederationSender(metaclass=abc.ABCMeta):
raise NotImplementedError() raise NotImplementedError()
@abc.abstractmethod @abc.abstractmethod
def send_device_messages(self, destination: str, immediate: bool = True) -> None: async def send_device_messages(
self, destinations: StrCollection, immediate: bool = True
) -> None:
"""Tells the sender that a new device message is ready to be sent to the """Tells the sender that a new device message is ready to be sent to the
destination. The `immediate` flag specifies whether the messages should destinations. The `immediate` flag specifies whether the messages should
be tried to be sent immediately, or whether it can be delayed for a be tried to be sent immediately, or whether it can be delayed for a
short while (to aid performance). short while (to aid performance).
""" """
@ -716,6 +722,13 @@ class FederationSender(AbstractFederationSender):
pdu.internal_metadata.stream_ordering, pdu.internal_metadata.stream_ordering,
) )
destinations = await filter_destinations_by_retry_limiter(
destinations,
clock=self.clock,
store=self.store,
retry_due_within_ms=CATCHUP_RETRY_INTERVAL,
)
for destination in destinations: for destination in destinations:
self._get_per_destination_queue(destination).send_pdu(pdu) self._get_per_destination_queue(destination).send_pdu(pdu)
@ -763,12 +776,20 @@ class FederationSender(AbstractFederationSender):
domains_set = await self._storage_controllers.state.get_current_hosts_in_room_or_partial_state_approximation( domains_set = await self._storage_controllers.state.get_current_hosts_in_room_or_partial_state_approximation(
room_id room_id
) )
domains = [ domains: StrCollection = [
d d
for d in domains_set for d in domains_set
if not self.is_mine_server_name(d) if not self.is_mine_server_name(d)
and self._federation_shard_config.should_handle(self._instance_name, d) and self._federation_shard_config.should_handle(self._instance_name, d)
] ]
domains = await filter_destinations_by_retry_limiter(
domains,
clock=self.clock,
store=self.store,
retry_due_within_ms=CATCHUP_RETRY_INTERVAL,
)
if not domains: if not domains:
return return
@ -816,7 +837,7 @@ class FederationSender(AbstractFederationSender):
for queue in queues: for queue in queues:
queue.flush_read_receipts_for_room(room_id) queue.flush_read_receipts_for_room(room_id)
def send_presence_to_destinations( async def send_presence_to_destinations(
self, states: Iterable[UserPresenceState], destinations: Iterable[str] self, states: Iterable[UserPresenceState], destinations: Iterable[str]
) -> None: ) -> None:
"""Send the given presence states to the given destinations. """Send the given presence states to the given destinations.
@ -831,13 +852,20 @@ class FederationSender(AbstractFederationSender):
for state in states: for state in states:
assert self.is_mine_id(state.user_id) assert self.is_mine_id(state.user_id)
destinations = await filter_destinations_by_retry_limiter(
[
d
for d in destinations
if self._federation_shard_config.should_handle(self._instance_name, d)
],
clock=self.clock,
store=self.store,
retry_due_within_ms=CATCHUP_RETRY_INTERVAL,
)
for destination in destinations: for destination in destinations:
if self.is_mine_server_name(destination): if self.is_mine_server_name(destination):
continue continue
if not self._federation_shard_config.should_handle(
self._instance_name, destination
):
continue
self._get_per_destination_queue(destination).send_presence( self._get_per_destination_queue(destination).send_presence(
states, start_loop=False states, start_loop=False
@ -896,21 +924,29 @@ class FederationSender(AbstractFederationSender):
else: else:
queue.send_edu(edu) queue.send_edu(edu)
def send_device_messages(self, destination: str, immediate: bool = True) -> None: async def send_device_messages(
if self.is_mine_server_name(destination): self, destinations: StrCollection, immediate: bool = True
logger.warning("Not sending device update to ourselves") ) -> None:
return destinations = await filter_destinations_by_retry_limiter(
[
destination
for destination in destinations
if self._federation_shard_config.should_handle(
self._instance_name, destination
)
and not self.is_mine_server_name(destination)
],
clock=self.clock,
store=self.store,
retry_due_within_ms=CATCHUP_RETRY_INTERVAL,
)
if not self._federation_shard_config.should_handle( for destination in destinations:
self._instance_name, destination if immediate:
): self._get_per_destination_queue(destination).attempt_new_transaction()
return else:
self._get_per_destination_queue(destination).mark_new_data()
if immediate: self._destination_wakeup_queue.add_to_queue(destination)
self._get_per_destination_queue(destination).attempt_new_transaction()
else:
self._get_per_destination_queue(destination).mark_new_data()
self._destination_wakeup_queue.add_to_queue(destination)
def wake_destination(self, destination: str) -> None: def wake_destination(self, destination: str) -> None:
"""Called when we want to retry sending transactions to a remote. """Called when we want to retry sending transactions to a remote.

View File

@ -59,6 +59,10 @@ sent_edus_by_type = Counter(
) )
# If the retry interval is larger than this then we enter "catchup" mode
CATCHUP_RETRY_INTERVAL = 60 * 60 * 1000
class PerDestinationQueue: class PerDestinationQueue:
""" """
Manages the per-destination transmission queues. Manages the per-destination transmission queues.
@ -370,7 +374,7 @@ class PerDestinationQueue:
), ),
) )
if e.retry_interval > 60 * 60 * 1000: if e.retry_interval > CATCHUP_RETRY_INTERVAL:
# we won't retry for another hour! # we won't retry for another hour!
# (this suggests a significant outage) # (this suggests a significant outage)
# We drop pending EDUs because otherwise they will # We drop pending EDUs because otherwise they will

View File

@ -836,17 +836,16 @@ class DeviceHandler(DeviceWorkerHandler):
user_id, user_id,
hosts, hosts,
) )
for host in hosts: await self.federation_sender.send_device_messages(
self.federation_sender.send_device_messages( hosts, immediate=False
host, immediate=False )
) # TODO: when called, this isn't in a logging context.
# TODO: when called, this isn't in a logging context. # This leads to log spam, sentry event spam, and massive
# This leads to log spam, sentry event spam, and massive # memory usage.
# memory usage. # See https://github.com/matrix-org/synapse/issues/12552.
# See https://github.com/matrix-org/synapse/issues/12552. # log_kv(
# log_kv( # {"message": "sent device update to host", "host": host}
# {"message": "sent device update to host", "host": host} # )
# )
if current_stream_id != stream_id: if current_stream_id != stream_id:
# Clear the set of hosts we've already sent to as we're # Clear the set of hosts we've already sent to as we're
@ -951,8 +950,9 @@ class DeviceHandler(DeviceWorkerHandler):
# Notify things that device lists need to be sent out. # Notify things that device lists need to be sent out.
self.notifier.notify_replication() self.notifier.notify_replication()
for host in potentially_changed_hosts: await self.federation_sender.send_device_messages(
self.federation_sender.send_device_messages(host, immediate=False) potentially_changed_hosts, immediate=False
)
def _update_device_from_client_ips( def _update_device_from_client_ips(

View File

@ -302,10 +302,9 @@ class DeviceMessageHandler:
) )
if self.federation_sender: if self.federation_sender:
for destination in remote_messages.keys(): # Enqueue a new federation transaction to send the new
# Enqueue a new federation transaction to send the new # device messages to each remote destination.
# device messages to each remote destination. await self.federation_sender.send_device_messages(remote_messages.keys())
self.federation_sender.send_device_messages(destination)
async def get_events_for_dehydrated_device( async def get_events_for_dehydrated_device(
self, self,

View File

@ -354,7 +354,9 @@ class BasePresenceHandler(abc.ABC):
) )
for destination, host_states in hosts_to_states.items(): for destination, host_states in hosts_to_states.items():
self._federation.send_presence_to_destinations(host_states, [destination]) await self._federation.send_presence_to_destinations(
host_states, [destination]
)
async def send_full_presence_to_users(self, user_ids: StrCollection) -> None: async def send_full_presence_to_users(self, user_ids: StrCollection) -> None:
""" """
@ -936,7 +938,7 @@ class PresenceHandler(BasePresenceHandler):
) )
for destination, states in hosts_to_states.items(): for destination, states in hosts_to_states.items():
self._federation_queue.send_presence_to_destinations( await self._federation_queue.send_presence_to_destinations(
states, [destination] states, [destination]
) )
@ -1508,7 +1510,7 @@ class PresenceHandler(BasePresenceHandler):
or state.status_msg is not None or state.status_msg is not None
] ]
self._federation_queue.send_presence_to_destinations( await self._federation_queue.send_presence_to_destinations(
destinations=newly_joined_remote_hosts, destinations=newly_joined_remote_hosts,
states=states, states=states,
) )
@ -1519,7 +1521,7 @@ class PresenceHandler(BasePresenceHandler):
prev_remote_hosts or newly_joined_remote_hosts prev_remote_hosts or newly_joined_remote_hosts
): ):
local_states = await self.current_state_for_users(newly_joined_local_users) local_states = await self.current_state_for_users(newly_joined_local_users)
self._federation_queue.send_presence_to_destinations( await self._federation_queue.send_presence_to_destinations(
destinations=prev_remote_hosts | newly_joined_remote_hosts, destinations=prev_remote_hosts | newly_joined_remote_hosts,
states=list(local_states.values()), states=list(local_states.values()),
) )
@ -2182,7 +2184,7 @@ class PresenceFederationQueue:
index = bisect(self._queue, (clear_before,)) index = bisect(self._queue, (clear_before,))
self._queue = self._queue[index:] self._queue = self._queue[index:]
def send_presence_to_destinations( async def send_presence_to_destinations(
self, states: Collection[UserPresenceState], destinations: StrCollection self, states: Collection[UserPresenceState], destinations: StrCollection
) -> None: ) -> None:
"""Send the presence states to the given destinations. """Send the presence states to the given destinations.
@ -2202,7 +2204,7 @@ class PresenceFederationQueue:
return return
if self._federation: if self._federation:
self._federation.send_presence_to_destinations( await self._federation.send_presence_to_destinations(
states=states, states=states,
destinations=destinations, destinations=destinations,
) )
@ -2325,7 +2327,7 @@ class PresenceFederationQueue:
for host, user_ids in hosts_to_users.items(): for host, user_ids in hosts_to_users.items():
states = await self._presence_handler.current_state_for_users(user_ids) states = await self._presence_handler.current_state_for_users(user_ids)
self._federation.send_presence_to_destinations( await self._federation.send_presence_to_destinations(
states=states.values(), states=states.values(),
destinations=[host], destinations=[host],
) )

View File

@ -26,9 +26,10 @@ from synapse.metrics.background_process_metrics import (
) )
from synapse.replication.tcp.streams import TypingStream from synapse.replication.tcp.streams import TypingStream
from synapse.streams import EventSource from synapse.streams import EventSource
from synapse.types import JsonDict, Requester, StreamKeyType, UserID from synapse.types import JsonDict, Requester, StrCollection, StreamKeyType, UserID
from synapse.util.caches.stream_change_cache import StreamChangeCache from synapse.util.caches.stream_change_cache import StreamChangeCache
from synapse.util.metrics import Measure from synapse.util.metrics import Measure
from synapse.util.retryutils import filter_destinations_by_retry_limiter
from synapse.util.wheel_timer import WheelTimer from synapse.util.wheel_timer import WheelTimer
if TYPE_CHECKING: if TYPE_CHECKING:
@ -150,8 +151,15 @@ class FollowerTypingHandler:
now=now, obj=member, then=now + FEDERATION_PING_INTERVAL now=now, obj=member, then=now + FEDERATION_PING_INTERVAL
) )
hosts = await self._storage_controllers.state.get_current_hosts_in_room( hosts: StrCollection = (
member.room_id await self._storage_controllers.state.get_current_hosts_in_room(
member.room_id
)
)
hosts = await filter_destinations_by_retry_limiter(
hosts,
clock=self.clock,
store=self.store,
) )
for domain in hosts: for domain in hosts:
if not self.is_mine_server_name(domain): if not self.is_mine_server_name(domain):

View File

@ -1180,7 +1180,7 @@ class ModuleApi:
# Send to remote destinations. # Send to remote destinations.
destination = UserID.from_string(user).domain destination = UserID.from_string(user).domain
presence_handler.get_federation_queue().send_presence_to_destinations( await presence_handler.get_federation_queue().send_presence_to_destinations(
presence_events, [destination] presence_events, [destination]
) )

View File

@ -422,7 +422,7 @@ class FederationSenderHandler:
# The federation stream contains things that we want to send out, e.g. # The federation stream contains things that we want to send out, e.g.
# presence, typing, etc. # presence, typing, etc.
if stream_name == "federation": if stream_name == "federation":
send_queue.process_rows_for_federation(self.federation_sender, rows) await send_queue.process_rows_for_federation(self.federation_sender, rows)
await self.update_token(token) await self.update_token(token)
# ... and when new receipts happen # ... and when new receipts happen
@ -439,16 +439,14 @@ class FederationSenderHandler:
for row in rows for row in rows
if not row.entity.startswith("@") and not row.is_signature if not row.entity.startswith("@") and not row.is_signature
} }
for host in hosts: await self.federation_sender.send_device_messages(hosts, immediate=False)
self.federation_sender.send_device_messages(host, immediate=False)
elif stream_name == ToDeviceStream.NAME: elif stream_name == ToDeviceStream.NAME:
# The to_device stream includes stuff to be pushed to both local # The to_device stream includes stuff to be pushed to both local
# clients and remote servers, so we ignore entities that start with # clients and remote servers, so we ignore entities that start with
# '@' (since they'll be local users rather than destinations). # '@' (since they'll be local users rather than destinations).
hosts = {row.entity for row in rows if not row.entity.startswith("@")} hosts = {row.entity for row in rows if not row.entity.startswith("@")}
for host in hosts: await self.federation_sender.send_device_messages(hosts)
self.federation_sender.send_device_messages(host)
async def _on_new_receipts( async def _on_new_receipts(
self, rows: Iterable[ReceiptsStream.ReceiptsStreamRow] self, rows: Iterable[ReceiptsStream.ReceiptsStreamRow]

View File

@ -14,7 +14,7 @@
import logging import logging
from enum import Enum from enum import Enum
from typing import TYPE_CHECKING, Iterable, List, Optional, Tuple, cast from typing import TYPE_CHECKING, Dict, Iterable, List, Optional, Tuple, cast
import attr import attr
from canonicaljson import encode_canonical_json from canonicaljson import encode_canonical_json
@ -28,8 +28,8 @@ from synapse.storage.database import (
LoggingTransaction, LoggingTransaction,
) )
from synapse.storage.databases.main.cache import CacheInvalidationWorkerStore from synapse.storage.databases.main.cache import CacheInvalidationWorkerStore
from synapse.types import JsonDict from synapse.types import JsonDict, StrCollection
from synapse.util.caches.descriptors import cached from synapse.util.caches.descriptors import cached, cachedList
if TYPE_CHECKING: if TYPE_CHECKING:
from synapse.server import HomeServer from synapse.server import HomeServer
@ -205,6 +205,26 @@ class TransactionWorkerStore(CacheInvalidationWorkerStore):
else: else:
return None return None
@cachedList(
cached_method_name="get_destination_retry_timings", list_name="destinations"
)
async def get_destination_retry_timings_batch(
self, destinations: StrCollection
) -> Dict[str, Optional[DestinationRetryTimings]]:
rows = await self.db_pool.simple_select_many_batch(
table="destinations",
iterable=destinations,
column="destination",
retcols=("destination", "failure_ts", "retry_last_ts", "retry_interval"),
desc="get_destination_retry_timings_batch",
)
return {
row.pop("destination"): DestinationRetryTimings(**row)
for row in rows
if row["retry_last_ts"] and row["failure_ts"] and row["retry_interval"]
}
async def set_destination_retry_timings( async def set_destination_retry_timings(
self, self,
destination: str, destination: str,

View File

@ -19,6 +19,7 @@ from typing import TYPE_CHECKING, Any, Optional, Type
from synapse.api.errors import CodeMessageException from synapse.api.errors import CodeMessageException
from synapse.metrics.background_process_metrics import run_as_background_process from synapse.metrics.background_process_metrics import run_as_background_process
from synapse.storage import DataStore from synapse.storage import DataStore
from synapse.types import StrCollection
from synapse.util import Clock from synapse.util import Clock
if TYPE_CHECKING: if TYPE_CHECKING:
@ -116,6 +117,30 @@ async def get_retry_limiter(
) )
async def filter_destinations_by_retry_limiter(
destinations: StrCollection,
clock: Clock,
store: DataStore,
retry_due_within_ms: int = 0,
) -> StrCollection:
"""Filter down the list of destinations to only those that will are either
alive or due for a retry (within `retry_due_within_ms`)
"""
if not destinations:
return destinations
retry_timings = await store.get_destination_retry_timings_batch(destinations)
now = int(clock.time_msec())
return [
destination
for destination, timings in retry_timings.items()
if timings is None
or timings.retry_last_ts + timings.retry_interval <= now + retry_due_within_ms
]
class RetryDestinationLimiter: class RetryDestinationLimiter:
def __init__( def __init__(
self, self,

View File

@ -75,7 +75,7 @@ class FederationSenderReceiptsTestCases(HomeserverTestCase):
thread_id=None, thread_id=None,
data={"ts": 1234}, data={"ts": 1234},
) )
self.successResultOf(defer.ensureDeferred(sender.send_read_receipt(receipt))) self.get_success(sender.send_read_receipt(receipt))
self.pump() self.pump()
@ -111,6 +111,9 @@ class FederationSenderReceiptsTestCases(HomeserverTestCase):
# * The same room / user on multiple threads. # * The same room / user on multiple threads.
# * A different user in the same room. # * A different user in the same room.
sender = self.hs.get_federation_sender() sender = self.hs.get_federation_sender()
# Hack so that we have a txn in-flight so we batch up read receipts
# below
sender.wake_destination("host2")
for user, thread in ( for user, thread in (
("alice", None), ("alice", None),
("alice", "thread"), ("alice", "thread"),
@ -125,9 +128,7 @@ class FederationSenderReceiptsTestCases(HomeserverTestCase):
thread_id=thread, thread_id=thread,
data={"ts": 1234}, data={"ts": 1234},
) )
self.successResultOf( defer.ensureDeferred(sender.send_read_receipt(receipt))
defer.ensureDeferred(sender.send_read_receipt(receipt))
)
self.pump() self.pump()
@ -191,7 +192,7 @@ class FederationSenderReceiptsTestCases(HomeserverTestCase):
thread_id=None, thread_id=None,
data={"ts": 1234}, data={"ts": 1234},
) )
self.successResultOf(defer.ensureDeferred(sender.send_read_receipt(receipt))) self.get_success(sender.send_read_receipt(receipt))
self.pump() self.pump()
@ -342,7 +343,9 @@ class FederationSenderDevicesTestCases(HomeserverTestCase):
self.reactor.advance(1) self.reactor.advance(1)
# a second call should produce no new device EDUs # a second call should produce no new device EDUs
self.hs.get_federation_sender().send_device_messages("host2") self.get_success(
self.hs.get_federation_sender().send_device_messages(["host2"])
)
self.assertEqual(self.edus, []) self.assertEqual(self.edus, [])
# a second device # a second device
@ -550,7 +553,9 @@ class FederationSenderDevicesTestCases(HomeserverTestCase):
# recover the server # recover the server
mock_send_txn.side_effect = self.record_transaction mock_send_txn.side_effect = self.record_transaction
self.hs.get_federation_sender().send_device_messages("host2") self.get_success(
self.hs.get_federation_sender().send_device_messages(["host2"])
)
# We queue up device list updates to be sent over federation, so we # We queue up device list updates to be sent over federation, so we
# advance to clear the queue. # advance to clear the queue.
@ -601,7 +606,9 @@ class FederationSenderDevicesTestCases(HomeserverTestCase):
# recover the server # recover the server
mock_send_txn.side_effect = self.record_transaction mock_send_txn.side_effect = self.record_transaction
self.hs.get_federation_sender().send_device_messages("host2") self.get_success(
self.hs.get_federation_sender().send_device_messages(["host2"])
)
# We queue up device list updates to be sent over federation, so we # We queue up device list updates to be sent over federation, so we
# advance to clear the queue. # advance to clear the queue.
@ -656,7 +663,9 @@ class FederationSenderDevicesTestCases(HomeserverTestCase):
# recover the server # recover the server
mock_send_txn.side_effect = self.record_transaction mock_send_txn.side_effect = self.record_transaction
self.hs.get_federation_sender().send_device_messages("host2") self.get_success(
self.hs.get_federation_sender().send_device_messages(["host2"])
)
# We queue up device list updates to be sent over federation, so we # We queue up device list updates to be sent over federation, so we
# advance to clear the queue. # advance to clear the queue.

View File

@ -909,8 +909,14 @@ class PresenceFederationQueueTestCase(unittest.HomeserverTestCase):
prev_token = self.queue.get_current_token(self.instance_name) prev_token = self.queue.get_current_token(self.instance_name)
self.queue.send_presence_to_destinations((state1, state2), ("dest1", "dest2")) self.get_success(
self.queue.send_presence_to_destinations((state3,), ("dest3",)) self.queue.send_presence_to_destinations(
(state1, state2), ("dest1", "dest2")
)
)
self.get_success(
self.queue.send_presence_to_destinations((state3,), ("dest3",))
)
now_token = self.queue.get_current_token(self.instance_name) now_token = self.queue.get_current_token(self.instance_name)
@ -946,11 +952,17 @@ class PresenceFederationQueueTestCase(unittest.HomeserverTestCase):
prev_token = self.queue.get_current_token(self.instance_name) prev_token = self.queue.get_current_token(self.instance_name)
self.queue.send_presence_to_destinations((state1, state2), ("dest1", "dest2")) self.get_success(
self.queue.send_presence_to_destinations(
(state1, state2), ("dest1", "dest2")
)
)
now_token = self.queue.get_current_token(self.instance_name) now_token = self.queue.get_current_token(self.instance_name)
self.queue.send_presence_to_destinations((state3,), ("dest3",)) self.get_success(
self.queue.send_presence_to_destinations((state3,), ("dest3",))
)
rows, upto_token, limited = self.get_success( rows, upto_token, limited = self.get_success(
self.queue.get_replication_rows("master", prev_token, now_token, 10) self.queue.get_replication_rows("master", prev_token, now_token, 10)
@ -989,8 +1001,14 @@ class PresenceFederationQueueTestCase(unittest.HomeserverTestCase):
prev_token = self.queue.get_current_token(self.instance_name) prev_token = self.queue.get_current_token(self.instance_name)
self.queue.send_presence_to_destinations((state1, state2), ("dest1", "dest2")) self.get_success(
self.queue.send_presence_to_destinations((state3,), ("dest3",)) self.queue.send_presence_to_destinations(
(state1, state2), ("dest1", "dest2")
)
)
self.get_success(
self.queue.send_presence_to_destinations((state3,), ("dest3",))
)
self.reactor.advance(10 * 60 * 1000) self.reactor.advance(10 * 60 * 1000)
@ -1005,8 +1023,14 @@ class PresenceFederationQueueTestCase(unittest.HomeserverTestCase):
prev_token = self.queue.get_current_token(self.instance_name) prev_token = self.queue.get_current_token(self.instance_name)
self.queue.send_presence_to_destinations((state1, state2), ("dest1", "dest2")) self.get_success(
self.queue.send_presence_to_destinations((state3,), ("dest3",)) self.queue.send_presence_to_destinations(
(state1, state2), ("dest1", "dest2")
)
)
self.get_success(
self.queue.send_presence_to_destinations((state3,), ("dest3",))
)
now_token = self.queue.get_current_token(self.instance_name) now_token = self.queue.get_current_token(self.instance_name)
@ -1033,11 +1057,17 @@ class PresenceFederationQueueTestCase(unittest.HomeserverTestCase):
prev_token = self.queue.get_current_token(self.instance_name) prev_token = self.queue.get_current_token(self.instance_name)
self.queue.send_presence_to_destinations((state1, state2), ("dest1", "dest2")) self.get_success(
self.queue.send_presence_to_destinations(
(state1, state2), ("dest1", "dest2")
)
)
self.reactor.advance(2 * 60 * 1000) self.reactor.advance(2 * 60 * 1000)
self.queue.send_presence_to_destinations((state3,), ("dest3",)) self.get_success(
self.queue.send_presence_to_destinations((state3,), ("dest3",))
)
self.reactor.advance(4 * 60 * 1000) self.reactor.advance(4 * 60 * 1000)
@ -1053,8 +1083,14 @@ class PresenceFederationQueueTestCase(unittest.HomeserverTestCase):
prev_token = self.queue.get_current_token(self.instance_name) prev_token = self.queue.get_current_token(self.instance_name)
self.queue.send_presence_to_destinations((state1, state2), ("dest1", "dest2")) self.get_success(
self.queue.send_presence_to_destinations((state3,), ("dest3",)) self.queue.send_presence_to_destinations(
(state1, state2), ("dest1", "dest2")
)
)
self.get_success(
self.queue.send_presence_to_destinations((state3,), ("dest3",))
)
now_token = self.queue.get_current_token(self.instance_name) now_token = self.queue.get_current_token(self.instance_name)

View File

@ -120,8 +120,6 @@ class TypingNotificationsTestCase(unittest.HomeserverTestCase):
self.datastore = hs.get_datastores().main self.datastore = hs.get_datastores().main
self.datastore.get_destination_retry_timings = AsyncMock(return_value=None)
self.datastore.get_device_updates_by_remote = AsyncMock( # type: ignore[method-assign] self.datastore.get_device_updates_by_remote = AsyncMock( # type: ignore[method-assign]
return_value=(0, []) return_value=(0, [])
) )