2014-12-16 18:41:30 +00:00
|
|
|
import logging
|
|
|
|
import etcd
|
|
|
|
import uuid
|
2014-12-22 17:14:16 +00:00
|
|
|
import calendar
|
2014-12-22 21:22:07 +00:00
|
|
|
import os.path
|
2014-12-23 19:09:04 +00:00
|
|
|
import json
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
from datetime import datetime, timedelta
|
2014-12-22 21:22:07 +00:00
|
|
|
from trollius import From, coroutine, Return, async
|
|
|
|
from concurrent.futures import ThreadPoolExecutor
|
2015-01-23 16:29:38 +00:00
|
|
|
from urllib3.exceptions import ReadTimeoutError, ProtocolError
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
from buildman.manager.basemanager import BaseManager
|
|
|
|
from buildman.manager.executor import PopenExecutor, EC2Executor
|
|
|
|
from buildman.component.buildcomponent import BuildComponent
|
2014-12-31 16:33:56 +00:00
|
|
|
from buildman.jobutil.buildjob import BuildJob
|
2014-12-22 17:14:16 +00:00
|
|
|
from buildman.asyncutil import AsyncWrapper
|
2014-12-31 16:33:56 +00:00
|
|
|
from util.morecollections import AttrDict
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
|
|
|
|
logger = logging.getLogger(__name__)
|
|
|
|
|
|
|
|
|
2014-12-23 19:54:34 +00:00
|
|
|
ETCD_DISABLE_TIMEOUT = 0
|
2014-12-16 18:41:30 +00:00
|
|
|
|
2015-02-02 17:00:19 +00:00
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
class EtcdAction(object):
|
|
|
|
GET = 'get'
|
|
|
|
SET = 'set'
|
|
|
|
EXPIRE = 'expire'
|
|
|
|
UPDATE = 'update'
|
|
|
|
DELETE = 'delete'
|
|
|
|
CREATE = 'create'
|
|
|
|
COMPARE_AND_SWAP = 'compareAndSwap'
|
|
|
|
COMPARE_AND_DELETE = 'compareAndDelete'
|
|
|
|
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
class EphemeralBuilderManager(BaseManager):
|
|
|
|
""" Build manager implementation for the Enterprise Registry. """
|
2014-12-22 17:14:16 +00:00
|
|
|
_executors = {
|
|
|
|
'popen': PopenExecutor,
|
|
|
|
'ec2': EC2Executor,
|
|
|
|
}
|
|
|
|
|
|
|
|
_etcd_client_klass = etcd.Client
|
|
|
|
|
2014-12-16 18:41:30 +00:00
|
|
|
def __init__(self, *args, **kwargs):
|
2014-12-22 21:22:07 +00:00
|
|
|
self._shutting_down = False
|
|
|
|
|
2014-12-16 18:41:30 +00:00
|
|
|
self._manager_config = None
|
2014-12-22 21:22:07 +00:00
|
|
|
self._async_thread_executor = None
|
2014-12-16 18:41:30 +00:00
|
|
|
self._etcd_client = None
|
|
|
|
|
2015-02-02 17:00:19 +00:00
|
|
|
self._etcd_realm_prefix = None
|
|
|
|
self._etcd_builder_prefix = None
|
|
|
|
|
2014-12-16 18:41:30 +00:00
|
|
|
self._component_to_job = {}
|
2014-12-31 16:33:56 +00:00
|
|
|
self._job_uuid_to_component = {}
|
2014-12-16 18:41:30 +00:00
|
|
|
self._component_to_builder = {}
|
|
|
|
|
|
|
|
self._executor = None
|
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
# Map of etcd keys being watched to the tasks watching them
|
|
|
|
self._watch_tasks = {}
|
2014-12-22 21:22:07 +00:00
|
|
|
|
2014-12-16 18:41:30 +00:00
|
|
|
super(EphemeralBuilderManager, self).__init__(*args, **kwargs)
|
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
def _watch_etcd(self, etcd_key, change_callback, recursive=True):
|
|
|
|
watch_task_key = (etcd_key, recursive)
|
|
|
|
def callback_wrapper(changed_key_future):
|
|
|
|
if watch_task_key not in self._watch_tasks or self._watch_tasks[watch_task_key].done():
|
|
|
|
self._watch_etcd(etcd_key, change_callback)
|
2014-12-22 21:22:07 +00:00
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
if changed_key_future.cancelled():
|
|
|
|
# Due to lack of interest, tomorrow has been cancelled
|
|
|
|
return
|
2014-12-23 17:13:49 +00:00
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
try:
|
|
|
|
etcd_result = changed_key_future.result()
|
2015-02-25 17:09:14 +00:00
|
|
|
except (ReadTimeoutError, ProtocolError, etcd.EtcdException):
|
2014-12-31 16:33:56 +00:00
|
|
|
return
|
|
|
|
|
|
|
|
change_callback(etcd_result)
|
|
|
|
|
|
|
|
if not self._shutting_down:
|
|
|
|
watch_future = self._etcd_client.watch(etcd_key, recursive=recursive,
|
|
|
|
timeout=ETCD_DISABLE_TIMEOUT)
|
|
|
|
watch_future.add_done_callback(callback_wrapper)
|
|
|
|
logger.debug('Scheduling watch of key: %s%s', etcd_key, '/*' if recursive else '')
|
|
|
|
self._watch_tasks[watch_task_key] = async(watch_future)
|
|
|
|
|
|
|
|
def _handle_builder_expiration(self, etcd_result):
|
2015-02-25 20:15:22 +00:00
|
|
|
if etcd_result is None:
|
|
|
|
return
|
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
if etcd_result.action == EtcdAction.EXPIRE:
|
2014-12-22 21:22:07 +00:00
|
|
|
# Handle the expiration
|
|
|
|
logger.debug('Builder expired, clean up the old build node')
|
2014-12-23 19:09:04 +00:00
|
|
|
job_metadata = json.loads(etcd_result._prev_node.value)
|
2015-01-05 16:21:36 +00:00
|
|
|
|
|
|
|
if 'builder_id' in job_metadata:
|
|
|
|
logger.info('Terminating expired build node.')
|
|
|
|
async(self._executor.stop_builder(job_metadata['builder_id']))
|
2014-12-22 21:22:07 +00:00
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
def _handle_realm_change(self, etcd_result):
|
2015-02-25 20:15:22 +00:00
|
|
|
if etcd_result is None:
|
|
|
|
return
|
|
|
|
|
2014-12-31 16:46:02 +00:00
|
|
|
if etcd_result.action == EtcdAction.CREATE:
|
2014-12-31 16:33:56 +00:00
|
|
|
# We must listen on the realm created by ourselves or another worker
|
|
|
|
realm_spec = json.loads(etcd_result.value)
|
2015-01-05 16:21:36 +00:00
|
|
|
self._register_realm(realm_spec)
|
2014-12-31 16:33:56 +00:00
|
|
|
|
|
|
|
elif etcd_result.action == EtcdAction.DELETE or etcd_result.action == EtcdAction.EXPIRE:
|
|
|
|
# We must stop listening for new connections on the specified realm, if we did not get the
|
|
|
|
# connection
|
|
|
|
realm_spec = json.loads(etcd_result._prev_node.value)
|
|
|
|
build_job = BuildJob(AttrDict(realm_spec['job_queue_item']))
|
|
|
|
component = self._job_uuid_to_component.pop(build_job.job_details['build_uuid'], None)
|
|
|
|
if component is not None:
|
|
|
|
# We were not the manager which the worker connected to, remove the bookkeeping for it
|
|
|
|
logger.debug('Unregistering unused component on realm: %s', realm_spec['realm'])
|
|
|
|
del self._component_to_job[component]
|
|
|
|
del self._component_to_builder[component]
|
|
|
|
self.unregister_component(component)
|
|
|
|
|
|
|
|
else:
|
|
|
|
logger.warning('Unexpected action (%s) on realm key: %s', etcd_result.action, etcd_result.key)
|
|
|
|
|
2015-01-05 16:21:36 +00:00
|
|
|
def _register_realm(self, realm_spec):
|
|
|
|
logger.debug('Registering realm with manager: %s', realm_spec['realm'])
|
|
|
|
component = self.register_component(realm_spec['realm'], BuildComponent,
|
|
|
|
token=realm_spec['token'])
|
|
|
|
build_job = BuildJob(AttrDict(realm_spec['job_queue_item']))
|
|
|
|
self._component_to_job[component] = build_job
|
|
|
|
self._component_to_builder[component] = realm_spec['builder_id']
|
|
|
|
self._job_uuid_to_component[build_job.job_details['build_uuid']] = component
|
|
|
|
|
|
|
|
@coroutine
|
|
|
|
def _register_existing_realms(self):
|
2015-01-05 17:23:54 +00:00
|
|
|
try:
|
2015-02-02 17:00:19 +00:00
|
|
|
all_realms = yield From(self._etcd_client.read(self._etcd_realm_prefix, recursive=True))
|
2015-01-05 17:23:54 +00:00
|
|
|
for realm in all_realms.children:
|
|
|
|
if not realm.dir:
|
|
|
|
self._register_realm(json.loads(realm.value))
|
2015-02-27 22:33:46 +00:00
|
|
|
except (KeyError, etcd.EtcdKeyError):
|
2015-01-05 17:23:54 +00:00
|
|
|
# no realms have been registered yet
|
|
|
|
pass
|
2015-01-05 16:21:36 +00:00
|
|
|
|
2014-12-16 18:41:30 +00:00
|
|
|
def initialize(self, manager_config):
|
|
|
|
logger.debug('Calling initialize')
|
|
|
|
self._manager_config = manager_config
|
|
|
|
|
|
|
|
executor_klass = self._executors.get(manager_config.get('EXECUTOR', ''), PopenExecutor)
|
|
|
|
self._executor = executor_klass(manager_config.get('EXECUTOR_CONFIG', {}),
|
2014-12-31 16:33:56 +00:00
|
|
|
self.manager_hostname)
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
etcd_host = self._manager_config.get('ETCD_HOST', '127.0.0.1')
|
|
|
|
etcd_port = self._manager_config.get('ETCD_PORT', 2379)
|
2015-01-22 15:53:23 +00:00
|
|
|
etcd_auth = self._manager_config.get('ETCD_CERT_AND_KEY', None)
|
|
|
|
etcd_ca_cert = self._manager_config.get('ETCD_CA_CERT', None)
|
2015-01-22 21:59:04 +00:00
|
|
|
etcd_protocol = 'http' if etcd_auth is None else 'https'
|
2014-12-16 18:41:30 +00:00
|
|
|
logger.debug('Connecting to etcd on %s:%s', etcd_host, etcd_port)
|
|
|
|
|
2014-12-22 22:24:44 +00:00
|
|
|
worker_threads = self._manager_config.get('ETCD_WORKER_THREADS', 5)
|
|
|
|
self._async_thread_executor = ThreadPoolExecutor(worker_threads)
|
2015-01-22 15:53:23 +00:00
|
|
|
self._etcd_client = AsyncWrapper(self._etcd_client_klass(host=etcd_host, port=etcd_port,
|
2015-01-22 21:59:04 +00:00
|
|
|
cert=etcd_auth, ca_cert=etcd_ca_cert,
|
2015-02-25 20:15:22 +00:00
|
|
|
protocol=etcd_protocol,
|
|
|
|
read_timeout=5),
|
2014-12-22 21:22:07 +00:00
|
|
|
executor=self._async_thread_executor)
|
|
|
|
|
2015-02-02 17:00:19 +00:00
|
|
|
self._etcd_builder_prefix = self._manager_config.get('ETCD_BUILDER_PREFIX', 'building/')
|
|
|
|
self._watch_etcd(self._etcd_builder_prefix, self._handle_builder_expiration)
|
|
|
|
|
|
|
|
self._etcd_realm_prefix = self._manager_config.get('ETCD_REALM_PREFIX', 'realm/')
|
|
|
|
self._watch_etcd(self._etcd_realm_prefix, self._handle_realm_change)
|
2014-12-16 18:41:30 +00:00
|
|
|
|
2015-01-05 16:21:36 +00:00
|
|
|
# Load components for all realms currently known to the cluster
|
|
|
|
async(self._register_existing_realms())
|
|
|
|
|
2014-12-16 18:41:30 +00:00
|
|
|
def setup_time(self):
|
|
|
|
setup_time = self._manager_config.get('MACHINE_SETUP_TIME', 300)
|
|
|
|
return setup_time
|
|
|
|
|
|
|
|
def shutdown(self):
|
2014-12-22 21:22:07 +00:00
|
|
|
logger.debug('Shutting down worker.')
|
|
|
|
self._shutting_down = True
|
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
for (etcd_key, _), task in self._watch_tasks.items():
|
|
|
|
if not task.done():
|
|
|
|
logger.debug('Canceling watch task for %s', etcd_key)
|
|
|
|
task.cancel()
|
2014-12-22 21:22:07 +00:00
|
|
|
|
|
|
|
if self._async_thread_executor is not None:
|
|
|
|
logger.debug('Shutting down thread pool executor.')
|
|
|
|
self._async_thread_executor.shutdown()
|
2014-12-16 18:41:30 +00:00
|
|
|
|
2014-12-22 17:14:16 +00:00
|
|
|
@coroutine
|
2014-12-31 16:33:56 +00:00
|
|
|
def schedule(self, build_job):
|
2015-01-05 20:35:14 +00:00
|
|
|
build_uuid = build_job.job_details['build_uuid']
|
|
|
|
logger.debug('Calling schedule with job: %s', build_uuid)
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
# Check if there are worker slots avialable by checking the number of jobs in etcd
|
2014-12-22 17:14:16 +00:00
|
|
|
allowed_worker_count = self._manager_config.get('ALLOWED_WORKER_COUNT', 1)
|
2014-12-16 18:41:30 +00:00
|
|
|
try:
|
2015-02-02 17:00:19 +00:00
|
|
|
building = yield From(self._etcd_client.read(self._etcd_builder_prefix, recursive=True))
|
2014-12-16 18:41:30 +00:00
|
|
|
workers_alive = sum(1 for child in building.children if not child.dir)
|
2015-02-27 22:33:46 +00:00
|
|
|
except (KeyError, etcd.EtcdKeyError):
|
2014-12-16 18:41:30 +00:00
|
|
|
workers_alive = 0
|
2015-02-25 20:15:22 +00:00
|
|
|
except etcd.EtcdException:
|
|
|
|
logger.exception('Exception when reading job count from etcd')
|
|
|
|
raise Return(False)
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
logger.debug('Total jobs: %s', workers_alive)
|
|
|
|
|
|
|
|
if workers_alive >= allowed_worker_count:
|
|
|
|
logger.info('Too many workers alive, unable to start new worker. %s >= %s', workers_alive,
|
|
|
|
allowed_worker_count)
|
2014-12-22 17:14:16 +00:00
|
|
|
raise Return(False)
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
job_key = self._etcd_job_key(build_job)
|
|
|
|
|
|
|
|
# First try to take a lock for this job, meaning we will be responsible for its lifeline
|
|
|
|
realm = str(uuid.uuid4())
|
|
|
|
token = str(uuid.uuid4())
|
2014-12-22 22:24:44 +00:00
|
|
|
ttl = self.setup_time()
|
|
|
|
expiration = datetime.utcnow() + timedelta(seconds=ttl)
|
2014-12-16 18:41:30 +00:00
|
|
|
|
2014-12-23 16:18:10 +00:00
|
|
|
machine_max_expiration = self._manager_config.get('MACHINE_MAX_TIME', 7200)
|
|
|
|
max_expiration = datetime.utcnow() + timedelta(seconds=machine_max_expiration)
|
|
|
|
|
2014-12-16 18:41:30 +00:00
|
|
|
payload = {
|
2014-12-22 17:14:16 +00:00
|
|
|
'expiration': calendar.timegm(expiration.timetuple()),
|
2014-12-23 16:18:10 +00:00
|
|
|
'max_expiration': calendar.timegm(max_expiration.timetuple()),
|
2014-12-16 18:41:30 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
try:
|
2014-12-23 19:09:04 +00:00
|
|
|
yield From(self._etcd_client.write(job_key, json.dumps(payload), prevExist=False, ttl=ttl))
|
2015-02-27 22:33:46 +00:00
|
|
|
except (KeyError, etcd.EtcdKeyError):
|
2014-12-16 18:41:30 +00:00
|
|
|
# The job was already taken by someone else, we are probably a retry
|
2014-12-22 17:14:16 +00:00
|
|
|
logger.error('Job already exists in etcd, are timeouts misconfigured or is the queue broken?')
|
|
|
|
raise Return(False)
|
2015-02-25 20:15:22 +00:00
|
|
|
except etcd.EtcdException:
|
|
|
|
logger.exception('Exception when writing job %s to etcd', build_uuid)
|
|
|
|
raise Return(False)
|
2014-12-16 18:41:30 +00:00
|
|
|
|
2014-12-22 17:14:16 +00:00
|
|
|
logger.debug('Starting builder with executor: %s', self._executor)
|
2015-02-25 17:09:14 +00:00
|
|
|
|
|
|
|
try:
|
|
|
|
builder_id = yield From(self._executor.start_builder(realm, token, build_uuid))
|
|
|
|
except:
|
|
|
|
logger.exception('Exception when starting builder for job: %s', build_uuid)
|
|
|
|
raise Return(False)
|
2014-12-16 18:41:30 +00:00
|
|
|
|
2014-12-22 17:14:16 +00:00
|
|
|
# Store the builder in etcd associated with the job id
|
2015-02-25 17:09:14 +00:00
|
|
|
try:
|
|
|
|
payload['builder_id'] = builder_id
|
|
|
|
yield From(self._etcd_client.write(job_key, json.dumps(payload), prevExist=True, ttl=ttl))
|
|
|
|
except etcd.EtcdException:
|
|
|
|
logger.exception('Exception when writing job %s to etcd', build_uuid)
|
|
|
|
raise Return(False)
|
2014-12-22 17:14:16 +00:00
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
# Store the realm spec which will allow any manager to accept this builder when it connects
|
|
|
|
realm_spec = json.dumps({
|
|
|
|
'realm': realm,
|
|
|
|
'token': token,
|
|
|
|
'builder_id': builder_id,
|
|
|
|
'job_queue_item': build_job.job_item,
|
|
|
|
})
|
2015-02-25 20:15:22 +00:00
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
try:
|
|
|
|
yield From(self._etcd_client.write(self._etcd_realm_key(realm), realm_spec, prevExist=False,
|
|
|
|
ttl=ttl))
|
2015-02-27 22:33:46 +00:00
|
|
|
except (KeyError, etcd.EtcdKeyError):
|
2014-12-31 16:33:56 +00:00
|
|
|
logger.error('Realm already exists in etcd. UUID collision or something is very very wrong.')
|
|
|
|
raise Return(False)
|
2015-02-25 20:15:22 +00:00
|
|
|
except etcd.EtcdException:
|
|
|
|
logger.exception('Exception when writing realm %s to etcd', realm)
|
|
|
|
raise Return(False)
|
2014-12-31 16:33:56 +00:00
|
|
|
|
2014-12-22 17:14:16 +00:00
|
|
|
raise Return(True)
|
2014-12-16 18:41:30 +00:00
|
|
|
|
2014-12-31 16:33:56 +00:00
|
|
|
@coroutine
|
|
|
|
def build_component_ready(self, build_component):
|
2014-12-16 18:41:30 +00:00
|
|
|
try:
|
2014-12-31 16:33:56 +00:00
|
|
|
# Clean up the bookkeeping for allowing any manager to take the job
|
2014-12-16 18:41:30 +00:00
|
|
|
job = self._component_to_job.pop(build_component)
|
2014-12-31 16:33:56 +00:00
|
|
|
del self._job_uuid_to_component[job.job_details['build_uuid']]
|
|
|
|
yield From(self._etcd_client.delete(self._etcd_realm_key(build_component.builder_realm)))
|
|
|
|
|
2014-12-22 17:14:16 +00:00
|
|
|
logger.debug('Sending build %s to newly ready component on realm %s',
|
|
|
|
job.job_details['build_uuid'], build_component.builder_realm)
|
2014-12-31 16:33:56 +00:00
|
|
|
yield From(build_component.start_build(job))
|
2015-02-27 22:33:46 +00:00
|
|
|
except (KeyError, etcd.EtcdKeyError):
|
2015-01-05 19:44:54 +00:00
|
|
|
logger.debug('Builder is asking for more work, but work already completed')
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
def build_component_disposed(self, build_component, timed_out):
|
|
|
|
logger.debug('Calling build_component_disposed.')
|
2014-12-22 22:24:44 +00:00
|
|
|
self.unregister_component(build_component)
|
|
|
|
|
2014-12-22 17:14:16 +00:00
|
|
|
@coroutine
|
2014-12-16 18:41:30 +00:00
|
|
|
def job_completed(self, build_job, job_status, build_component):
|
|
|
|
logger.debug('Calling job_completed with status: %s', job_status)
|
|
|
|
|
2014-12-22 22:24:44 +00:00
|
|
|
# Kill the ephmeral builder
|
2014-12-23 21:12:10 +00:00
|
|
|
yield From(self._executor.stop_builder(self._component_to_builder.pop(build_component)))
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
# Release the lock in etcd
|
|
|
|
job_key = self._etcd_job_key(build_job)
|
2014-12-22 17:14:16 +00:00
|
|
|
yield From(self._etcd_client.delete(job_key))
|
2014-12-16 18:41:30 +00:00
|
|
|
|
|
|
|
self.job_complete_callback(build_job, job_status)
|
|
|
|
|
2014-12-22 22:24:44 +00:00
|
|
|
@coroutine
|
|
|
|
def job_heartbeat(self, build_job):
|
|
|
|
# Extend the deadline in etcd
|
|
|
|
job_key = self._etcd_job_key(build_job)
|
2014-12-23 19:09:04 +00:00
|
|
|
build_job_metadata_response = yield From(self._etcd_client.read(job_key))
|
|
|
|
build_job_metadata = json.loads(build_job_metadata_response.value)
|
2014-12-22 22:24:44 +00:00
|
|
|
|
2014-12-23 19:09:04 +00:00
|
|
|
max_expiration = datetime.utcfromtimestamp(build_job_metadata['max_expiration'])
|
2014-12-23 16:18:10 +00:00
|
|
|
max_expiration_remaining = max_expiration - datetime.utcnow()
|
|
|
|
max_expiration_sec = max(0, int(max_expiration_remaining.total_seconds()))
|
|
|
|
|
|
|
|
ttl = min(self.heartbeat_period_sec * 2, max_expiration_sec)
|
2014-12-22 22:24:44 +00:00
|
|
|
new_expiration = datetime.utcnow() + timedelta(seconds=ttl)
|
|
|
|
|
|
|
|
payload = {
|
|
|
|
'expiration': calendar.timegm(new_expiration.timetuple()),
|
2014-12-23 19:09:04 +00:00
|
|
|
'builder_id': build_job_metadata['builder_id'],
|
|
|
|
'max_expiration': build_job_metadata['max_expiration'],
|
2014-12-22 22:24:44 +00:00
|
|
|
}
|
|
|
|
|
2014-12-23 19:09:04 +00:00
|
|
|
yield From(self._etcd_client.write(job_key, json.dumps(payload), ttl=ttl))
|
2014-12-22 22:24:44 +00:00
|
|
|
|
|
|
|
self.job_heartbeat_callback(build_job)
|
|
|
|
|
2015-02-02 17:00:19 +00:00
|
|
|
def _etcd_job_key(self, build_job):
|
2014-12-16 18:41:30 +00:00
|
|
|
""" Create a key which is used to track a job in etcd.
|
|
|
|
"""
|
2015-02-02 17:00:19 +00:00
|
|
|
return os.path.join(self._etcd_builder_prefix, build_job.job_details['build_uuid'])
|
2014-12-22 22:24:44 +00:00
|
|
|
|
2015-02-02 17:00:19 +00:00
|
|
|
def _etcd_realm_key(self, realm):
|
2014-12-31 16:33:56 +00:00
|
|
|
""" Create a key which is used to track an incoming connection on a realm.
|
|
|
|
"""
|
2015-02-02 17:00:19 +00:00
|
|
|
return os.path.join(self._etcd_realm_prefix, realm)
|
2014-12-31 16:33:56 +00:00
|
|
|
|
2014-12-22 22:24:44 +00:00
|
|
|
def num_workers(self):
|
|
|
|
""" Return the number of workers we're managing locally.
|
|
|
|
"""
|
|
|
|
return len(self._component_to_builder)
|