mirror of
https://git.anonymousland.org/anonymousland/synapse.git
synced 2024-10-01 11:49:51 -04:00
Optimise queueing of inbound replication commands (#7861)
When we get behind on replication, we tend to stack up background processes behind a linearizer. Bg processes are heavy (particularly with respect to prometheus metrics) and linearizers aren't terribly efficient once the queue gets long either. A better approach is to maintain a queue of requests to be processed, and nominate a single process to work its way through the queue. Fixes: #7444
This commit is contained in:
parent
346476df21
commit
e5300063ed
1
changelog.d/7861.misc
Normal file
1
changelog.d/7861.misc
Normal file
@ -0,0 +1 @@
|
|||||||
|
Optimise queueing of inbound replication commands.
|
@ -14,9 +14,21 @@
|
|||||||
# See the License for the specific language governing permissions and
|
# See the License for the specific language governing permissions and
|
||||||
# limitations under the License.
|
# limitations under the License.
|
||||||
import logging
|
import logging
|
||||||
from typing import Any, Dict, Iterable, Iterator, List, Optional, Set, Tuple, TypeVar
|
from typing import (
|
||||||
|
Any,
|
||||||
|
Dict,
|
||||||
|
Iterable,
|
||||||
|
Iterator,
|
||||||
|
List,
|
||||||
|
Optional,
|
||||||
|
Set,
|
||||||
|
Tuple,
|
||||||
|
TypeVar,
|
||||||
|
Union,
|
||||||
|
)
|
||||||
|
|
||||||
from prometheus_client import Counter
|
from prometheus_client import Counter
|
||||||
|
from typing_extensions import Deque
|
||||||
|
|
||||||
from twisted.internet.protocol import ReconnectingClientFactory
|
from twisted.internet.protocol import ReconnectingClientFactory
|
||||||
|
|
||||||
@ -44,7 +56,6 @@ from synapse.replication.tcp.streams import (
|
|||||||
Stream,
|
Stream,
|
||||||
TypingStream,
|
TypingStream,
|
||||||
)
|
)
|
||||||
from synapse.util.async_helpers import Linearizer
|
|
||||||
|
|
||||||
logger = logging.getLogger(__name__)
|
logger = logging.getLogger(__name__)
|
||||||
|
|
||||||
@ -62,6 +73,12 @@ invalidate_cache_counter = Counter(
|
|||||||
user_ip_cache_counter = Counter("synapse_replication_tcp_resource_user_ip_cache", "")
|
user_ip_cache_counter = Counter("synapse_replication_tcp_resource_user_ip_cache", "")
|
||||||
|
|
||||||
|
|
||||||
|
# the type of the entries in _command_queues_by_stream
|
||||||
|
_StreamCommandQueue = Deque[
|
||||||
|
Tuple[Union[RdataCommand, PositionCommand], AbstractConnection]
|
||||||
|
]
|
||||||
|
|
||||||
|
|
||||||
class ReplicationCommandHandler:
|
class ReplicationCommandHandler:
|
||||||
"""Handles incoming commands from replication as well as sending commands
|
"""Handles incoming commands from replication as well as sending commands
|
||||||
back out to connections.
|
back out to connections.
|
||||||
@ -116,10 +133,6 @@ class ReplicationCommandHandler:
|
|||||||
|
|
||||||
self._streams_to_replicate.append(stream)
|
self._streams_to_replicate.append(stream)
|
||||||
|
|
||||||
self._position_linearizer = Linearizer(
|
|
||||||
"replication_position", clock=self._clock
|
|
||||||
)
|
|
||||||
|
|
||||||
# Map of stream name to batched updates. See RdataCommand for info on
|
# Map of stream name to batched updates. See RdataCommand for info on
|
||||||
# how batching works.
|
# how batching works.
|
||||||
self._pending_batches = {} # type: Dict[str, List[Any]]
|
self._pending_batches = {} # type: Dict[str, List[Any]]
|
||||||
@ -131,10 +144,6 @@ class ReplicationCommandHandler:
|
|||||||
# outgoing replication commands to.)
|
# outgoing replication commands to.)
|
||||||
self._connections = [] # type: List[AbstractConnection]
|
self._connections = [] # type: List[AbstractConnection]
|
||||||
|
|
||||||
# For each connection, the incoming stream names that are coming from
|
|
||||||
# that connection.
|
|
||||||
self._streams_by_connection = {} # type: Dict[AbstractConnection, Set[str]]
|
|
||||||
|
|
||||||
LaterGauge(
|
LaterGauge(
|
||||||
"synapse_replication_tcp_resource_total_connections",
|
"synapse_replication_tcp_resource_total_connections",
|
||||||
"",
|
"",
|
||||||
@ -142,6 +151,32 @@ class ReplicationCommandHandler:
|
|||||||
lambda: len(self._connections),
|
lambda: len(self._connections),
|
||||||
)
|
)
|
||||||
|
|
||||||
|
# When POSITION or RDATA commands arrive, we stick them in a queue and process
|
||||||
|
# them in order in a separate background process.
|
||||||
|
|
||||||
|
# the streams which are currently being processed by _unsafe_process_stream
|
||||||
|
self._processing_streams = set() # type: Set[str]
|
||||||
|
|
||||||
|
# for each stream, a queue of commands that are awaiting processing, and the
|
||||||
|
# connection that they arrived on.
|
||||||
|
self._command_queues_by_stream = {
|
||||||
|
stream_name: _StreamCommandQueue() for stream_name in self._streams
|
||||||
|
}
|
||||||
|
|
||||||
|
# For each connection, the incoming stream names that have received a POSITION
|
||||||
|
# from that connection.
|
||||||
|
self._streams_by_connection = {} # type: Dict[AbstractConnection, Set[str]]
|
||||||
|
|
||||||
|
LaterGauge(
|
||||||
|
"synapse_replication_tcp_command_queue",
|
||||||
|
"Number of inbound RDATA/POSITION commands queued for processing",
|
||||||
|
["stream_name"],
|
||||||
|
lambda: {
|
||||||
|
(stream_name,): len(queue)
|
||||||
|
for stream_name, queue in self._command_queues_by_stream.items()
|
||||||
|
},
|
||||||
|
)
|
||||||
|
|
||||||
self._is_master = hs.config.worker_app is None
|
self._is_master = hs.config.worker_app is None
|
||||||
|
|
||||||
self._federation_sender = None
|
self._federation_sender = None
|
||||||
@ -152,6 +187,64 @@ class ReplicationCommandHandler:
|
|||||||
if self._is_master:
|
if self._is_master:
|
||||||
self._server_notices_sender = hs.get_server_notices_sender()
|
self._server_notices_sender = hs.get_server_notices_sender()
|
||||||
|
|
||||||
|
async def _add_command_to_stream_queue(
|
||||||
|
self, conn: AbstractConnection, cmd: Union[RdataCommand, PositionCommand]
|
||||||
|
) -> None:
|
||||||
|
"""Queue the given received command for processing
|
||||||
|
|
||||||
|
Adds the given command to the per-stream queue, and processes the queue if
|
||||||
|
necessary
|
||||||
|
"""
|
||||||
|
stream_name = cmd.stream_name
|
||||||
|
queue = self._command_queues_by_stream.get(stream_name)
|
||||||
|
if queue is None:
|
||||||
|
logger.error("Got %s for unknown stream: %s", cmd.NAME, stream_name)
|
||||||
|
return
|
||||||
|
|
||||||
|
# if we're already processing this stream, stick the new command in the
|
||||||
|
# queue, and we're done.
|
||||||
|
if stream_name in self._processing_streams:
|
||||||
|
queue.append((cmd, conn))
|
||||||
|
return
|
||||||
|
|
||||||
|
# otherwise, process the new command.
|
||||||
|
|
||||||
|
# arguably we should start off a new background process here, but nothing
|
||||||
|
# will be too upset if we don't return for ages, so let's save the overhead
|
||||||
|
# and use the existing logcontext.
|
||||||
|
|
||||||
|
self._processing_streams.add(stream_name)
|
||||||
|
try:
|
||||||
|
# might as well skip the queue for this one, since it must be empty
|
||||||
|
assert not queue
|
||||||
|
await self._process_command(cmd, conn, stream_name)
|
||||||
|
|
||||||
|
# now process any other commands that have built up while we were
|
||||||
|
# dealing with that one.
|
||||||
|
while queue:
|
||||||
|
cmd, conn = queue.popleft()
|
||||||
|
try:
|
||||||
|
await self._process_command(cmd, conn, stream_name)
|
||||||
|
except Exception:
|
||||||
|
logger.exception("Failed to handle command %s", cmd)
|
||||||
|
|
||||||
|
finally:
|
||||||
|
self._processing_streams.discard(stream_name)
|
||||||
|
|
||||||
|
async def _process_command(
|
||||||
|
self,
|
||||||
|
cmd: Union[PositionCommand, RdataCommand],
|
||||||
|
conn: AbstractConnection,
|
||||||
|
stream_name: str,
|
||||||
|
) -> None:
|
||||||
|
if isinstance(cmd, PositionCommand):
|
||||||
|
await self._process_position(stream_name, conn, cmd)
|
||||||
|
elif isinstance(cmd, RdataCommand):
|
||||||
|
await self._process_rdata(stream_name, conn, cmd)
|
||||||
|
else:
|
||||||
|
# This shouldn't be possible
|
||||||
|
raise Exception("Unrecognised command %s in stream queue", cmd.NAME)
|
||||||
|
|
||||||
def start_replication(self, hs):
|
def start_replication(self, hs):
|
||||||
"""Helper method to start a replication connection to the remote server
|
"""Helper method to start a replication connection to the remote server
|
||||||
using TCP.
|
using TCP.
|
||||||
@ -285,18 +378,28 @@ class ReplicationCommandHandler:
|
|||||||
stream_name = cmd.stream_name
|
stream_name = cmd.stream_name
|
||||||
inbound_rdata_count.labels(stream_name).inc()
|
inbound_rdata_count.labels(stream_name).inc()
|
||||||
|
|
||||||
try:
|
# We put the received command into a queue here for two reasons:
|
||||||
row = STREAMS_MAP[stream_name].parse_row(cmd.row)
|
|
||||||
except Exception:
|
|
||||||
logger.exception("Failed to parse RDATA: %r %r", stream_name, cmd.row)
|
|
||||||
raise
|
|
||||||
|
|
||||||
# We linearize here for two reasons:
|
|
||||||
# 1. so we don't try and concurrently handle multiple rows for the
|
# 1. so we don't try and concurrently handle multiple rows for the
|
||||||
# same stream, and
|
# same stream, and
|
||||||
# 2. so we don't race with getting a POSITION command and fetching
|
# 2. so we don't race with getting a POSITION command and fetching
|
||||||
# missing RDATA.
|
# missing RDATA.
|
||||||
with await self._position_linearizer.queue(cmd.stream_name):
|
|
||||||
|
await self._add_command_to_stream_queue(conn, cmd)
|
||||||
|
|
||||||
|
async def _process_rdata(
|
||||||
|
self, stream_name: str, conn: AbstractConnection, cmd: RdataCommand
|
||||||
|
) -> None:
|
||||||
|
"""Process an RDATA command
|
||||||
|
|
||||||
|
Called after the command has been popped off the queue of inbound commands
|
||||||
|
"""
|
||||||
|
try:
|
||||||
|
row = STREAMS_MAP[stream_name].parse_row(cmd.row)
|
||||||
|
except Exception as e:
|
||||||
|
raise Exception(
|
||||||
|
"Failed to parse RDATA: %r %r" % (stream_name, cmd.row)
|
||||||
|
) from e
|
||||||
|
|
||||||
# make sure that we've processed a POSITION for this stream *on this
|
# make sure that we've processed a POSITION for this stream *on this
|
||||||
# connection*. (A POSITION on another connection is no good, as there
|
# connection*. (A POSITION on another connection is no good, as there
|
||||||
# is no guarantee that we have seen all the intermediate updates.)
|
# is no guarantee that we have seen all the intermediate updates.)
|
||||||
@ -316,15 +419,13 @@ class ReplicationCommandHandler:
|
|||||||
# which case batch until we get an update for the stream with a non
|
# which case batch until we get an update for the stream with a non
|
||||||
# None token).
|
# None token).
|
||||||
self._pending_batches.setdefault(stream_name, []).append(row)
|
self._pending_batches.setdefault(stream_name, []).append(row)
|
||||||
else:
|
return
|
||||||
|
|
||||||
# Check if this is the last of a batch of updates
|
# Check if this is the last of a batch of updates
|
||||||
rows = self._pending_batches.pop(stream_name, [])
|
rows = self._pending_batches.pop(stream_name, [])
|
||||||
rows.append(row)
|
rows.append(row)
|
||||||
|
|
||||||
stream = self._streams.get(stream_name)
|
stream = self._streams[stream_name]
|
||||||
if not stream:
|
|
||||||
logger.error("Got RDATA for unknown stream: %s", stream_name)
|
|
||||||
return
|
|
||||||
|
|
||||||
# Find where we previously streamed up to.
|
# Find where we previously streamed up to.
|
||||||
current_token = stream.current_token(cmd.instance_name)
|
current_token = stream.current_token(cmd.instance_name)
|
||||||
@ -367,15 +468,17 @@ class ReplicationCommandHandler:
|
|||||||
|
|
||||||
logger.info("Handling '%s %s'", cmd.NAME, cmd.to_line())
|
logger.info("Handling '%s %s'", cmd.NAME, cmd.to_line())
|
||||||
|
|
||||||
stream_name = cmd.stream_name
|
await self._add_command_to_stream_queue(conn, cmd)
|
||||||
stream = self._streams.get(stream_name)
|
|
||||||
if not stream:
|
async def _process_position(
|
||||||
logger.error("Got POSITION for unknown stream: %s", stream_name)
|
self, stream_name: str, conn: AbstractConnection, cmd: PositionCommand
|
||||||
return
|
) -> None:
|
||||||
|
"""Process a POSITION command
|
||||||
|
|
||||||
|
Called after the command has been popped off the queue of inbound commands
|
||||||
|
"""
|
||||||
|
stream = self._streams[stream_name]
|
||||||
|
|
||||||
# We protect catching up with a linearizer in case the replication
|
|
||||||
# connection reconnects under us.
|
|
||||||
with await self._position_linearizer.queue(stream_name):
|
|
||||||
# We're about to go and catch up with the stream, so remove from set
|
# We're about to go and catch up with the stream, so remove from set
|
||||||
# of connected streams.
|
# of connected streams.
|
||||||
for streams in self._streams_by_connection.values():
|
for streams in self._streams_by_connection.values():
|
||||||
@ -399,11 +502,7 @@ class ReplicationCommandHandler:
|
|||||||
current_token,
|
current_token,
|
||||||
cmd.token,
|
cmd.token,
|
||||||
)
|
)
|
||||||
(
|
(updates, current_token, missing_updates) = await stream.get_updates_since(
|
||||||
updates,
|
|
||||||
current_token,
|
|
||||||
missing_updates,
|
|
||||||
) = await stream.get_updates_since(
|
|
||||||
cmd.instance_name, current_token, cmd.token
|
cmd.instance_name, current_token, cmd.token
|
||||||
)
|
)
|
||||||
|
|
||||||
|
Loading…
Reference in New Issue
Block a user