def test_via_cli(reactor, hosts): log.startLogging(sys.stdout) client = TxKazooClient(hosts=hosts, txlog=log) yield client.start() yield partitioning(reactor, client) # yield locking(reactor, client) yield client.stop()
def test_via_cli(reactor, hosts): log.startLogging(sys.stdout) client = TxKazooClient(hosts=hosts, txlog=log) yield client.start() yield partitioning(reactor, client) #yield locking(reactor, client) yield client.stop()
class TxKazooClientTests(TxKazooTestCase): """ Tests for `TxKazooClient` """ @mock.patch('txkazoo.reactor') def test_init(self, mock_reactor): """ __init__ sets up thread size and creates KazooClient """ self.txkzclient = TxKazooClient(hosts='abc', arg2='12', threads=20) mock_reactor.suggestThreadPoolSize.assert_called_once_with(20) self.kazoo_client.assert_called_with(hosts='abc', arg2='12') self.assertEqual(self.txkzclient.client, self.kz_obj) def test_method(self): """ Any method is called in seperate thread """ d = self.txkzclient.start() self.defer_to_thread.assert_called_once_with(self.txkzclient.client.start) self.assertEqual(d, self.defer_to_thread.return_value) def test_property_get(self): """ Accessing property does not defer to thread. It is returned immediately """ s = self.txkzclient.state self.assertFalse(self.defer_to_thread.called) self.assertEqual(s, self.kazoo_client.return_value.state)
def test_init(self, mock_reactor): """ __init__ sets up thread size and creates KazooClient """ self.txkzclient = TxKazooClient(hosts='abc', arg2='12', threads=20) mock_reactor.suggestThreadPoolSize.assert_called_once_with(20) self.kazoo_client.assert_called_with(hosts='abc', arg2='12') self.assertEqual(self.txkzclient.client, self.kz_obj)
def makeService(config): """ Set up the otter-api service. """ config = dict(config) set_config_data(config) parent = MultiService() region = config_value('region') seed_endpoints = [ clientFromString(reactor, str(host)) for host in config_value('cassandra.seed_hosts')] cassandra_cluster = LoggingCQLClient( TimingOutCQLClient( reactor, RoundRobinCassandraCluster( seed_endpoints, config_value('cassandra.keyspace'), disconnect_on_cancel=True), config_value('cassandra.timeout') or 30), log.bind(system='otter.silverberg')) store = CassScalingGroupCollection( cassandra_cluster, reactor, config_value('limits.absolute.maxGroups')) admin_store = CassAdmin(cassandra_cluster) bobby_url = config_value('bobby_url') if bobby_url is not None: set_bobby(BobbyClient(bobby_url)) service_configs = get_service_configs(config) authenticator = generate_authenticator(reactor, config['identity']) supervisor = SupervisorService(authenticator, region, coiterate, service_configs) supervisor.setServiceParent(parent) set_supervisor(supervisor) health_checker = HealthChecker(reactor, { 'store': getattr(store, 'health_check', None), 'kazoo': store.kazoo_health_check, 'supervisor': supervisor.health_check }) # Setup cassandra cluster to disconnect when otter shuts down if 'cassandra_cluster' in locals(): parent.addService(FunctionalService(stop=partial( call_after_supervisor, cassandra_cluster.disconnect, supervisor))) otter = Otter(store, region, health_checker.health_check) site = Site(otter.app.resource()) site.displayTracebacks = False api_service = service(str(config_value('port')), site) api_service.setServiceParent(parent) # Setup admin service admin_port = config_value('admin') if admin_port: admin = OtterAdmin(admin_store) admin_site = Site(admin.app.resource()) admin_site.displayTracebacks = False admin_service = service(str(admin_port), admin_site) admin_service.setServiceParent(parent) # setup cloud feed cf_conf = config.get('cloudfeeds', None) if cf_conf is not None: id_conf = deepcopy(config['identity']) id_conf['strategy'] = 'single_tenant' add_to_fanout(CloudFeedsObserver( reactor=reactor, authenticator=generate_authenticator(reactor, id_conf), tenant_id=cf_conf['tenant_id'], region=region, service_configs=service_configs)) # Setup Kazoo client if config_value('zookeeper'): threads = config_value('zookeeper.threads') or 10 disable_logs = config_value('zookeeper.no_logs') threadpool = ThreadPool(maxthreads=threads) sync_kz_client = KazooClient( hosts=config_value('zookeeper.hosts'), # Keep trying to connect until the end of time with # max interval of 10 minutes connection_retry=dict(max_tries=-1, max_delay=600), logger=None if disable_logs else TxLogger(log.bind(system='kazoo')) ) kz_client = TxKazooClient(reactor, threadpool, sync_kz_client) # Don't timeout. Keep trying to connect forever d = kz_client.start(timeout=None) def on_client_ready(_): dispatcher = get_full_dispatcher(reactor, authenticator, log, get_service_configs(config), kz_client, store, supervisor, cassandra_cluster) # Setup scheduler service after starting scheduler = setup_scheduler(parent, dispatcher, store, kz_client) health_checker.checks['scheduler'] = scheduler.health_check otter.scheduler = scheduler # Give dispatcher to Otter REST object otter.dispatcher = dispatcher # Set the client after starting # NOTE: There is small amount of time when the start is # not finished and the kz_client is not set in which case # policy execution and group delete will fail store.kz_client = kz_client # Setup kazoo to stop when shutting down parent.addService(FunctionalService( stop=partial(call_after_supervisor, kz_client.stop, supervisor))) setup_converger( parent, kz_client, dispatcher, config_value('converger.interval') or 10, config_value('converger.build_timeout') or 3600, config_value('converger.limited_retry_iterations') or 10, config_value('converger.step_limits') or {}) d.addCallback(on_client_ready) d.addErrback(log.err, 'Could not start TxKazooClient') return parent
def makeService(config): """ Set up the otter-api service. """ set_config_data(dict(config)) s = MultiService() region = config_value('region') seed_endpoints = [ clientFromString(reactor, str(host)) for host in config_value('cassandra.seed_hosts')] cassandra_cluster = LoggingCQLClient( TimingOutCQLClient( reactor, RoundRobinCassandraCluster( seed_endpoints, config_value('cassandra.keyspace')), config_value('cassandra.timeout') or 30), log.bind(system='otter.silverberg')) get_consistency = partial( get_consistency_level, default=config_value('cassandra.default_consistency'), exceptions=config_value('cassandra.consistency_exceptions')) store = CassScalingGroupCollection(cassandra_cluster, reactor, get_consistency) admin_store = CassAdmin(cassandra_cluster, get_consistency) bobby_url = config_value('bobby_url') if bobby_url is not None: set_bobby(BobbyClient(bobby_url)) cache_ttl = config_value('identity.cache_ttl') if cache_ttl is None: # FIXME: Pick an arbitrary cache ttl value based on absolutely no # science. cache_ttl = 300 authenticator = CachingAuthenticator( reactor, RetryingAuthenticator( reactor, ImpersonatingAuthenticator( config_value('identity.username'), config_value('identity.password'), config_value('identity.url'), config_value('identity.admin_url')), max_retries=config_value('identity.max_retries'), retry_interval=config_value('identity.retry_interval')), cache_ttl) supervisor = SupervisorService(authenticator.authenticate_tenant, region, coiterate) supervisor.setServiceParent(s) set_supervisor(supervisor) health_checker = HealthChecker(reactor, { 'store': getattr(store, 'health_check', None), 'kazoo': store.kazoo_health_check, 'supervisor': supervisor.health_check }) # Setup cassandra cluster to disconnect when otter shuts down if 'cassandra_cluster' in locals(): s.addService(FunctionalService(stop=partial(call_after_supervisor, cassandra_cluster.disconnect, supervisor))) otter = Otter(store, region, health_checker.health_check, es_host=config_value('elasticsearch.host')) site = Site(otter.app.resource()) site.displayTracebacks = False api_service = service(str(config_value('port')), site) api_service.setServiceParent(s) # Setup admin service admin_port = config_value('admin') if admin_port: admin = OtterAdmin(admin_store) admin_site = Site(admin.app.resource()) admin_site.displayTracebacks = False admin_service = service(str(admin_port), admin_site) admin_service.setServiceParent(s) # Setup Kazoo client if config_value('zookeeper'): threads = config_value('zookeeper.threads') or 10 kz_client = TxKazooClient(hosts=config_value('zookeeper.hosts'), threads=threads, txlog=log.bind(system='kazoo')) d = kz_client.start() def on_client_ready(_): # Setup scheduler service after starting scheduler = setup_scheduler(s, store, kz_client) health_checker.checks['scheduler'] = scheduler.health_check otter.scheduler = scheduler # Set the client after starting # NOTE: There is small amount of time when the start is not finished # and the kz_client is not set in which case policy execution and group # delete will fail store.kz_client = kz_client # Setup kazoo to stop when shutting down s.addService(FunctionalService(stop=partial(call_after_supervisor, kz_client.stop, supervisor))) d.addCallback(on_client_ready) d.addErrback(log.err, 'Could not start TxKazooClient') return s