diff --git a/tests/appservice/test_appservice.py b/tests/appservice/test_appservice.py
index aa8cc50550..7586ea9053 100644
--- a/tests/appservice/test_appservice.py
+++ b/tests/appservice/test_appservice.py
@@ -19,10 +19,12 @@ from twisted.internet import defer
from mock import Mock
from tests import unittest
+import re
+
def _regex(regex, exclusive=True):
return {
- "regex": regex,
+ "regex": re.compile(regex),
"exclusive": exclusive
}
diff --git a/tests/handlers/test_e2e_keys.py b/tests/handlers/test_e2e_keys.py
index 878a54dc34..19f5ed6bce 100644
--- a/tests/handlers/test_e2e_keys.py
+++ b/tests/handlers/test_e2e_keys.py
@@ -14,6 +14,7 @@
# limitations under the License.
import mock
+from synapse.api import errors
from twisted.internet import defer
import synapse.api.errors
@@ -44,3 +45,134 @@ class E2eKeysHandlerTestCase(unittest.TestCase):
local_user = "@boris:" + self.hs.hostname
res = yield self.handler.query_local_devices({local_user: None})
self.assertDictEqual(res, {local_user: {}})
+
+ @defer.inlineCallbacks
+ def test_reupload_one_time_keys(self):
+ """we should be able to re-upload the same keys"""
+ local_user = "@boris:" + self.hs.hostname
+ device_id = "xyz"
+ keys = {
+ "alg1:k1": "key1",
+ "alg2:k2": {
+ "key": "key2",
+ "signatures": {"k1": "sig1"}
+ },
+ "alg2:k3": {
+ "key": "key3",
+ },
+ }
+
+ res = yield self.handler.upload_keys_for_user(
+ local_user, device_id, {"one_time_keys": keys},
+ )
+ self.assertDictEqual(res, {
+ "one_time_key_counts": {"alg1": 1, "alg2": 2}
+ })
+
+ # we should be able to change the signature without a problem
+ keys["alg2:k2"]["signatures"]["k1"] = "sig2"
+ res = yield self.handler.upload_keys_for_user(
+ local_user, device_id, {"one_time_keys": keys},
+ )
+ self.assertDictEqual(res, {
+ "one_time_key_counts": {"alg1": 1, "alg2": 2}
+ })
+
+ @defer.inlineCallbacks
+ def test_change_one_time_keys(self):
+ """attempts to change one-time-keys should be rejected"""
+
+ local_user = "@boris:" + self.hs.hostname
+ device_id = "xyz"
+ keys = {
+ "alg1:k1": "key1",
+ "alg2:k2": {
+ "key": "key2",
+ "signatures": {"k1": "sig1"}
+ },
+ "alg2:k3": {
+ "key": "key3",
+ },
+ }
+
+ res = yield self.handler.upload_keys_for_user(
+ local_user, device_id, {"one_time_keys": keys},
+ )
+ self.assertDictEqual(res, {
+ "one_time_key_counts": {"alg1": 1, "alg2": 2}
+ })
+
+ try:
+ yield self.handler.upload_keys_for_user(
+ local_user, device_id, {"one_time_keys": {"alg1:k1": "key2"}},
+ )
+ self.fail("No error when changing string key")
+ except errors.SynapseError:
+ pass
+
+ try:
+ yield self.handler.upload_keys_for_user(
+ local_user, device_id, {"one_time_keys": {"alg2:k3": "key2"}},
+ )
+ self.fail("No error when replacing dict key with string")
+ except errors.SynapseError:
+ pass
+
+ try:
+ yield self.handler.upload_keys_for_user(
+ local_user, device_id, {
+ "one_time_keys": {"alg1:k1": {"key": "key"}}
+ },
+ )
+ self.fail("No error when replacing string key with dict")
+ except errors.SynapseError:
+ pass
+
+ try:
+ yield self.handler.upload_keys_for_user(
+ local_user, device_id, {
+ "one_time_keys": {
+ "alg2:k2": {
+ "key": "key3",
+ "signatures": {"k1": "sig1"},
+ }
+ },
+ },
+ )
+ self.fail("No error when replacing dict key")
+ except errors.SynapseError:
+ pass
+
+ @unittest.DEBUG
+ @defer.inlineCallbacks
+ def test_claim_one_time_key(self):
+ local_user = "@boris:" + self.hs.hostname
+ device_id = "xyz"
+ keys = {
+ "alg1:k1": "key1",
+ }
+
+ res = yield self.handler.upload_keys_for_user(
+ local_user, device_id, {"one_time_keys": keys},
+ )
+ self.assertDictEqual(res, {
+ "one_time_key_counts": {"alg1": 1}
+ })
+
+ res2 = yield self.handler.claim_one_time_keys({
+ "one_time_keys": {
+ local_user: {
+ device_id: "alg1"
+ }
+ }
+ }, timeout=None)
+ self.assertEqual(res2, {
+ "failures": {},
+ "one_time_keys": {
+ local_user: {
+ device_id: {
+ "alg1:k1": "key1"
+ }
+ }
+ }
+ })
diff --git a/tests/replication/slave/storage/_base.py b/tests/replication/slave/storage/_base.py
index b82868054d..81063f19a1 100644
--- a/tests/replication/slave/storage/_base.py
+++ b/tests/replication/slave/storage/_base.py
@@ -12,12 +12,15 @@
# See the License for the specific language governing permissions and
# limitations under the License.
-from twisted.internet import defer
+from twisted.internet import defer, reactor
from tests import unittest
from mock import Mock, NonCallableMock
from tests.utils import setup_test_homeserver
-from synapse.replication.resource import ReplicationResource
+from synapse.replication.tcp.resource import ReplicationStreamProtocolFactory
+from synapse.replication.tcp.client import (
+ ReplicationClientHandler, ReplicationClientFactory,
+)
class BaseSlavedStoreTestCase(unittest.TestCase):
@@ -33,18 +36,29 @@ class BaseSlavedStoreTestCase(unittest.TestCase):
)
self.hs.get_ratelimiter().send_message.return_value = (True, 0)
- self.replication = ReplicationResource(self.hs)
-
self.master_store = self.hs.get_datastore()
self.slaved_store = self.STORE_TYPE(self.hs.get_db_conn(), self.hs)
self.event_id = 0
+ server_factory = ReplicationStreamProtocolFactory(self.hs)
+ listener = reactor.listenUNIX("\0xxx", server_factory)
+ self.addCleanup(listener.stopListening)
+ self.streamer = server_factory.streamer
+
+ self.replication_handler = ReplicationClientHandler(self.slaved_store)
+ client_factory = ReplicationClientFactory(
+ self.hs, "client_name", self.replication_handler
+ )
+ client_connector = reactor.connectUNIX("\0xxx", client_factory)
+ self.addCleanup(client_factory.stopTrying)
+ self.addCleanup(client_connector.disconnect)
+
@defer.inlineCallbacks
def replicate(self):
- streams = self.slaved_store.stream_positions()
- writer = yield self.replication.replicate(streams, 100)
- result = writer.finish()
- yield self.slaved_store.process_replication(result)
+ yield self.streamer.on_notifier_poke()
+ d = self.replication_handler.await_sync("replication_test")
+ self.streamer.send_sync_to_all_connections("replication_test")
+ yield d
@defer.inlineCallbacks
def check(self, method, args, expected_result=None):
diff --git a/tests/replication/test_resource.py b/tests/replication/test_resource.py
deleted file mode 100644
index 429b37e360..0000000000
--- a/tests/replication/test_resource.py
+++ /dev/null
@@ -1,204 +0,0 @@
-# -*- coding: utf-8 -*-
-# Copyright 2016 OpenMarket Ltd
-#
-# Licensed under the Apache License, Version 2.0 (the "License");
-# you may not use this file except in compliance with the License.
-# You may obtain a copy of the License at
-#
-# http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-import contextlib
-import json
-
-from mock import Mock, NonCallableMock
-from twisted.internet import defer
-
-import synapse.types
-from synapse.replication.resource import ReplicationResource
-from synapse.types import UserID
-from tests import unittest
-from tests.utils import setup_test_homeserver
-
-
-class ReplicationResourceCase(unittest.TestCase):
- @defer.inlineCallbacks
- def setUp(self):
- self.hs = yield setup_test_homeserver(
- "red",
- http_client=None,
- replication_layer=Mock(),
- ratelimiter=NonCallableMock(spec_set=[
- "send_message",
- ]),
- )
- self.user_id = "@seeing:red"
- self.user = UserID.from_string(self.user_id)
-
- self.hs.get_ratelimiter().send_message.return_value = (True, 0)
-
- self.resource = ReplicationResource(self.hs)
-
- @defer.inlineCallbacks
- def test_streams(self):
- # Passing "-1" returns the current stream positions
- code, body = yield self.get(streams="-1")
- self.assertEquals(code, 200)
- self.assertEquals(body["streams"]["field_names"], ["name", "position"])
- position = body["streams"]["position"]
- # Passing the current position returns an empty response after the
- # timeout
- get = self.get(streams=str(position), timeout="0")
- self.hs.clock.advance_time_msec(1)
- code, body = yield get
- self.assertEquals(code, 200)
- self.assertEquals(body, {})
-
- @defer.inlineCallbacks
- def test_events(self):
- get = self.get(events="-1", timeout="0")
- yield self.hs.get_handlers().room_creation_handler.create_room(
- synapse.types.create_requester(self.user), {}
- )
- code, body = yield get
- self.assertEquals(code, 200)
- self.assertEquals(body["events"]["field_names"], [
- "position", "event_id", "room_id", "type", "state_key",
- ])
-
- @defer.inlineCallbacks
- def test_presence(self):
- get = self.get(presence="-1")
- yield self.hs.get_presence_handler().set_state(
- self.user, {"presence": "online"}
- )
- code, body = yield get
- self.assertEquals(code, 200)
- self.assertEquals(body["presence"]["field_names"], [
- "position", "user_id", "state", "last_active_ts",
- "last_federation_update_ts", "last_user_sync_ts",
- "status_msg", "currently_active",
- ])
-
- @defer.inlineCallbacks
- def test_typing(self):
- room_id = yield self.create_room()
- get = self.get(typing="-1")
- yield self.hs.get_typing_handler().started_typing(
- self.user, self.user, room_id, timeout=2
- )
- code, body = yield get
- self.assertEquals(code, 200)
- self.assertEquals(body["typing"]["field_names"], [
- "position", "room_id", "typing"
- ])
-
- @defer.inlineCallbacks
- def test_receipts(self):
- room_id = yield self.create_room()
- event_id = yield self.send_text_message(room_id, "Hello, World")
- get = self.get(receipts="-1")
- yield self.hs.get_receipts_handler().received_client_receipt(
- room_id, "m.read", self.user_id, event_id
- )
- code, body = yield get
- self.assertEquals(code, 200)
- self.assertEquals(body["receipts"]["field_names"], [
- "position", "room_id", "receipt_type", "user_id", "event_id", "data"
- ])
-
- def _test_timeout(stream):
- """Check that a request for the given stream timesout"""
- @defer.inlineCallbacks
- def test_timeout(self):
- get = self.get(**{stream: "-1", "timeout": "0"})
- self.hs.clock.advance_time_msec(1)
- code, body = yield get
- self.assertEquals(code, 200)
- self.assertEquals(body.get("rows", []), [])
- test_timeout.__name__ = "test_timeout_%s" % (stream)
- return test_timeout
-
- test_timeout_events = _test_timeout("events")
- test_timeout_presence = _test_timeout("presence")
- test_timeout_typing = _test_timeout("typing")
- test_timeout_receipts = _test_timeout("receipts")
- test_timeout_user_account_data = _test_timeout("user_account_data")
- test_timeout_room_account_data = _test_timeout("room_account_data")
- test_timeout_tag_account_data = _test_timeout("tag_account_data")
- test_timeout_backfill = _test_timeout("backfill")
- test_timeout_push_rules = _test_timeout("push_rules")
- test_timeout_pushers = _test_timeout("pushers")
- test_timeout_state = _test_timeout("state")
-
- @defer.inlineCallbacks
- def send_text_message(self, room_id, message):
- handler = self.hs.get_handlers().message_handler
- event = yield handler.create_and_send_nonmember_event(
- synapse.types.create_requester(self.user),
- {
- "type": "m.room.message",
- "content": {"body": "message", "msgtype": "m.text"},
- "room_id": room_id,
- "sender": self.user.to_string(),
- }
- )
- defer.returnValue(event.event_id)
-
- @defer.inlineCallbacks
- def create_room(self):
- result = yield self.hs.get_handlers().room_creation_handler.create_room(
- synapse.types.create_requester(self.user), {}
- )
- defer.returnValue(result["room_id"])
-
- @defer.inlineCallbacks
- def get(self, **params):
- request = NonCallableMock(spec_set=[
- "write", "finish", "setResponseCode", "setHeader", "args",
- "method", "processing"
- ])
-
- request.method = "GET"
- request.args = {k: [v] for k, v in params.items()}
-
- @contextlib.contextmanager
- def processing():
- yield
- request.processing = processing
-
- yield self.resource._async_render_GET(request)
- self.assertTrue(request.finish.called)
-
- if request.setResponseCode.called:
- response_code = request.setResponseCode.call_args[0][0]
- else:
- response_code = 200
-
- response_json = "".join(
- call[0][0] for call in request.write.call_args_list
- )
- response_body = json.loads(response_json)
-
- if response_code == 200:
- self.check_response(response_body)
-
- defer.returnValue((response_code, response_body))
-
- def check_response(self, response_body):
- for name, stream in response_body.items():
- self.assertIn("field_names", stream)
- field_names = stream["field_names"]
- self.assertIn("rows", stream)
- for row in stream["rows"]:
- self.assertEquals(
- len(row), len(field_names),
- "%s: len(row = %r) == len(field_names = %r)" % (
- name, row, field_names
- )
- )
diff --git a/tests/storage/event_injector.py b/tests/storage/event_injector.py
index 38556da9a7..024ac15069 100644
--- a/tests/storage/event_injector.py
+++ b/tests/storage/event_injector.py
@@ -27,10 +27,10 @@ class EventInjector:
self.event_builder_factory = hs.get_event_builder_factory()
@defer.inlineCallbacks
- def create_room(self, room):
+ def create_room(self, room, user):
builder = self.event_builder_factory.new({
"type": EventTypes.Create,
- "sender": "",
+ "sender": user.to_string(),
"room_id": room.to_string(),
"content": {},
})
diff --git a/tests/storage/test__base.py b/tests/storage/test__base.py
index 8361dd8cee..281eb16254 100644
--- a/tests/storage/test__base.py
+++ b/tests/storage/test__base.py
@@ -199,7 +199,7 @@ class CacheDecoratorTestCase(unittest.TestCase):
a.func.prefill(("foo",), ObservableDeferred(d))
- self.assertEquals(a.func("foo").result, d.result)
+ self.assertEquals(a.func("foo"), d.result)
self.assertEquals(callcount[0], 0)
@defer.inlineCallbacks
diff --git a/tests/storage/test_events.py b/tests/storage/test_events.py
index 3762b38e37..14443b53bc 100644
--- a/tests/storage/test_events.py
+++ b/tests/storage/test_events.py
@@ -50,7 +50,7 @@ class EventsStoreTestCase(unittest.TestCase):
# Create something to report
room = RoomID.from_string("!abc123:test")
user = UserID.from_string("@raccoonlover:test")
- yield self.event_injector.create_room(room)
+ yield self.event_injector.create_room(room, user)
self.base_event = yield self._get_last_stream_token()
diff --git a/tests/util/caches/test_descriptors.py b/tests/util/caches/test_descriptors.py
index 4414e86771..3f14ab503f 100644
--- a/tests/util/caches/test_descriptors.py
+++ b/tests/util/caches/test_descriptors.py
@@ -175,3 +175,41 @@ class DescriptorTestCase(unittest.TestCase):
logcontext.LoggingContext.sentinel)
return d1
+
+ @defer.inlineCallbacks
+ def test_cache_default_args(self):
+ class Cls(object):
+ def __init__(self):
+ self.mock = mock.Mock()
+
+ @descriptors.cached()
+ def fn(self, arg1, arg2=2, arg3=3):
+ return self.mock(arg1, arg2, arg3)
+
+ obj = Cls()
+
+ obj.mock.return_value = 'fish'
+ r = yield obj.fn(1, 2, 3)
+ self.assertEqual(r, 'fish')
+ obj.mock.assert_called_once_with(1, 2, 3)
+ obj.mock.reset_mock()
+
+ # a call with same params shouldn't call the mock again
+ r = yield obj.fn(1, 2)
+ self.assertEqual(r, 'fish')
+ obj.mock.assert_not_called()
+ obj.mock.reset_mock()
+
+ # a call with different params should call the mock again
+ obj.mock.return_value = 'chips'
+ r = yield obj.fn(2, 3)
+ self.assertEqual(r, 'chips')
+ obj.mock.assert_called_once_with(2, 3, 3)
+ obj.mock.reset_mock()
+
+ # the two values should now be cached
+ r = yield obj.fn(1, 2)
+ self.assertEqual(r, 'fish')
+ r = yield obj.fn(2, 3)
+ self.assertEqual(r, 'chips')
+ obj.mock.assert_not_called()
diff --git a/tests/util/test_snapshot_cache.py b/tests/util/test_snapshot_cache.py
index 7e289715ba..d3a8630c2f 100644
--- a/tests/util/test_snapshot_cache.py
+++ b/tests/util/test_snapshot_cache.py
@@ -53,7 +53,9 @@ class SnapshotCacheTestCase(unittest.TestCase):
# before the cache expires returns a resolved deferred.
get_result_at_11 = self.cache.get(11, "key")
self.assertIsNotNone(get_result_at_11)
- self.assertTrue(get_result_at_11.called)
+ if isinstance(get_result_at_11, Deferred):
+ # The cache may return the actual result rather than a deferred
+ self.assertTrue(get_result_at_11.called)
# Check that getting the key after the deferred has resolved
# after the cache expires returns None
|