def setUp(self): """ Set up mock Bobby client """ set_bobby(BobbyClient("http://127.0.0.1:9876/")) super(AllBobbyPoliciesTestCase, self).setUp()
def setUp(self): """ Set up mock Bobby client """ set_bobby(BobbyClient("http://127.0.0.1:9876/")) super(AllGroupsBobbyEndpointTestCase, self).setUp() self.mock_controller = patch(self, 'otter.rest.groups.controller') patch(self, 'otter.util.http.get_url_root', return_value="") # Patch supervisor supervisor = mock.Mock(spec=['validate_launch_config']) supervisor.validate_launch_config.return_value = defer.succeed(None) set_supervisor(supervisor)
def setUp(self): """ Set up test dependencies. """ self.log = mock_log() set_config_data(fake_config) self.addCleanup(set_config_data, {}) self.treq = patch(self, 'otter.worker.launch_server_v1.treq') patch(self, 'otter.util.http.treq', new=self.treq) self.generate_server_name = patch( self, 'otter.worker.launch_server_v1.generate_server_name') self.generate_server_name.return_value = 'as000000' self.scaling_group_uuid = '1111111-11111-11111-11111111' self.scaling_group = mock.Mock(uuid=self.scaling_group_uuid, tenant_id='1234') self.undo = iMock(IUndoStack) set_bobby(BobbyClient("http://127.0.0.1:9876/"))
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
def makeService(config): """ Set up the otter-api service. """ set_config_data(dict(config)) if not config_value('mock'): seed_endpoints = [ clientFromString(reactor, str(host)) for host in config_value('cassandra.seed_hosts')] cassandra_cluster = LoggingCQLClient(RoundRobinCassandraCluster( seed_endpoints, config_value('cassandra.keyspace')), log.bind(system='otter.silverberg')) store = CassScalingGroupCollection(cassandra_cluster) admin_store = CassAdmin(cassandra_cluster) else: store = MockScalingGroupCollection() admin_store = MockAdmin() 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, ImpersonatingAuthenticator( config_value('identity.username'), config_value('identity.password'), config_value('identity.url'), config_value('identity.admin_url')), cache_ttl) s = MultiService() supervisor = SupervisorService(authenticator.authenticate_tenant, coiterate) supervisor.setServiceParent(s) set_supervisor(supervisor) otter = Otter(store) site = Site(otter.app.resource()) site.displayTracebacks = False api_service = service(str(config_value('port')), site) api_service.setServiceParent(s) # Setup admin service admin = OtterAdmin(admin_store) admin_site = Site(admin.app.resource()) admin_site.displayTracebacks = False admin_service = service(str(config_value('admin')), admin_site) admin_service.setServiceParent(s) # Setup scheduler service if config_value('scheduler') and not config_value('mock'): scheduler_service = SchedulerService(int(config_value('scheduler.batchsize')), int(config_value('scheduler.interval')), cassandra_cluster, store) scheduler_service.setServiceParent(s) return s
def tearDown(self): """ Revert mock Bobby client """ set_bobby(None) set_supervisor(None)
def tearDown(self): """ Revert mock Bobby client """ set_bobby(None)
def tearDown(self): """ Reset bobby dependencies. """ set_bobby(None)