debian-mirror-gitlab/app/models/ci/pipeline.rb

423 lines
11 KiB
Ruby
Raw Normal View History

2015-09-25 12:07:36 +05:30
module Ci
class Pipeline < ActiveRecord::Base
2015-09-25 12:07:36 +05:30
extend Ci::Model
2016-09-29 09:46:39 +05:30
include HasStatus
include Importable
2016-11-03 12:29:30 +05:30
include AfterCommitQueue
2017-08-17 22:00:37 +05:30
include Presentable
2015-10-24 18:46:33 +05:30
2017-08-17 22:00:37 +05:30
belongs_to :project
2016-08-24 12:49:21 +05:30
belongs_to :user
2017-08-17 22:00:37 +05:30
belongs_to :auto_canceled_by, class_name: 'Ci::Pipeline'
belongs_to :pipeline_schedule, class_name: 'Ci::PipelineSchedule'
has_many :auto_canceled_pipelines, class_name: 'Ci::Pipeline', foreign_key: 'auto_canceled_by_id'
has_many :auto_canceled_jobs, class_name: 'CommitStatus', foreign_key: 'auto_canceled_by_id'
2016-08-24 12:49:21 +05:30
has_many :statuses, class_name: 'CommitStatus', foreign_key: :commit_id
2017-08-17 22:00:37 +05:30
has_many :builds, foreign_key: :commit_id
has_many :trigger_requests, dependent: :destroy, foreign_key: :commit_id
has_many :pending_builds, -> { pending }, foreign_key: :commit_id, class_name: 'Ci::Build'
has_many :retryable_builds, -> { latest.failed_or_canceled }, foreign_key: :commit_id, class_name: 'Ci::Build'
has_many :cancelable_statuses, -> { cancelable }, foreign_key: :commit_id, class_name: 'CommitStatus'
has_many :manual_actions, -> { latest.manual_actions }, foreign_key: :commit_id, class_name: 'Ci::Build'
has_many :artifacts, -> { latest.with_artifacts_not_expired }, foreign_key: :commit_id, class_name: 'Ci::Build'
delegate :id, to: :project, prefix: true
2015-09-25 12:07:36 +05:30
2017-08-17 22:00:37 +05:30
validates :sha, presence: { unless: :importing? }
validates :ref, presence: { unless: :importing? }
validates :status, presence: { unless: :importing? }
2016-09-29 09:46:39 +05:30
validate :valid_commit_sha, unless: :importing?
2015-09-25 12:07:36 +05:30
2016-11-03 12:29:30 +05:30
after_create :keep_around_commits, unless: :importing?
2016-08-24 12:49:21 +05:30
2016-09-13 17:45:13 +05:30
state_machine :status, initial: :created do
event :enqueue do
transition created: :pending
transition [:success, :failed, :canceled, :skipped] => :running
end
event :run do
2017-08-17 22:00:37 +05:30
transition any - [:running] => :running
2016-09-13 17:45:13 +05:30
end
event :skip do
2017-08-17 22:00:37 +05:30
transition any - [:skipped] => :skipped
2016-09-13 17:45:13 +05:30
end
event :drop do
2017-08-17 22:00:37 +05:30
transition any - [:failed] => :failed
2016-09-13 17:45:13 +05:30
end
event :succeed do
2017-08-17 22:00:37 +05:30
transition any - [:success] => :success
2016-09-13 17:45:13 +05:30
end
event :cancel do
2017-08-17 22:00:37 +05:30
transition any - [:canceled] => :canceled
end
event :block do
transition any - [:manual] => :manual
2016-09-13 17:45:13 +05:30
end
2016-11-03 12:29:30 +05:30
# IMPORTANT
# Do not add any operations to this state_machine
# Create a separate worker for each new operation
2016-09-13 17:45:13 +05:30
before_transition [:created, :pending] => :running do |pipeline|
pipeline.started_at = Time.now
end
before_transition any => [:success, :failed, :canceled] do |pipeline|
pipeline.finished_at = Time.now
2016-11-03 12:29:30 +05:30
pipeline.update_duration
2016-09-13 17:45:13 +05:30
end
2017-08-17 22:00:37 +05:30
before_transition any => [:manual] do |pipeline|
pipeline.update_duration
end
before_transition canceled: any - [:canceled] do |pipeline|
pipeline.auto_canceled_by = nil
end
2016-09-29 09:46:39 +05:30
after_transition [:created, :pending] => :running do |pipeline|
2017-08-17 22:00:37 +05:30
pipeline.run_after_commit { PipelineMetricsWorker.perform_async(pipeline.id) }
2016-09-29 09:46:39 +05:30
end
after_transition any => [:success] do |pipeline|
2017-08-17 22:00:37 +05:30
pipeline.run_after_commit { PipelineMetricsWorker.perform_async(pipeline.id) }
2016-09-29 09:46:39 +05:30
end
2016-11-03 12:29:30 +05:30
after_transition [:created, :pending, :running] => :success do |pipeline|
2017-08-17 22:00:37 +05:30
pipeline.run_after_commit { PipelineSuccessWorker.perform_async(pipeline.id) }
2016-09-13 17:45:13 +05:30
end
after_transition do |pipeline, transition|
2016-11-03 12:29:30 +05:30
next if transition.loopback?
pipeline.run_after_commit do
2017-08-17 22:00:37 +05:30
PipelineHooksWorker.perform_async(pipeline.id)
ExpirePipelineCacheWorker.perform_async(pipeline.id)
end
end
after_transition any => [:success, :failed] do |pipeline|
pipeline.run_after_commit do
PipelineNotificationWorker.perform_async(pipeline.id)
2016-11-03 12:29:30 +05:30
end
2016-09-13 17:45:13 +05:30
end
end
2016-08-24 12:49:21 +05:30
# ref can't be HEAD or SHA, can only be branch/tag name
2017-08-17 22:00:37 +05:30
scope :latest, ->(ref = nil) do
max_id = unscope(:select)
.select("max(#{quoted_table_name}.id)")
.group(:ref, :sha)
if ref
where(ref: ref, id: max_id.where(ref: ref))
else
where(id: max_id)
end
end
def self.latest_status(ref = nil)
latest(ref).status
end
2016-09-29 09:46:39 +05:30
def self.latest_successful_for(ref)
2017-08-17 22:00:37 +05:30
success.latest(ref).order(id: :desc).first
2016-08-24 12:49:21 +05:30
end
2016-06-02 11:05:42 +05:30
2017-08-17 22:00:37 +05:30
def self.latest_successful_for_refs(refs)
success.latest(refs).order(id: :desc).each_with_object({}) do |pipeline, hash|
hash[pipeline.ref] ||= pipeline
end
2015-09-25 12:07:36 +05:30
end
2017-08-17 22:00:37 +05:30
def self.truncate_sha(sha)
sha[0...8]
2015-09-25 12:07:36 +05:30
end
2016-09-13 17:45:13 +05:30
def self.total_duration
where.not(duration: nil).sum(:duration)
end
2017-08-17 22:00:37 +05:30
def stage(name)
stage = Ci::Stage.new(self, name: name)
stage unless stage.statuses_count.zero?
2016-09-13 17:45:13 +05:30
end
2017-08-17 22:00:37 +05:30
def stages_count
statuses.select(:stage).distinct.count
end
def stages_name
statuses.order(:stage_idx).distinct.
pluck(:stage, :stage_idx).map(&:first)
end
def stages
# TODO, this needs refactoring, see gitlab-ce#26481.
stages_query = statuses
.group('stage').select(:stage).order('max(stage_idx)')
status_sql = statuses.latest.where('stage=sg.stage').status_sql
warnings_sql = statuses.latest.select('COUNT(*)')
.where('stage=sg.stage').failed_but_allowed.to_sql
stages_with_statuses = CommitStatus.from(stages_query, :sg)
.pluck('sg.stage', status_sql, "(#{warnings_sql})")
stages_with_statuses.map do |stage|
Ci::Stage.new(self, Hash[%i[name status warnings].zip(stage)])
end
2015-10-24 18:46:33 +05:30
end
2015-09-25 12:07:36 +05:30
def valid_commit_sha
2015-12-23 02:04:40 +05:30
if self.sha == Gitlab::Git::BLANK_SHA
2015-09-25 12:07:36 +05:30
self.errors.add(:sha, " cant be 00000000 (branch removal)")
end
end
def git_author_name
2016-06-22 15:30:34 +05:30
commit.try(:author_name)
2015-09-25 12:07:36 +05:30
end
def git_author_email
2016-06-22 15:30:34 +05:30
commit.try(:author_email)
2015-09-25 12:07:36 +05:30
end
def git_commit_message
2016-06-22 15:30:34 +05:30
commit.try(:message)
2015-09-25 12:07:36 +05:30
end
2016-08-24 12:49:21 +05:30
def git_commit_title
commit.try(:title)
end
2015-09-25 12:07:36 +05:30
def short_sha
Ci::Pipeline.truncate_sha(sha)
2015-09-25 12:07:36 +05:30
end
2016-06-22 15:30:34 +05:30
def commit
2015-12-23 02:04:40 +05:30
@commit ||= project.commit(sha)
2015-09-25 12:07:36 +05:30
rescue
nil
end
2016-06-02 11:05:42 +05:30
def branch?
!tag?
end
2017-08-17 22:00:37 +05:30
def stuck?
pending_builds.any?(&:stuck?)
2016-08-24 12:49:21 +05:30
end
2016-06-02 11:05:42 +05:30
def retryable?
2017-08-17 22:00:37 +05:30
retryable_builds.any?
2016-06-02 11:05:42 +05:30
end
def cancelable?
2017-08-17 22:00:37 +05:30
cancelable_statuses.any?
end
def auto_canceled?
canceled? && auto_canceled_by_id?
end
2016-06-02 11:05:42 +05:30
def cancel_running
2017-08-17 22:00:37 +05:30
Gitlab::OptimisticLocking.retry_lock(cancelable_statuses) do |cancelable|
cancelable.find_each do |job|
yield(job) if block_given?
job.cancel
end
end
2016-06-02 11:05:42 +05:30
end
2017-08-17 22:00:37 +05:30
def auto_cancel_running(pipeline)
update(auto_canceled_by: pipeline)
cancel_running do |job|
job.auto_canceled_by = pipeline
end
2016-06-02 11:05:42 +05:30
end
2017-08-17 22:00:37 +05:30
def retry_failed(current_user)
Ci::RetryPipelineService.new(project, current_user)
.execute(self)
end
2016-09-13 17:45:13 +05:30
def mark_as_processable_after_stage(stage_idx)
2017-08-17 22:00:37 +05:30
builds.skipped.after_stage(stage_idx).find_each(&:process)
2016-09-13 17:45:13 +05:30
end
2016-06-02 11:05:42 +05:30
def latest?
return false unless ref
commit = project.commit(ref)
return false unless commit
commit.sha == sha
2015-09-25 12:07:36 +05:30
end
2016-06-02 11:05:42 +05:30
def triggered?
trigger_requests.any?
end
2015-10-24 18:46:33 +05:30
def retried
@retried ||= (statuses.order(id: :desc) - statuses.latest)
2015-09-25 12:07:36 +05:30
end
def coverage
2016-06-02 11:05:42 +05:30
coverage_array = statuses.latest.map(&:coverage).compact
2015-12-23 02:04:40 +05:30
if coverage_array.size >= 1
'%.2f' % (coverage_array.reduce(:+) / coverage_array.size)
2015-09-25 12:07:36 +05:30
end
end
2016-09-13 17:45:13 +05:30
def config_builds_attributes
return [] unless config_processor
config_processor.
builds_for_ref(ref, tag?, trigger_requests.first).
sort_by { |build| build[:stage_idx] }
end
2016-08-24 12:49:21 +05:30
def has_warnings?
2016-11-03 12:29:30 +05:30
builds.latest.failed_but_allowed.any?
2016-08-24 12:49:21 +05:30
end
2015-09-25 12:07:36 +05:30
def config_processor
2015-11-26 14:37:03 +05:30
return nil unless ci_yaml_file
2016-06-02 11:05:42 +05:30
return @config_processor if defined?(@config_processor)
@config_processor ||= begin
Ci::GitlabCiYamlProcessor.new(ci_yaml_file, project.path_with_namespace)
rescue Ci::GitlabCiYamlProcessor::ValidationError, Psych::SyntaxError => e
2016-06-22 15:30:34 +05:30
self.yaml_errors = e.message
2016-06-02 11:05:42 +05:30
nil
rescue
2016-06-22 15:30:34 +05:30
self.yaml_errors = 'Undefined error'
2016-06-02 11:05:42 +05:30
nil
end
2015-09-25 12:07:36 +05:30
end
2015-10-24 18:46:33 +05:30
def ci_yaml_file
2016-06-02 11:05:42 +05:30
return @ci_yaml_file if defined?(@ci_yaml_file)
2017-08-17 22:00:37 +05:30
@ci_yaml_file = project.repository.gitlab_ci_yml_for(sha) rescue nil
end
def has_yaml_errors?
yaml_errors.present?
2015-10-24 18:46:33 +05:30
end
def environments
builds.where.not(environment: nil).success.pluck(:environment).uniq
end
2016-08-24 12:49:21 +05:30
# Manually set the notes for a Ci::Pipeline
# There is no ActiveRecord relation between Ci::Pipeline and notes
# as they are related to a commit sha. This method helps importing
# them using the +Gitlab::ImportExport::RelationFactory+ class.
def notes=(notes)
notes.each do |note|
note[:id] = nil
note[:commit_id] = sha
note[:noteable_id] = self['id']
note.save!
end
end
2016-06-22 15:30:34 +05:30
def notes
Note.for_commit_id(sha)
end
2016-09-13 17:45:13 +05:30
def process!
Ci::ProcessPipelineService.new(project, user).execute(self)
end
2016-11-03 12:29:30 +05:30
def update_status
2017-08-17 22:00:37 +05:30
Gitlab::OptimisticLocking.retry_lock(self) do
2016-09-29 09:46:39 +05:30
case latest_builds_status
when 'pending' then enqueue
when 'running' then run
when 'success' then succeed
when 'failed' then drop
when 'canceled' then cancel
when 'skipped' then skip
2017-08-17 22:00:37 +05:30
when 'manual' then block
2016-09-29 09:46:39 +05:30
end
2016-09-13 17:45:13 +05:30
end
end
2016-08-24 12:49:21 +05:30
def predefined_variables
[
{ key: 'CI_PIPELINE_ID', value: id.to_s, public: true }
]
end
2016-09-29 09:46:39 +05:30
def queued_duration
return unless started_at
seconds = (started_at - created_at).to_i
seconds unless seconds.zero?
end
2016-09-13 17:45:13 +05:30
def update_duration
2016-09-29 09:46:39 +05:30
return unless started_at
self.duration = Gitlab::Ci::PipelineDuration.from_pipeline(self)
2016-09-13 17:45:13 +05:30
end
def execute_hooks
data = pipeline_data
project.execute_hooks(data, :pipeline_hooks)
project.execute_services(data, :pipeline_hooks)
end
2016-09-29 09:46:39 +05:30
# Merge requests for which the current pipeline is running against
# the merge request's latest commit.
def merge_requests
2016-11-03 12:29:30 +05:30
@merge_requests ||= project.merge_requests
.where(source_branch: self.ref)
2017-08-17 22:00:37 +05:30
.select { |merge_request| merge_request.head_pipeline.try(:id) == self.id }
end
# All the merge requests for which the current pipeline runs/ran against
def all_merge_requests
@all_merge_requests ||= project.merge_requests.where(source_branch: ref)
end
def detailed_status(current_user)
Gitlab::Ci::Status::Pipeline::Factory
.new(self, current_user)
.fabricate!
2016-09-29 09:46:39 +05:30
end
2015-09-25 12:07:36 +05:30
private
2016-09-13 17:45:13 +05:30
def pipeline_data
Gitlab::DataBuilder::Pipeline.build(self)
end
def latest_builds_status
return 'failed' unless yaml_errors.blank?
statuses.latest.status || 'skipped'
2016-06-02 11:05:42 +05:30
end
2016-08-24 12:49:21 +05:30
def keep_around_commits
return unless project
project.repository.keep_around(self.sha)
project.repository.keep_around(self.before_sha)
end
2015-09-25 12:07:36 +05:30
end
end