| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653654655656657658659660661662663664665666667668669670671672673674675676677678679680681682683684685686687688689690691692693694695696697698699700701702703704705706707708709710711712713714715716717718719720721722723724725726727728729730731732733734735736737738739740741742743744745746747748749750751 |
- // Copyright 2021 The Gitea Authors. All rights reserved.
- // SPDX-License-Identifier: MIT
-
- package repository
-
- import (
- "context"
- "errors"
- "fmt"
- "strings"
-
- actions_model "code.gitea.io/gitea/models/actions"
- "code.gitea.io/gitea/models/db"
- git_model "code.gitea.io/gitea/models/git"
- issues_model "code.gitea.io/gitea/models/issues"
- access_model "code.gitea.io/gitea/models/perm/access"
- repo_model "code.gitea.io/gitea/models/repo"
- "code.gitea.io/gitea/models/unit"
- user_model "code.gitea.io/gitea/models/user"
- "code.gitea.io/gitea/modules/cache"
- "code.gitea.io/gitea/modules/git"
- "code.gitea.io/gitea/modules/gitrepo"
- "code.gitea.io/gitea/modules/graceful"
- "code.gitea.io/gitea/modules/json"
- "code.gitea.io/gitea/modules/log"
- "code.gitea.io/gitea/modules/optional"
- "code.gitea.io/gitea/modules/queue"
- repo_module "code.gitea.io/gitea/modules/repository"
- "code.gitea.io/gitea/modules/reqctx"
- "code.gitea.io/gitea/modules/timeutil"
- "code.gitea.io/gitea/modules/util"
- webhook_module "code.gitea.io/gitea/modules/webhook"
- actions_service "code.gitea.io/gitea/services/actions"
- notify_service "code.gitea.io/gitea/services/notify"
- release_service "code.gitea.io/gitea/services/release"
- files_service "code.gitea.io/gitea/services/repository/files"
-
- "xorm.io/builder"
- )
-
- // CreateNewBranch creates a new repository branch
- func CreateNewBranch(ctx context.Context, doer *user_model.User, repo *repo_model.Repository, gitRepo *git.Repository, oldBranchName, branchName string) (err error) {
- branch, err := git_model.GetBranch(ctx, repo.ID, oldBranchName)
- if err != nil {
- return err
- }
-
- return CreateNewBranchFromCommit(ctx, doer, repo, gitRepo, branch.CommitID, branchName)
- }
-
- // Branch contains the branch information
- type Branch struct {
- DBBranch *git_model.Branch
- IsProtected bool
- IsIncluded bool
- CommitsAhead int
- CommitsBehind int
- LatestPullRequest *issues_model.PullRequest
- MergeMovedOn bool
- }
-
- // LoadBranches loads branches from the repository limited by page & pageSize.
- func LoadBranches(ctx context.Context, repo *repo_model.Repository, gitRepo *git.Repository, isDeletedBranch optional.Option[bool], keyword string, page, pageSize int) (*Branch, []*Branch, int64, error) {
- defaultDBBranch, err := git_model.GetBranch(ctx, repo.ID, repo.DefaultBranch)
- if err != nil {
- return nil, nil, 0, err
- }
-
- branchOpts := git_model.FindBranchOptions{
- RepoID: repo.ID,
- IsDeletedBranch: isDeletedBranch,
- ListOptions: db.ListOptions{
- Page: page,
- PageSize: pageSize,
- },
- Keyword: keyword,
- ExcludeBranchNames: []string{repo.DefaultBranch},
- }
-
- dbBranches, totalNumOfBranches, err := db.FindAndCount[git_model.Branch](ctx, branchOpts)
- if err != nil {
- return nil, nil, 0, err
- }
-
- if err := git_model.BranchList(dbBranches).LoadDeletedBy(ctx); err != nil {
- return nil, nil, 0, err
- }
- if err := git_model.BranchList(dbBranches).LoadPusher(ctx); err != nil {
- return nil, nil, 0, err
- }
-
- rules, err := git_model.FindRepoProtectedBranchRules(ctx, repo.ID)
- if err != nil {
- return nil, nil, 0, err
- }
-
- repoIDToRepo := map[int64]*repo_model.Repository{}
- repoIDToRepo[repo.ID] = repo
-
- repoIDToGitRepo := map[int64]*git.Repository{}
- repoIDToGitRepo[repo.ID] = gitRepo
-
- branches := make([]*Branch, 0, len(dbBranches))
- for i := range dbBranches {
- branch, err := loadOneBranch(ctx, repo, dbBranches[i], &rules, repoIDToRepo, repoIDToGitRepo)
- if err != nil {
- return nil, nil, 0, fmt.Errorf("loadOneBranch: %v", err)
- }
- branches = append(branches, branch)
- }
-
- // Always add the default branch
- log.Debug("loadOneBranch: load default: '%s'", defaultDBBranch.Name)
- defaultBranch, err := loadOneBranch(ctx, repo, defaultDBBranch, &rules, repoIDToRepo, repoIDToGitRepo)
- if err != nil {
- return nil, nil, 0, fmt.Errorf("loadOneBranch: %v", err)
- }
- return defaultBranch, branches, totalNumOfBranches, nil
- }
-
- func getDivergenceCacheKey(repoID int64, branchName string) string {
- return fmt.Sprintf("%d-%s", repoID, branchName)
- }
-
- // getDivergenceFromCache gets the divergence from cache
- func getDivergenceFromCache(repoID int64, branchName string) (*git.DivergeObject, bool) {
- data, ok := cache.GetCache().Get(getDivergenceCacheKey(repoID, branchName))
- res := git.DivergeObject{
- Ahead: -1,
- Behind: -1,
- }
- if !ok || data == "" {
- return &res, false
- }
- if err := json.Unmarshal(util.UnsafeStringToBytes(data), &res); err != nil {
- log.Error("json.UnMarshal failed: %v", err)
- return &res, false
- }
- return &res, true
- }
-
- func putDivergenceFromCache(repoID int64, branchName string, divergence *git.DivergeObject) error {
- bs, err := json.Marshal(divergence)
- if err != nil {
- return err
- }
- return cache.GetCache().Put(getDivergenceCacheKey(repoID, branchName), util.UnsafeBytesToString(bs), 30*24*60*60)
- }
-
- func DelDivergenceFromCache(repoID int64, branchName string) error {
- return cache.GetCache().Delete(getDivergenceCacheKey(repoID, branchName))
- }
-
- // DelRepoDivergenceFromCache deletes all divergence caches of a repository
- func DelRepoDivergenceFromCache(ctx context.Context, repoID int64) error {
- dbBranches, err := db.Find[git_model.Branch](ctx, git_model.FindBranchOptions{
- RepoID: repoID,
- ListOptions: db.ListOptionsAll,
- })
- if err != nil {
- return err
- }
- for i := range dbBranches {
- if err := DelDivergenceFromCache(repoID, dbBranches[i].Name); err != nil {
- log.Error("DelDivergenceFromCache: %v", err)
- }
- }
- return nil
- }
-
- func loadOneBranch(ctx context.Context, repo *repo_model.Repository, dbBranch *git_model.Branch, protectedBranches *git_model.ProtectedBranchRules,
- repoIDToRepo map[int64]*repo_model.Repository,
- repoIDToGitRepo map[int64]*git.Repository,
- ) (*Branch, error) {
- log.Trace("loadOneBranch: '%s'", dbBranch.Name)
-
- branchName := dbBranch.Name
- p := protectedBranches.GetFirstMatched(branchName)
- isProtected := p != nil
-
- var divergence *git.DivergeObject
-
- // it's not default branch
- if repo.DefaultBranch != dbBranch.Name && !dbBranch.IsDeleted {
- var cached bool
- divergence, cached = getDivergenceFromCache(repo.ID, dbBranch.Name)
- if !cached {
- var err error
- divergence, err = files_service.CountDivergingCommits(ctx, repo, git.BranchPrefix+branchName)
- if err != nil {
- log.Error("CountDivergingCommits: %v", err)
- } else {
- if err = putDivergenceFromCache(repo.ID, dbBranch.Name, divergence); err != nil {
- log.Error("putDivergenceFromCache: %v", err)
- }
- }
- }
- }
-
- if divergence == nil {
- // tolerate the error that we cannot get divergence
- divergence = &git.DivergeObject{Ahead: -1, Behind: -1}
- }
-
- pr, err := issues_model.GetLatestPullRequestByHeadInfo(ctx, repo.ID, branchName)
- if err != nil {
- return nil, fmt.Errorf("GetLatestPullRequestByHeadInfo: %v", err)
- }
- headCommit := dbBranch.CommitID
-
- mergeMovedOn := false
- if pr != nil {
- pr.HeadRepo = repo
- if err := pr.LoadIssue(ctx); err != nil {
- return nil, fmt.Errorf("LoadIssue: %v", err)
- }
- if repo, ok := repoIDToRepo[pr.BaseRepoID]; ok {
- pr.BaseRepo = repo
- } else if err := pr.LoadBaseRepo(ctx); err != nil {
- return nil, fmt.Errorf("LoadBaseRepo: %v", err)
- } else {
- repoIDToRepo[pr.BaseRepoID] = pr.BaseRepo
- }
- pr.Issue.Repo = pr.BaseRepo
-
- if pr.HasMerged {
- baseGitRepo, ok := repoIDToGitRepo[pr.BaseRepoID]
- if !ok {
- baseGitRepo, err = gitrepo.OpenRepository(ctx, pr.BaseRepo)
- if err != nil {
- return nil, fmt.Errorf("OpenRepository: %v", err)
- }
- defer baseGitRepo.Close()
- repoIDToGitRepo[pr.BaseRepoID] = baseGitRepo
- }
- pullCommit, err := baseGitRepo.GetRefCommitID(pr.GetGitHeadRefName())
- if err != nil && !git.IsErrNotExist(err) {
- return nil, fmt.Errorf("GetBranchCommitID: %v", err)
- }
- if err == nil && headCommit != pullCommit {
- // the head has moved on from the merge - we shouldn't delete
- mergeMovedOn = true
- }
- }
- }
-
- isIncluded := divergence.Ahead == 0 && repo.DefaultBranch != branchName
- return &Branch{
- DBBranch: dbBranch,
- IsProtected: isProtected,
- IsIncluded: isIncluded,
- CommitsAhead: divergence.Ahead,
- CommitsBehind: divergence.Behind,
- LatestPullRequest: pr,
- MergeMovedOn: mergeMovedOn,
- }, nil
- }
-
- // checkBranchName validates branch name with existing repository branches
- func checkBranchName(ctx context.Context, repo *repo_model.Repository, name string) error {
- _, err := gitrepo.WalkReferences(ctx, repo, func(_, refName string) error {
- branchRefName := strings.TrimPrefix(refName, git.BranchPrefix)
- switch {
- case branchRefName == name:
- return git_model.ErrBranchAlreadyExists{
- BranchName: name,
- }
- // If branchRefName like a/b but we want to create a branch named a then we have a conflict
- case strings.HasPrefix(branchRefName, name+"/"):
- return git_model.ErrBranchNameConflict{
- BranchName: branchRefName,
- }
- // Conversely if branchRefName like a but we want to create a branch named a/b then we also have a conflict
- case strings.HasPrefix(name, branchRefName+"/"):
- return git_model.ErrBranchNameConflict{
- BranchName: branchRefName,
- }
- case refName == git.TagPrefix+name:
- return release_service.ErrTagAlreadyExists{
- TagName: name,
- }
- }
- return nil
- })
-
- return err
- }
-
- // SyncBranchesToDB sync the branch information in the database.
- // It will check whether the branches of the repository have never been synced before.
- // If so, it will sync all branches of the repository.
- // Otherwise, it will sync the branches that need to be updated.
- func SyncBranchesToDB(ctx context.Context, repoID, pusherID int64, branchNames, commitIDs []string, getCommit func(commitID string) (*git.Commit, error)) error {
- // Some designs that make the code look strange but are made for performance optimization purposes:
- // 1. Sync branches in a batch to reduce the number of DB queries.
- // 2. Lazy load commit information since it may be not necessary.
- // 3. Exit early if synced all branches of git repo when there's no branch in DB.
- // 4. Check the branches in DB if they are already synced.
- //
- // If the user pushes many branches at once, the Git hook will call the internal API in batches, rather than all at once.
- // See https://github.com/go-gitea/gitea/blob/cb52b17f92e2d2293f7c003649743464492bca48/cmd/hook.go#L27
- // For the first batch, it will hit optimization 3.
- // For other batches, it will hit optimization 4.
-
- if len(branchNames) != len(commitIDs) {
- return errors.New("branchNames and commitIDs length not match")
- }
-
- return db.WithTx(ctx, func(ctx context.Context) error {
- branches, err := git_model.GetBranches(ctx, repoID, branchNames, true)
- if err != nil {
- return fmt.Errorf("git_model.GetBranches: %v", err)
- }
-
- if len(branches) == 0 {
- // if user haven't visit UI but directly push to a branch after upgrading from 1.20 -> 1.21,
- // we cannot simply insert the branch but need to check we have branches or not
- hasBranch, err := db.Exist[git_model.Branch](ctx, git_model.FindBranchOptions{
- RepoID: repoID,
- IsDeletedBranch: optional.Some(false),
- }.ToConds())
- if err != nil {
- return err
- }
- if !hasBranch {
- if _, err = repo_module.SyncRepoBranches(ctx, repoID, pusherID); err != nil {
- return fmt.Errorf("repo_module.SyncRepoBranches %d failed: %v", repoID, err)
- }
- return nil
- }
- }
-
- branchMap := make(map[string]*git_model.Branch, len(branches))
- for _, branch := range branches {
- branchMap[branch.Name] = branch
- }
-
- newBranches := make([]*git_model.Branch, 0, len(branchNames))
-
- for i, branchName := range branchNames {
- commitID := commitIDs[i]
- branch, exist := branchMap[branchName]
- if exist && branch.CommitID == commitID && !branch.IsDeleted {
- continue
- }
-
- commit, err := getCommit(commitID)
- if err != nil {
- return fmt.Errorf("get commit of %s failed: %v", branchName, err)
- }
-
- if exist {
- if _, err := git_model.UpdateBranch(ctx, repoID, pusherID, branchName, commit); err != nil {
- return fmt.Errorf("git_model.UpdateBranch %d:%s failed: %v", repoID, branchName, err)
- }
- continue
- }
-
- // if database have branches but not this branch, it means this is a new branch
- newBranches = append(newBranches, &git_model.Branch{
- RepoID: repoID,
- Name: branchName,
- CommitID: commit.ID.String(),
- CommitMessage: commit.Summary(),
- PusherID: pusherID,
- CommitTime: timeutil.TimeStamp(commit.Committer.When.Unix()),
- })
- }
-
- if len(newBranches) > 0 {
- return db.Insert(ctx, newBranches)
- }
- return nil
- })
- }
-
- // CreateNewBranchFromCommit creates a new repository branch
- func CreateNewBranchFromCommit(ctx context.Context, doer *user_model.User, repo *repo_model.Repository, gitRepo *git.Repository, commitID, branchName string) (err error) {
- err = repo.MustNotBeArchived()
- if err != nil {
- return err
- }
-
- // Check if branch name can be used
- if err := checkBranchName(ctx, repo, branchName); err != nil {
- return err
- }
-
- if err := git.Push(ctx, repo.RepoPath(), git.PushOptions{
- Remote: repo.RepoPath(),
- Branch: fmt.Sprintf("%s:%s%s", commitID, git.BranchPrefix, branchName),
- Env: repo_module.PushingEnvironment(doer, repo),
- }); err != nil {
- if git.IsErrPushOutOfDate(err) || git.IsErrPushRejected(err) {
- return err
- }
- return fmt.Errorf("push: %w", err)
- }
- return nil
- }
-
- // RenameBranch rename a branch
- func RenameBranch(ctx context.Context, repo *repo_model.Repository, doer *user_model.User, gitRepo *git.Repository, from, to string) (string, error) {
- err := repo.MustNotBeArchived()
- if err != nil {
- return "", err
- }
-
- if from == to {
- return "target_exist", nil
- }
-
- if gitrepo.IsBranchExist(ctx, repo, to) {
- return "target_exist", nil
- }
-
- if !gitrepo.IsBranchExist(ctx, repo, from) {
- return "from_not_exist", nil
- }
-
- perm, err := access_model.GetUserRepoPermission(ctx, repo, doer)
- if err != nil {
- return "", err
- }
-
- isDefault := from == repo.DefaultBranch
- if isDefault && !perm.IsAdmin() {
- return "", repo_model.ErrUserDoesNotHaveAccessToRepo{
- UserID: doer.ID,
- RepoName: repo.LowerName,
- }
- }
-
- // If from == rule name, admins are allowed to modify them.
- if protectedBranch, err := git_model.GetProtectedBranchRuleByName(ctx, repo.ID, from); err != nil {
- return "", err
- } else if protectedBranch != nil && !perm.IsAdmin() {
- return "", repo_model.ErrUserDoesNotHaveAccessToRepo{
- UserID: doer.ID,
- RepoName: repo.LowerName,
- }
- }
-
- if err := git_model.RenameBranch(ctx, repo, from, to, func(ctx context.Context, isDefault bool) error {
- err2 := gitRepo.RenameBranch(from, to)
- if err2 != nil {
- return err2
- }
-
- if isDefault {
- // if default branch changed, we need to delete all schedules and cron jobs
- if err := actions_model.DeleteScheduleTaskByRepo(ctx, repo.ID); err != nil {
- log.Error("DeleteCronTaskByRepo: %v", err)
- }
- // cancel running cron jobs of this repository and delete old schedules
- if err := actions_service.CancelPreviousJobs(
- ctx,
- repo.ID,
- from,
- "",
- webhook_module.HookEventSchedule,
- ); err != nil {
- log.Error("CancelPreviousJobs: %v", err)
- }
-
- err2 = gitrepo.SetDefaultBranch(ctx, repo, to)
- if err2 != nil {
- return err2
- }
- }
-
- return nil
- }); err != nil {
- return "", err
- }
- refNameTo := git.RefNameFromBranch(to)
- refID, err := gitRepo.GetRefCommitID(refNameTo.String())
- if err != nil {
- return "", err
- }
-
- notify_service.DeleteRef(ctx, doer, repo, git.RefNameFromBranch(from))
- notify_service.CreateRef(ctx, doer, repo, refNameTo, refID)
-
- return "", nil
- }
-
- // enmuerates all branch related errors
- var (
- ErrBranchIsDefault = errors.New("branch is default")
- )
-
- func CanDeleteBranch(ctx context.Context, repo *repo_model.Repository, branchName string, doer *user_model.User) error {
- if branchName == repo.DefaultBranch {
- return ErrBranchIsDefault
- }
-
- perm, err := access_model.GetUserRepoPermission(ctx, repo, doer)
- if err != nil {
- return err
- }
- if !perm.CanWrite(unit.TypeCode) {
- return util.NewPermissionDeniedErrorf("permission denied to access repo %d unit %s", repo.ID, unit.TypeCode.LogString())
- }
-
- isProtected, err := git_model.IsBranchProtected(ctx, repo.ID, branchName)
- if err != nil {
- return err
- }
- if isProtected {
- return git_model.ErrBranchIsProtected
- }
- return nil
- }
-
- // DeleteBranch delete branch
- func DeleteBranch(ctx context.Context, doer *user_model.User, repo *repo_model.Repository, gitRepo *git.Repository, branchName string, pr *issues_model.PullRequest) error {
- err := repo.MustNotBeArchived()
- if err != nil {
- return err
- }
-
- if err := CanDeleteBranch(ctx, repo, branchName, doer); err != nil {
- return err
- }
-
- rawBranch, err := git_model.GetBranch(ctx, repo.ID, branchName)
- if err != nil && !git_model.IsErrBranchNotExist(err) {
- return fmt.Errorf("GetBranch: %vc", err)
- }
-
- // database branch record not exist or it's a deleted branch
- notExist := git_model.IsErrBranchNotExist(err) || rawBranch.IsDeleted
-
- branchCommit, err := gitRepo.GetBranchCommit(branchName)
- if err != nil && !errors.Is(err, util.ErrNotExist) {
- return err
- }
-
- if err := db.WithTx(ctx, func(ctx context.Context) error {
- if !notExist {
- if err := git_model.AddDeletedBranch(ctx, repo.ID, branchName, doer.ID); err != nil {
- return err
- }
- }
-
- if pr != nil {
- if err := issues_model.AddDeletePRBranchComment(ctx, doer, pr.BaseRepo, pr.Issue.ID, pr.HeadBranch); err != nil {
- return fmt.Errorf("DeleteBranch: %v", err)
- }
- }
- if branchCommit == nil {
- return nil
- }
-
- return gitRepo.DeleteBranch(branchName, git.DeleteBranchOptions{
- Force: true,
- })
- }); err != nil {
- return err
- }
-
- if branchCommit == nil {
- return nil
- }
-
- // Don't return error below this
-
- objectFormat := git.ObjectFormatFromName(repo.ObjectFormatName)
- if err := PushUpdate(
- &repo_module.PushUpdateOptions{
- RefFullName: git.RefNameFromBranch(branchName),
- OldCommitID: branchCommit.ID.String(),
- NewCommitID: objectFormat.EmptyObjectID().String(),
- PusherID: doer.ID,
- PusherName: doer.Name,
- RepoUserName: repo.OwnerName,
- RepoName: repo.Name,
- }); err != nil {
- log.Error("PushUpdateOptions: %v", err)
- }
-
- return nil
- }
-
- type BranchSyncOptions struct {
- RepoID int64
- }
-
- // branchSyncQueue represents a queue to handle branch sync jobs.
- var branchSyncQueue *queue.WorkerPoolQueue[*BranchSyncOptions]
-
- func handlerBranchSync(items ...*BranchSyncOptions) []*BranchSyncOptions {
- for _, opts := range items {
- _, err := repo_module.SyncRepoBranches(graceful.GetManager().ShutdownContext(), opts.RepoID, 0)
- if err != nil {
- log.Error("syncRepoBranches [%d] failed: %v", opts.RepoID, err)
- }
- }
- return nil
- }
-
- func addRepoToBranchSyncQueue(repoID int64) error {
- return branchSyncQueue.Push(&BranchSyncOptions{
- RepoID: repoID,
- })
- }
-
- func initBranchSyncQueue(ctx context.Context) error {
- branchSyncQueue = queue.CreateUniqueQueue(ctx, "branch_sync", handlerBranchSync)
- if branchSyncQueue == nil {
- return errors.New("unable to create branch_sync queue")
- }
- go graceful.GetManager().RunWithCancel(branchSyncQueue)
-
- return nil
- }
-
- func AddAllRepoBranchesToSyncQueue(ctx context.Context) error {
- if err := db.Iterate(ctx, builder.Eq{"is_empty": false}, func(ctx context.Context, repo *repo_model.Repository) error {
- return addRepoToBranchSyncQueue(repo.ID)
- }); err != nil {
- return fmt.Errorf("run sync all branches failed: %v", err)
- }
- return nil
- }
-
- func SetRepoDefaultBranch(ctx context.Context, repo *repo_model.Repository, newBranchName string) error {
- if repo.DefaultBranch == newBranchName {
- return nil
- }
-
- if !gitrepo.IsBranchExist(ctx, repo, newBranchName) {
- return git_model.ErrBranchNotExist{
- BranchName: newBranchName,
- }
- }
-
- oldDefaultBranchName := repo.DefaultBranch
- repo.DefaultBranch = newBranchName
- if err := db.WithTx(ctx, func(ctx context.Context) error {
- if err := repo_model.UpdateDefaultBranch(ctx, repo); err != nil {
- return err
- }
-
- if err := actions_model.DeleteScheduleTaskByRepo(ctx, repo.ID); err != nil {
- log.Error("DeleteCronTaskByRepo: %v", err)
- }
- // cancel running cron jobs of this repository and delete old schedules
- if err := actions_service.CancelPreviousJobs(
- ctx,
- repo.ID,
- oldDefaultBranchName,
- "",
- webhook_module.HookEventSchedule,
- ); err != nil {
- log.Error("CancelPreviousJobs: %v", err)
- }
-
- return gitrepo.SetDefaultBranch(ctx, repo, newBranchName)
- }); err != nil {
- return err
- }
-
- if !repo.IsEmpty {
- if err := AddRepoToLicenseUpdaterQueue(&LicenseUpdaterOptions{
- RepoID: repo.ID,
- }); err != nil {
- log.Error("AddRepoToLicenseUpdaterQueue: %v", err)
- }
- }
-
- // clear divergence cache
- if err := DelRepoDivergenceFromCache(ctx, repo.ID); err != nil {
- log.Error("DelRepoDivergenceFromCache: %v", err)
- }
-
- notify_service.ChangeDefaultBranch(ctx, repo)
-
- return nil
- }
-
- // BranchDivergingInfo contains the information about the divergence of a head branch to the base branch.
- type BranchDivergingInfo struct {
- // whether the base branch contains new commits which are not in the head branch
- BaseHasNewCommits bool
-
- // behind/after are number of commits that the head branch is behind/after the base branch, it's 0 if it's unable to calculate.
- // there could be a case that BaseHasNewCommits=true while the behind/after are both 0 (unable to calculate).
- HeadCommitsBehind int
- HeadCommitsAhead int
- }
-
- // GetBranchDivergingInfo returns the information about the divergence of a patch branch to the base branch.
- func GetBranchDivergingInfo(ctx reqctx.RequestContext, baseRepo *repo_model.Repository, baseBranch string, headRepo *repo_model.Repository, headBranch string) (*BranchDivergingInfo, error) {
- headGitBranch, err := git_model.GetBranch(ctx, headRepo.ID, headBranch)
- if err != nil {
- return nil, err
- }
- if headGitBranch.IsDeleted {
- return nil, git_model.ErrBranchNotExist{
- BranchName: headBranch,
- }
- }
- baseGitBranch, err := git_model.GetBranch(ctx, baseRepo.ID, baseBranch)
- if err != nil {
- return nil, err
- }
- if baseGitBranch.IsDeleted {
- return nil, git_model.ErrBranchNotExist{
- BranchName: baseBranch,
- }
- }
-
- info := &BranchDivergingInfo{}
- if headGitBranch.CommitID == baseGitBranch.CommitID {
- return info, nil
- }
-
- // if the fork repo has new commits, this call will fail because they are not in the base repo
- // exit status 128 - fatal: Invalid symmetric difference expression aaaaaaaaaaaa...bbbbbbbbbbbb
- // so at the moment, we first check the update time, then check whether the fork branch has base's head
- diff, err := git.GetDivergingCommits(ctx, baseRepo.RepoPath(), baseGitBranch.CommitID, headGitBranch.CommitID)
- if err != nil {
- info.BaseHasNewCommits = baseGitBranch.UpdatedUnix > headGitBranch.UpdatedUnix
- if headRepo.IsFork && info.BaseHasNewCommits {
- return info, nil
- }
- // if the base's update time is before the fork, check whether the base's head is in the fork
- headGitRepo, err := gitrepo.RepositoryFromRequestContextOrOpen(ctx, headRepo)
- if err != nil {
- return nil, err
- }
- headCommit, err := headGitRepo.GetCommit(headGitBranch.CommitID)
- if err != nil {
- return nil, err
- }
- baseCommitID, err := git.NewIDFromString(baseGitBranch.CommitID)
- if err != nil {
- return nil, err
- }
- hasPreviousCommit, _ := headCommit.HasPreviousCommit(baseCommitID)
- info.BaseHasNewCommits = !hasPreviousCommit
- return info, nil
- }
-
- info.HeadCommitsBehind, info.HeadCommitsAhead = diff.Behind, diff.Ahead
- info.BaseHasNewCommits = info.HeadCommitsBehind > 0
- return info, nil
- }
|