本文整理汇总了Python中twisted.test.proto_helpers.MemoryReactorClock方法的典型用法代码示例。如果您正苦于以下问题:Python proto_helpers.MemoryReactorClock方法的具体用法?Python proto_helpers.MemoryReactorClock怎么用?Python proto_helpers.MemoryReactorClock使用的例子?那么恭喜您, 这里精选的方法代码示例或许可以为您提供帮助。您也可以进一步了解该方法所在类twisted.test.proto_helpers
的用法示例。
在下文中一共展示了proto_helpers.MemoryReactorClock方法的15个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于系统推荐出更棒的Python代码示例。
示例1: test_consumer_commit_during_commit
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_consumer_commit_during_commit(self):
clock = MemoryReactorClock()
mockclient = Mock(reactor=clock)
return_value = Deferred()
mockclient.send_offset_commit_request.return_value = return_value
the_group = 'The Cure'
the_topic = 'test_consumer_commit_during_commit_topic'
the_part = 1
the_offset = 28616
the_request = OffsetCommitRequest(
the_topic, the_part, the_offset, TIMESTAMP_INVALID, None)
# Create a consumer and muck with the state a bit...
consumer = Consumer(mockclient, the_topic, the_part, Mock(), the_group)
consumer._last_processed_offset = the_offset # Fake processed msgs
consumer._commit_looper = Mock() # Mock a looping call to test reset
d1 = consumer.commit()
mockclient.send_offset_commit_request.assert_called_once_with(
the_group, [the_request], consumer_id='', group_generation_id=-1)
consumer._commit_looper.reset.assert_called_once_with()
self.assertFalse(d1.called)
d2 = consumer.commit()
self.failureResultOf(d2, OperationInProgress)
示例2: test_consumer_stop_during_fetch_retry
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_consumer_stop_during_fetch_retry(self):
fetch_ds = [Deferred()]
clock = MemoryReactorClock()
mockclient = Mock(reactor=clock)
mockclient.send_fetch_request.side_effect = fetch_ds
consumer = Consumer(mockclient, 'committedTopic', 11, "FakeProc",
consumer_group="myGroup")
d = consumer.start(0)
with patch.object(kconsumer, 'log') as klog:
f = Failure(UnknownError())
fetch_ds[0].errback(f)
klog.debug.assert_called_once_with(
"%r: Failure fetching messages from kafka: %r",
consumer, f)
self.assertIsNone(consumer.stop())
self.assertIsNone(self.successResultOf(d))
示例3: test_consumer_error_during_offset
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_consumer_error_during_offset(self):
topic = 'error_during_offset'
part = 991
reqs_ds = [Deferred(), Deferred()]
clock = MemoryReactorClock()
mockclient = Mock(reactor=clock)
mockclient.send_offset_request.side_effect = reqs_ds
consumer = Consumer(mockclient, topic, part, Mock())
d = consumer.start(OFFSET_LATEST)
# Make sure request for offset was made
request = OffsetRequest(topic, part, OFFSET_LATEST, 1)
mockclient.send_offset_request.assert_called_once_with([request])
# Errback the first request
f = Failure(KafkaUnavailableError()) # Perhaps kafka wasn't up yet...
with patch.object(kconsumer, 'log'):
reqs_ds[0].errback(f)
# Advance the clock to trigger the 2nd request
clock.advance(consumer.retry_delay + 1) # fire the callLater
self.assertEqual(2, mockclient.send_offset_request.call_count)
# Stop the consumer to cleanup any outstanding operations
self.assertIsNone(consumer.stop())
self.assertIsNone(self.successResultOf(d))
示例4: test_consumer_shutdown_nothing_processing
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_consumer_shutdown_nothing_processing(self):
"""
Test the consumer shutdown happy path when no messages are currently
being processed by the processor function (while waiting on fetch req).
"""
clock = MemoryReactorClock()
mockclient = Mock(reactor=clock)
mockproc = Mock()
consumer = Consumer(mockclient, 'snpTopic', 1, mockproc, 'snpGroup')
start_d = consumer.start(1)
# Ensure a fetch request was made
request = FetchRequest('snpTopic', 1, 1, consumer.buffer_size)
mockclient.send_fetch_request.assert_called_once_with(
[request], max_wait_time=consumer.fetch_max_wait_time,
min_bytes=consumer.fetch_min_bytes)
# Shutdown the consumer
shutdown_d = consumer.shutdown()
# Ensure the stop was signaled
self.assertIsNone(self.successResultOf(start_d))
# Ensure the shutdown was signaled
self.assertIsNone(self.successResultOf(shutdown_d))
# Ensure the processor was never called
self.assertFalse(mockproc.called)
示例5: test_producer_send_messages_no_retry_fail
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_producer_send_messages_no_retry_fail(self):
client = Mock(reactor=MemoryReactorClock())
f = Failure(BrokerNotAvailableError())
client.send_produce_request.side_effect = [fail(f)]
client.topic_partitions = {self.topic: [0, 1, 2, 3]}
client.metadata_error_for_topic.return_value = False
msgs = [self.msg("one"), self.msg("two")]
producer = Producer(client, max_req_attempts=1)
d = producer.send_messages(self.topic, msgs=msgs)
# Check the expected request was sent
msgSet = create_message_set(
make_send_requests(msgs), producer.codec)
req = ProduceRequest(self.topic, 0, msgSet)
client.send_produce_request.assert_called_once_with(
[req], acks=producer.req_acks, timeout=producer.ack_timeout,
fail_on_error=False)
self.failureResultOf(d, BrokerNotAvailableError)
producer.stop()
示例6: test_producer_complete_batch_send_unexpected_error
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_producer_complete_batch_send_unexpected_error(self):
# Purely for coverage
client = Mock(reactor=MemoryReactorClock())
client.topic_partitions = {self.topic: [0, 1, 2, 3]}
client.metadata_error_for_topic.return_value = False
e = ValueError('test_producer_complete_batch_send_unexpected_error')
client.send_produce_request.side_effect = e
msgs = [self.msg("one"), self.msg("two")]
producer = Producer(client)
# FIXME: Don't use patch to test logging
with patch.object(aProducer, 'log') as klog:
producer.send_messages(self.topic, msgs=msgs)
# The error 'e' gets wrapped in a failure with a traceback, so
# we can't easily match the call exactly...
klog.error.assert_called_once_with(
'Failure detected in _complete_batch_send: %r', ANY, exc_info=ANY)
producer.stop()
示例7: test_producer_cancel_request_in_batch
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_producer_cancel_request_in_batch(self):
# Test cancelling a request before it's begun to be processed
client = Mock(reactor=MemoryReactorClock())
client.topic_partitions = {self.topic: [0, 1, 2, 3]}
client.metadata_error_for_topic.return_value = False
msgs = [self.msg("one"), self.msg("two")]
msgs2 = [self.msg("three"), self.msg("four")]
batch_n = 3
producer = Producer(client, batch_every_n=batch_n, batch_send=True)
d1 = producer.send_messages(self.topic, msgs=msgs)
# Check that no request was sent
self.assertFalse(client.send_produce_request.called)
d1.cancel()
self.failureResultOf(d1, CancelledError)
d2 = producer.send_messages(self.topic, msgs=msgs2)
# Check that still no request was sent
self.assertFalse(client.send_produce_request.called)
self.assertNoResult(d2)
producer.stop()
示例8: test_producer_stop_during_request
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_producer_stop_during_request(self):
"""
Test stopping producer while it's waiting for reply from client
"""
clock = MemoryReactorClock()
client = Mock(reactor=clock)
f = Failure(BrokerNotAvailableError())
ret = [fail(f), Deferred()]
client.send_produce_request.side_effect = ret
client.topic_partitions = {self.topic: [0, 1, 2, 3]}
client.metadata_error_for_topic.return_value = False
msgs = [self.msg("one"), self.msg("two")]
batch_n = 2
producer = Producer(client, batch_every_n=batch_n, batch_send=True)
d = producer.send_messages(self.topic, msgs=msgs)
# At first, there's no result. Have to retry due to first failure
self.assertNoResult(d)
clock.advance(producer._retry_interval)
producer.stop()
self.failureResultOf(d, tid_CancelledError)
示例9: test_producer_stop_waiting_to_retry
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_producer_stop_waiting_to_retry(self):
"""
Test stopping producer while it's waiting to retry a request
"""
clock = MemoryReactorClock()
client = Mock(reactor=clock)
f = Failure(BrokerNotAvailableError())
ret = [fail(f)]
client.send_produce_request.side_effect = ret
client.topic_partitions = {self.topic: [0, 1, 2, 3]}
client.metadata_error_for_topic.return_value = False
msgs = [self.msg("one"), self.msg("two")]
batch_n = 2
producer = Producer(client, batch_every_n=batch_n, batch_send=True)
d = producer.send_messages(self.topic, msgs=msgs)
# At first, there's no result. Have to retry due to first failure
self.assertNoResult(d)
# Advance the clock, some, but not enough to retry
clock.advance(producer._retry_interval / 2)
# Stop the producer before the retry
producer.stop()
self.failureResultOf(d, tid_CancelledError)
示例10: test_producer_send_messages_unknown_topic
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_producer_send_messages_unknown_topic(self):
clock = MemoryReactorClock()
client = Mock(reactor=clock)
ds = [Deferred() for _ in range(Producer.DEFAULT_REQ_ATTEMPTS)]
client.load_metadata_for_topics.side_effect = ds
client.metadata_error_for_topic.return_value = 3
client.topic_partitions = {}
msgs = [self.msg("one"), self.msg("two")]
ack_timeout = 5
producer = Producer(client, ack_timeout=ack_timeout)
d = producer.send_messages(self.topic, msgs=msgs)
# d is waiting on result from ds[0] for load_metadata_for_topics
self.assertNoResult(d)
# fire it with client still reporting no metadata for topic
# The producer will retry the lookup DEFAULT_REQ_ATTEMPTS times...
for i in range(Producer.DEFAULT_REQ_ATTEMPTS):
ds[i].callback(None)
# And then wait producer._retry_interval for a call back...
clock.advance(producer._retry_interval + 0.01)
self.failureResultOf(d, UnknownTopicOrPartitionError)
self.assertFalse(client.send_produce_request.called)
producer.stop()
示例11: test_send_broker_unaware_request_bootstrap_fail
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_send_broker_unaware_request_bootstrap_fail(self):
"""
Broker unaware requests fail with `KafkaUnavailableError` when boostrap
fails.
This scenario makes two connection attempts in random order, one for
each configured bootstrap host. Both fail.
"""
client = KafkaClient(
hosts=['kafka01:9092', 'kafka02:9092'],
reactor=MemoryReactorClock(),
# Every connection attempt will immediately fail due to this
# endpoint, including attempts to bootstrap.
endpoint_factory=FailureEndpoint,
)
d = client.load_metadata_for_topics('sometopic')
self.failureResultOf(d).trap(KafkaUnavailableError)
示例12: createReactor
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def createReactor(self):
"""
Create a L{MemoryReactorClock} and give it some hostnames it can
resolve.
@return: a L{MemoryReactorClock}-like object with a slightly limited
interface (only C{advance} and C{tcpClients} in addition to its
formally-declared reactor interfaces), which can resolve a fixed
set of domains.
"""
mrc = MemoryReactorClock()
drr = deterministicResolvingReactor(mrc, hostMap={
u'example.com': [EXAMPLE_COM_IP],
u'ipv6.example.com': [EXAMPLE_COM_V6_IP],
u'example.net': [EXAMPLE_NET_IP],
u'example.org': [EXAMPLE_ORG_IP],
u'foo': [FOO_LOCAL_IP],
u'foo.com': [FOO_COM_IP],
})
# Lots of tests were written expecting MemoryReactorClock and the
# reactor seen by the SUT to be the same object.
drr.tcpClients = mrc.tcpClients
drr.advance = mrc.advance
return drr
示例13: test_deprecatedDuckPolicy
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_deprecatedDuckPolicy(self):
"""
Passing something that duck-types I{like} a L{web client context
factory <twisted.web.client.WebClientContextFactory>} - something that
does not provide L{IPolicyForHTTPS} - to L{Agent} emits a
L{DeprecationWarning} even if you don't actually C{import
WebClientContextFactory} to do it.
"""
def warnMe():
client.Agent(MemoryReactorClock(),
"does-not-provide-IPolicyForHTTPS")
warnMe()
warnings = self.flushWarnings([warnMe])
self.assertEqual(len(warnings), 1)
[warning] = warnings
self.assertEqual(warning['category'], DeprecationWarning)
self.assertEqual(
warning['message'],
"'does-not-provide-IPolicyForHTTPS' was passed as the HTTPS "
"policy for an Agent, but it does not provide IPolicyForHTTPS. "
"Since Twisted 14.0, you must pass a provider of IPolicyForHTTPS."
)
示例14: test_endpointConnectNonDefaultArgs
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_endpointConnectNonDefaultArgs(self):
"""
The endpoint should pass it's connectArgs parameter to the reactor's
listen methods.
"""
factory = object()
mreactor = MemoryReactor()
ep, expectedArgs, ignoredHost = self.createClientEndpoint(
mreactor, factory,
**self.connectArgs())
ep.connect(factory)
expectedClients = self.expectedClients(mreactor)
self.assertEqual(len(expectedClients), 1)
self.assertConnectArgs(expectedClients[0], expectedArgs)
示例15: test_endpointListenSuccess
# 需要导入模块: from twisted.test import proto_helpers [as 别名]
# 或者: from twisted.test.proto_helpers import MemoryReactorClock [as 别名]
def test_endpointListenSuccess(self):
"""
An endpoint can listen and returns a deferred that gets called back
with a port instance.
"""
mreactor = MemoryReactor()
factory = object()
ep, expectedArgs, expectedHost = self.createServerEndpoint(
mreactor, factory)
d = ep.listen(factory)
receivedHosts = []
def checkPortAndServer(port):
receivedHosts.append(port.getHost())
d.addCallback(checkPortAndServer)
self.assertEqual(receivedHosts, [expectedHost])
self.assertEqual(self.expectedServers(mreactor), [expectedArgs])