Class: Resque::Worker
- Inherits:
-
Object
- Object
- Resque::Worker
- Extended by:
- Helpers
- Includes:
- Helpers
- Defined in:
- lib/resque/worker.rb
Overview
A Resque Worker processes jobs. On platforms that support fork(2), the worker will fork off a child to process each job. This ensures a clean slate when beginning the next job and cuts down on gradual memory growth as well as low level failures.
It also ensures workers are always listening to signals from you, their master, and can react accordingly.
Instance Attribute Summary collapse
-
#cant_fork ⇒ Object
Boolean indicating whether this worker can or can not fork.
-
#to_s ⇒ Object
(also: #id)
The string representation is the same as the id for this worker instance.
-
#verbose ⇒ Object
Whether the worker should log basic info to STDOUT.
-
#very_verbose ⇒ Object
Whether the worker should log lots of info to STDOUT.
Class Method Summary collapse
-
.all ⇒ Object
Returns an array of all worker objects.
-
.attach(worker_id) ⇒ Object
Alias of ‘find`.
-
.exists?(worker_id) ⇒ Boolean
Given a string worker id, return a boolean indicating whether the worker exists.
-
.find(worker_id) ⇒ Object
Returns a single worker object.
-
.working ⇒ Object
Returns an array of all worker objects currently processing jobs.
Instance Method Summary collapse
-
#==(other) ⇒ Object
Is this worker the same as another worker?.
-
#done_working ⇒ Object
Called when we are done working - clears our ‘working_on` state and tells Redis we processed a job.
-
#enable_gc_optimizations ⇒ Object
Enables GC Optimizations if you’re running REE.
-
#failed ⇒ Object
How many failed jobs has this worker seen? Returns an int.
-
#failed! ⇒ Object
Tells Redis we’ve failed a job.
-
#fork ⇒ Object
Not every platform supports fork.
-
#hostname ⇒ Object
chomp’d hostname of this machine.
-
#idle? ⇒ Boolean
Boolean - true if idle, false if not.
-
#initialize(*queues) ⇒ Worker
constructor
Workers should be initialized with an array of string queue names.
- #inspect ⇒ Object
-
#job ⇒ Object
(also: #processing)
Returns a hash explaining the Job we’re currently processing, if any.
-
#kill_child ⇒ Object
Kills the forked child immediately, without remorse.
-
#linux_worker_pids ⇒ Object
Find Resque worker pids on Linux and OS X.
-
#log(message) ⇒ Object
Log a message to STDOUT if we are verbose or very_verbose.
-
#log!(message) ⇒ Object
Logs a very verbose message to STDOUT.
- #pause ⇒ Object
-
#pause_processing ⇒ Object
Stop processing jobs after the current one has completed (if we’re currently running one).
-
#perform(job) ⇒ Object
Processes a given job in the child.
-
#pid ⇒ Object
Returns Integer PID of running worker.
-
#process(job = nil, &block) ⇒ Object
DEPRECATED.
-
#processed ⇒ Object
How many jobs has this worker processed? Returns an int.
-
#processed! ⇒ Object
Tell Redis we’ve processed a job.
-
#procline(string) ⇒ Object
Given a string, sets the procline ($0) and logs.
-
#prune_dead_workers ⇒ Object
Looks for any workers which should be running on this server and, if they’re not, removes them from Redis.
-
#queues ⇒ Object
Returns a list of queues to use when searching for a job.
-
#register_signal_handlers ⇒ Object
Registers the various signal handlers a worker responds to.
-
#register_worker ⇒ Object
Registers ourself as a worker.
-
#reserve(interval = 5.0) ⇒ Object
Attempts to grab a job off one of the provided queues.
-
#run_hook(name, *args) ⇒ Object
Runs a named hook, passing along any arguments.
-
#should_pause? ⇒ Boolean
(also: #paused?)
are we paused?.
-
#shutdown ⇒ Object
Schedule this worker for shutdown.
-
#shutdown! ⇒ Object
Kill the child and shutdown immediately.
-
#shutdown? ⇒ Boolean
Should this worker shutdown as soon as current job is finished?.
-
#solaris_worker_pids ⇒ Object
Find Resque worker pids on Solaris.
-
#started ⇒ Object
What time did this worker start? Returns an instance of ‘Time`.
-
#started! ⇒ Object
Tell Redis we’ve started.
-
#startup ⇒ Object
Runs all the methods needed when a worker begins its lifecycle.
-
#state ⇒ Object
Returns a symbol representing the current worker state, which can be either :working or :idle.
-
#unregister_worker ⇒ Object
Unregisters ourself as a worker.
-
#validate_queues ⇒ Object
A worker must be given a queue, otherwise it won’t know what to do with itself.
-
#work(interval = 5.0, &block) ⇒ Object
This is the main workhorse method.
-
#worker_pids ⇒ Object
Returns an Array of string pids of all the other workers on this machine.
-
#working? ⇒ Boolean
Boolean - true if working, false if not.
-
#working_on(job) ⇒ Object
Given a job, tells Redis we’re working on it.
Methods included from Helpers
classify, constantize, decode, encode, redis
Constructor Details
#initialize(*queues) ⇒ Worker
Workers should be initialized with an array of string queue names. The order is important: a Worker will check the first queue given for a job. If none is found, it will check the second queue name given. If a job is found, it will be processed. Upon completion, the Worker will again check the first queue given, and so forth. In this way the queue list passed to a Worker on startup defines the priorities of queues.
If passed a single “*”, this Worker will operate on all queues in alphabetical order. Queues can be dynamically added or removed without needing to restart workers using this method.
90 91 92 93 94 95 |
# File 'lib/resque/worker.rb', line 90 def initialize(*queues) @queues = queues.map { |queue| queue.to_s.strip } @shutdown = nil @paused = nil validate_queues end |
Instance Attribute Details
#cant_fork ⇒ Object
Boolean indicating whether this worker can or can not fork. Automatically set if a fork(2) fails.
21 22 23 |
# File 'lib/resque/worker.rb', line 21 def cant_fork @cant_fork end |
#to_s ⇒ Object Also known as: id
The string representation is the same as the id for this worker instance. Can be used with ‘Worker.find`.
485 486 487 |
# File 'lib/resque/worker.rb', line 485 def to_s @to_s ||= "#{hostname}:#{Process.pid}:#{@queues.join(',')}" end |
#verbose ⇒ Object
Whether the worker should log basic info to STDOUT
14 15 16 |
# File 'lib/resque/worker.rb', line 14 def verbose @verbose end |
#very_verbose ⇒ Object
Whether the worker should log lots of info to STDOUT
17 18 19 |
# File 'lib/resque/worker.rb', line 17 def very_verbose @very_verbose end |
Class Method Details
.all ⇒ Object
Returns an array of all worker objects.
26 27 28 |
# File 'lib/resque/worker.rb', line 26 def self.all Array(redis.smembers(:workers)).map { |id| find(id) }.compact end |
.attach(worker_id) ⇒ Object
Alias of ‘find`
69 70 71 |
# File 'lib/resque/worker.rb', line 69 def self.attach(worker_id) find(worker_id) end |
.exists?(worker_id) ⇒ Boolean
Given a string worker id, return a boolean indicating whether the worker exists
75 76 77 |
# File 'lib/resque/worker.rb', line 75 def self.exists?(worker_id) redis.sismember(:workers, worker_id) end |
.find(worker_id) ⇒ Object
Returns a single worker object. Accepts a string id.
57 58 59 60 61 62 63 64 65 66 |
# File 'lib/resque/worker.rb', line 57 def self.find(worker_id) if exists? worker_id queues = worker_id.split(':')[-1].split(',') worker = new(*queues) worker.to_s = worker_id worker else nil end end |
.working ⇒ Object
Returns an array of all worker objects currently processing jobs.
32 33 34 35 36 37 38 39 40 41 42 43 44 45 46 47 48 49 50 51 52 53 54 |
# File 'lib/resque/worker.rb', line 32 def self.working names = all return [] unless names.any? names.map! { |name| "worker:#{name}" } reportedly_working = {} begin reportedly_working = redis.mapped_mget(*names).reject do |key, value| value.nil? || value.empty? end rescue Redis::Distributed::CannotDistribute names.each do |name| value = redis.get name reportedly_working[name] = value unless value.nil? || value.empty? end end reportedly_working.keys.map do |key| find key.sub("worker:", '') end.compact end |
Instance Method Details
#==(other) ⇒ Object
Is this worker the same as another worker?
475 476 477 |
# File 'lib/resque/worker.rb', line 475 def ==(other) to_s == other.to_s end |
#done_working ⇒ Object
Called when we are done working - clears our ‘working_on` state and tells Redis we processed a job.
415 416 417 418 |
# File 'lib/resque/worker.rb', line 415 def done_working processed! redis.del("worker:#{self}") end |
#enable_gc_optimizations ⇒ Object
Enables GC Optimizations if you’re running REE. www.rubyenterpriseedition.com/faq.html#adapt_apps_for_cow
258 259 260 261 262 |
# File 'lib/resque/worker.rb', line 258 def enable_gc_optimizations if GC.respond_to?(:copy_on_write_friendly=) GC.copy_on_write_friendly = true end end |
#failed ⇒ Object
How many failed jobs has this worker seen? Returns an int.
432 433 434 |
# File 'lib/resque/worker.rb', line 432 def failed Stat["failed:#{self}"] end |
#failed! ⇒ Object
Tells Redis we’ve failed a job.
437 438 439 440 |
# File 'lib/resque/worker.rb', line 437 def failed! Stat << "failed" Stat << "failed:#{self}" end |
#fork ⇒ Object
Not every platform supports fork. Here we do our magic to determine if yours does.
225 226 227 228 229 230 231 232 233 234 235 236 237 238 239 240 241 |
# File 'lib/resque/worker.rb', line 225 def fork @cant_fork = true if $TESTING return if @cant_fork begin # IronRuby doesn't support `Kernel.fork` yet if Kernel.respond_to?(:fork) Kernel.fork else raise NotImplementedError end rescue NotImplementedError @cant_fork = true nil end end |
#hostname ⇒ Object
chomp’d hostname of this machine
491 492 493 |
# File 'lib/resque/worker.rb', line 491 def hostname Socket.gethostname end |
#idle? ⇒ Boolean
Boolean - true if idle, false if not
464 465 466 |
# File 'lib/resque/worker.rb', line 464 def idle? state == :idle end |
#inspect ⇒ Object
479 480 481 |
# File 'lib/resque/worker.rb', line 479 def inspect "#<Worker #{to_s}>" end |
#job ⇒ Object Also known as: processing
Returns a hash explaining the Job we’re currently processing, if any.
453 454 455 |
# File 'lib/resque/worker.rb', line 453 def job decode(redis.get("worker:#{self}")) || {} end |
#kill_child ⇒ Object
Kills the forked child immediately, without remorse. The job it is processing will not be completed.
307 308 309 310 311 312 313 314 315 316 317 |
# File 'lib/resque/worker.rb', line 307 def kill_child if @child log! "Killing child at #{@child}" if system("ps -o pid,state -p #{@child}") Process.kill("KILL", @child) rescue nil else log! "Child #{@child} not found, restarting." shutdown end end end |
#linux_worker_pids ⇒ Object
Find Resque worker pids on Linux and OS X.
Returns an Array of string pids of all the other workers on this machine. Useful when pruning dead workers on startup.
514 515 516 517 518 |
# File 'lib/resque/worker.rb', line 514 def linux_worker_pids `ps -A -o pid,command | grep "[r]esque" | grep -v "resque-web"`.split("\n").map do |line| line.split(' ')[0] end end |
#log(message) ⇒ Object
Log a message to STDOUT if we are verbose or very_verbose.
543 544 545 546 547 548 549 550 |
# File 'lib/resque/worker.rb', line 543 def log() if verbose puts "*** #{}" elsif very_verbose time = Time.now.strftime('%H:%M:%S %Y-%m-%d') puts "** [#{time}] #$$: #{}" end end |
#log!(message) ⇒ Object
Logs a very verbose message to STDOUT.
553 554 555 |
# File 'lib/resque/worker.rb', line 553 def log!() log if very_verbose end |
#pause ⇒ Object
325 326 327 328 329 330 331 332 333 334 335 |
# File 'lib/resque/worker.rb', line 325 def pause rd, wr = IO.pipe trap('CONT') { log "CONT received; resuming job processing" @paused = false wr.write 'x' wr.close } rd.read 1 rd.close end |
#pause_processing ⇒ Object
Stop processing jobs after the current one has completed (if we’re currently running one).
339 340 341 342 |
# File 'lib/resque/worker.rb', line 339 def pause_processing log "USR2 received; pausing job processing" @paused = true end |
#perform(job) ⇒ Object
Processes a given job in the child.
175 176 177 178 179 180 181 182 183 184 185 186 187 188 189 190 191 192 |
# File 'lib/resque/worker.rb', line 175 def perform(job) begin run_hook :after_fork, job job.perform rescue Object => e log "#{job.inspect} failed: #{e.inspect}" begin job.fail(e) rescue Object => e log "Received exception when reporting failure: #{e.inspect}" end failed! else log "done: #{job.inspect}" ensure yield job if block_given? end end |
#pid ⇒ Object
Returns Integer PID of running worker
496 497 498 |
# File 'lib/resque/worker.rb', line 496 def pid Process.pid end |
#process(job = nil, &block) ⇒ Object
DEPRECATED. Processes a single job. If none is given, it will try to produce one. Usually run in the child.
164 165 166 167 168 169 170 171 172 |
# File 'lib/resque/worker.rb', line 164 def process(job = nil, &block) return unless job ||= reserve job.worker = self working_on job perform(job, &block) ensure done_working end |
#processed ⇒ Object
How many jobs has this worker processed? Returns an int.
421 422 423 |
# File 'lib/resque/worker.rb', line 421 def processed Stat["processed:#{self}"] end |
#processed! ⇒ Object
Tell Redis we’ve processed a job.
426 427 428 429 |
# File 'lib/resque/worker.rb', line 426 def processed! Stat << "processed" Stat << "processed:#{self}" end |
#procline(string) ⇒ Object
Given a string, sets the procline ($0) and logs. Procline is always in the format of:
resque-VERSION: STRING
537 538 539 540 |
# File 'lib/resque/worker.rb', line 537 def procline(string) $0 = "resque-#{Resque::Version}: #{string}" log! $0 end |
#prune_dead_workers ⇒ Object
Looks for any workers which should be running on this server and, if they’re not, removes them from Redis.
This is a form of garbage collection. If a server is killed by a hard shutdown, power failure, or something else beyond our control, the Resque workers will not die gracefully and therefore will leave stale state information in Redis.
By checking the current Redis state against the actual environment, we can determine if Redis is old and clean it up a bit.
354 355 356 357 358 359 360 361 362 363 364 |
# File 'lib/resque/worker.rb', line 354 def prune_dead_workers all_workers = Worker.all known_workers = worker_pids unless all_workers.empty? all_workers.each do |worker| host, pid, queues = worker.id.split(':') next unless host == hostname next if known_workers.include?(pid) log! "Pruning dead worker: #{worker}" worker.unregister_worker end end |
#queues ⇒ Object
Returns a list of queues to use when searching for a job. A splat (“*”) means you want every queue (in alpha order) - this can be useful for dynamically adding new queues.
219 220 221 |
# File 'lib/resque/worker.rb', line 219 def queues @queues.map {|queue| queue == "*" ? Resque.queues.sort : queue }.flatten.uniq end |
#register_signal_handlers ⇒ Object
Registers the various signal handlers a worker responds to.
TERM: Shutdown immediately, stop processing jobs.
INT: Shutdown immediately, stop processing jobs.
QUIT: Shutdown after the current job has finished processing. USR1: Kill the forked child immediately, continue processing jobs. USR2: Don’t process any new jobs CONT: Start processing jobs again after a USR2
272 273 274 275 276 277 278 279 280 281 282 283 284 285 |
# File 'lib/resque/worker.rb', line 272 def register_signal_handlers trap('TERM') { shutdown } trap('INT') { shutdown! } begin trap('QUIT') { shutdown } trap('USR1') { kill_child } trap('USR2') { pause_processing } rescue ArgumentError warn "Signals QUIT, USR1, USR2, and/or CONT not supported." end log! "Registered signals" end |
#register_worker ⇒ Object
Registers ourself as a worker. Useful when entering the worker lifecycle on startup.
368 369 370 371 |
# File 'lib/resque/worker.rb', line 368 def register_worker redis.sadd(:workers, self) started! end |
#reserve(interval = 5.0) ⇒ Object
Attempts to grab a job off one of the provided queues. Returns nil if no job can be found.
196 197 198 199 200 201 202 203 204 205 206 207 208 209 210 211 212 213 214 |
# File 'lib/resque/worker.rb', line 196 def reserve(interval = 5.0) interval = interval.to_i multi_queue = MultiQueue.new( queues.map {|queue| Queue.new(queue, Resque.redis, Resque.coder) }, Resque.redis) if interval < 1 begin queue, job = multi_queue.pop(true) rescue ThreadError queue, job = nil end else queue, job = multi_queue.poll(interval.to_i) end log! "Found job on #{queue}" Job.new(queue.name, job) if queue && job end |
#run_hook(name, *args) ⇒ Object
Runs a named hook, passing along any arguments.
374 375 376 377 378 379 380 381 |
# File 'lib/resque/worker.rb', line 374 def run_hook(name, *args) return unless hook = Resque.send(name) msg = "Running #{name} hook" msg << " with #{args.inspect}" if args.any? log msg args.any? ? hook.call(*args) : hook.call end |
#should_pause? ⇒ Boolean Also known as: paused?
are we paused?
320 321 322 |
# File 'lib/resque/worker.rb', line 320 def should_pause? @paused end |
#shutdown ⇒ Object
Schedule this worker for shutdown. Will finish processing the current job.
289 290 291 292 |
# File 'lib/resque/worker.rb', line 289 def shutdown log 'Exiting...' @shutdown = true end |
#shutdown! ⇒ Object
Kill the child and shutdown immediately.
295 296 297 298 |
# File 'lib/resque/worker.rb', line 295 def shutdown! shutdown kill_child end |
#shutdown? ⇒ Boolean
Should this worker shutdown as soon as current job is finished?
301 302 303 |
# File 'lib/resque/worker.rb', line 301 def shutdown? @shutdown end |
#solaris_worker_pids ⇒ Object
Find Resque worker pids on Solaris.
Returns an Array of string pids of all the other workers on this machine. Useful when pruning dead workers on startup.
524 525 526 527 528 529 530 531 532 |
# File 'lib/resque/worker.rb', line 524 def solaris_worker_pids `ps -A -o pid,comm | grep "[r]uby" | grep -v "resque-web"`.split("\n").map do |line| real_pid = line.split(' ')[0] pargs_command = `pargs -a #{real_pid} 2>/dev/null | grep [r]esque | grep -v "resque-web"` if pargs_command.split(':')[1] == " resque-#{Resque::Version}" real_pid end end.compact end |
#started ⇒ Object
What time did this worker start? Returns an instance of ‘Time`
443 444 445 |
# File 'lib/resque/worker.rb', line 443 def started redis.get "worker:#{self}:started" end |
#started! ⇒ Object
Tell Redis we’ve started
448 449 450 |
# File 'lib/resque/worker.rb', line 448 def started! redis.set("worker:#{self}:started", Time.now.to_s) end |
#startup ⇒ Object
Runs all the methods needed when a worker begins its lifecycle.
244 245 246 247 248 249 250 251 252 253 254 |
# File 'lib/resque/worker.rb', line 244 def startup enable_gc_optimizations register_signal_handlers prune_dead_workers run_hook :before_first_fork register_worker # Fix buffering so we can `rake resque:work > resque.log` and # get output from the child in there. $stdout.sync = true end |
#state ⇒ Object
Returns a symbol representing the current worker state, which can be either :working or :idle
470 471 472 |
# File 'lib/resque/worker.rb', line 470 def state redis.exists("worker:#{self}") ? :working : :idle end |
#unregister_worker ⇒ Object
Unregisters ourself as a worker. Useful when shutting down.
384 385 386 387 388 389 390 391 392 393 394 395 396 397 398 399 400 401 |
# File 'lib/resque/worker.rb', line 384 def unregister_worker # If we're still processing a job, make sure it gets logged as a # failure. if (hash = processing) && !hash.empty? job = Job.new(hash['queue'], hash['payload']) # Ensure the proper worker is attached to this job, even if # it's not the precise instance that died. job.worker = self job.fail(DirtyExit.new) end redis.srem(:workers, self) redis.del("worker:#{self}") redis.del("worker:#{self}:started") Stat.clear("processed:#{self}") Stat.clear("failed:#{self}") end |
#validate_queues ⇒ Object
A worker must be given a queue, otherwise it won’t know what to do with itself.
You probably never need to call this.
101 102 103 104 105 |
# File 'lib/resque/worker.rb', line 101 def validate_queues if @queues.nil? || @queues.empty? raise NoQueueError.new("Please give each worker at least one queue.") end end |
#work(interval = 5.0, &block) ⇒ Object
This is the main workhorse method. Called on a Worker instance, it begins the worker life cycle.
The following events occur during a worker’s life cycle:
-
Startup: Signals are registered, dead workers are pruned,
and this worker is registered.
-
Work loop: Jobs are pulled from a queue and processed.
-
Teardown: This worker is unregistered.
Can be passed a float representing the polling frequency. The default is 5 seconds, but for a semi-active site you may want to use a smaller value.
Also accepts a block which will be passed the job as soon as it has completed processing. Useful for testing.
123 124 125 126 127 128 129 130 131 132 133 134 135 136 137 138 139 140 141 142 143 144 145 146 147 148 149 150 151 152 153 154 155 156 157 158 159 160 |
# File 'lib/resque/worker.rb', line 123 def work(interval = 5.0, &block) interval = Float(interval) $0 = "resque: Starting" startup loop do break if shutdown? pause if should_pause? if job = reserve(interval) log "got: #{job.inspect}" job.worker = self run_hook :before_fork, job working_on job if @child = fork srand # Reseeding procline "Forked #{@child} at #{Time.now.to_i}" Process.wait(@child) else procline "Processing #{job.queue} since #{Time.now.to_i}" perform(job, &block) exit! unless @cant_fork end done_working @child = nil else break if interval.zero? log! "Timed out after #{interval} seconds" procline paused? ? "Paused" : "Waiting for #{@queues.join(',')}" end end ensure unregister_worker end |
#worker_pids ⇒ Object
Returns an Array of string pids of all the other workers on this machine. Useful when pruning dead workers on startup.
502 503 504 505 506 507 508 |
# File 'lib/resque/worker.rb', line 502 def worker_pids if RUBY_PLATFORM =~ /solaris/ solaris_worker_pids else linux_worker_pids end end |
#working? ⇒ Boolean
Boolean - true if working, false if not
459 460 461 |
# File 'lib/resque/worker.rb', line 459 def working? state == :working end |
#working_on(job) ⇒ Object
Given a job, tells Redis we’re working on it. Useful for seeing what workers are doing and when.
405 406 407 408 409 410 411 |
# File 'lib/resque/worker.rb', line 405 def working_on(job) data = encode \ :queue => job.queue, :run_at => Time.now.strftime("%Y/%m/%d %H:%M:%S %Z"), :payload => job.payload redis.set("worker:#{self}", data) end |