WIP: refactor: repo-actor: rewrite tests using mockall
All checks were successful
ci/woodpecker/push/cron-docker-builder Pipeline was successful
ci/woodpecker/push/push-next Pipeline was successful
ci/woodpecker/push/tag-created Pipeline was successful

This commit is contained in:
Paul Campbell 2024-06-19 07:03:08 +01:00
parent 601e400300
commit 15a5867ca7
21 changed files with 1558 additions and 437 deletions

View file

@ -4,7 +4,7 @@
# Complete help on configuration: https://dystroy.org/bacon/config/
default_job = "check"
reverse = true
# reverse = true
[jobs.check]
command = ["cargo", "check", "--color", "always"]

View file

@ -42,7 +42,8 @@ async fn main() {
git_next_server::init(fs);
}
Server::Start => {
git_next_server::start(fs, net, repo).await;
let sleep_duration = std::time::Duration::from_secs(10);
git_next_server::start(fs, net, repo, sleep_duration).await;
}
},
}

View file

@ -1,7 +1,8 @@
use git_next_config::{
use config::{
BranchName, ForgeAlias, ForgeConfig, ForgeDetails, GitDir, RepoAlias, RepoConfig, RepoPath,
ServerRepoConfig,
};
use git_next_config as config;
use super::{Generation, GitRemote};
@ -57,4 +58,10 @@ impl RepoDetails {
pub fn git_remote(&self) -> GitRemote {
GitRemote::new(self.forge.hostname().clone(), self.repo_path.clone())
}
pub fn with_hostname(mut self, hostname: config::Hostname) -> Self {
let forge = self.forge;
self.forge = forge.with_hostname(hostname);
self
}
}

View file

@ -42,12 +42,20 @@ ulid = { workspace = true }
# boilerplate
derive_more = { workspace = true }
thiserror = { workspace = true }
# Actors
actix = { workspace = true }
actix-rt = { workspace = true }
tokio = { workspace = true }
[dev-dependencies]
# Testing
assert2 = { workspace = true }
rand = { workspace = true }
pretty_assertions = { workspace = true }
mockall = { workspace = true }
[lints.clippy]
nursery = { level = "warn", priority = -1 }
# pedantic = "warn"

View file

@ -1,78 +1,67 @@
//
use actix::prelude::*;
use crate::messages::MessageToken;
use git_next_config as config;
use git_next_git as git;
use derive_more::Display;
use tracing::{info, warn};
use crate::{MessageToken, ValidateRepo};
use std::time::Duration;
// advance next to the next commit towards the head of the dev branch
#[tracing::instrument(fields(next), skip_all)]
pub async fn advance_next(
next: git::Commit,
dev_commit_history: Vec<git::Commit>,
next: &git::Commit,
dev_commit_history: &[git::Commit],
repo_details: git::RepoDetails,
repo_config: config::RepoConfig,
open_repository: &dyn git::repository::OpenRepositoryLike,
addr: Addr<super::RepoActor>,
message_token: MessageToken,
) {
let next_commit = find_next_commit_on_dev(next, dev_commit_history);
let Some(commit) = next_commit else {
warn!("No commits to advance next to");
return;
};
if let Some(problem) = validate_commit_message(commit.message()) {
warn!("Can't advance next to commit '{}': {}", commit, problem);
return;
}
) -> Result<MessageToken> {
let commit =
find_next_commit_on_dev(next, dev_commit_history).ok_or_else(|| Error::NextAtDev)?;
validate_commit_message(commit.message())?;
info!("Advancing next to commit '{}'", commit);
if let Err(err) = git::push::reset(
git::push::reset(
open_repository,
&repo_details,
&repo_config.branches().next(),
&commit.into(),
&git::push::Force::No,
) {
warn!(?err, "Failed")
}
tokio::time::sleep(Duration::from_secs(10)).await;
addr.do_send(ValidateRepo { message_token })
)?;
Ok(message_token)
}
#[tracing::instrument]
fn validate_commit_message(message: &git::commit::Message) -> Option<String> {
fn validate_commit_message(message: &git::commit::Message) -> Result<()> {
let message = &message.to_string();
if message.to_ascii_lowercase().starts_with("wip") {
return Some("Is Work-In-Progress".to_string());
return Err(Error::IsWorkInProgress);
}
match git_conventional::Commit::parse(message) {
Ok(commit) => {
info!(?commit, "Pass");
None
Ok(())
}
Err(err) => {
warn!(?err, "Fail");
Some(err.kind().to_string())
Err(Error::InvalidCommitMessage {
reason: err.kind().to_string(),
})
}
}
}
pub fn find_next_commit_on_dev(
next: git::Commit,
dev_commit_history: Vec<git::Commit>,
next: &git::Commit,
dev_commit_history: &[git::Commit],
) -> Option<git::Commit> {
let mut next_commit: Option<git::Commit> = None;
for commit in dev_commit_history.into_iter() {
let mut next_commit: Option<&git::Commit> = None;
for commit in dev_commit_history.iter() {
if commit == next {
break;
};
next_commit.replace(commit);
}
next_commit
next_commit.cloned()
}
// advance main branch to the commit 'next'
@ -82,15 +71,30 @@ pub async fn advance_main(
repo_details: &git::RepoDetails,
repo_config: &config::RepoConfig,
open_repository: &dyn git::repository::OpenRepositoryLike,
) {
) -> Result<()> {
info!("Advancing main to next");
if let Err(err) = git::push::reset(
git::push::reset(
open_repository,
repo_details,
&repo_config.branches().main(),
&next.into(),
&git::push::Force::No,
) {
warn!(?err, "Failed")
};
)?;
Ok(())
}
pub type Result<T> = core::result::Result<T, Error>;
#[derive(Debug, thiserror::Error, Display)]
pub enum Error {
#[display("push: {}", 0)]
Push(#[from] git::push::Error),
#[display("no commits to advance next to")]
NextAtDev,
#[display("commit is a Work-in-progress")]
IsWorkInProgress,
#[display("commit message is not in conventional commit format: {reason}")]
InvalidCommitMessage { reason: String },
}

View file

@ -0,0 +1,53 @@
//
use actix::prelude::*;
use tracing::Instrument as _;
use crate as actor;
impl Handler<actor::messages::AdvanceMainTo> for actor::RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::AdvanceMainTo", skip_all, fields(repo = %self.repo_details, commit = ?msg))]
fn handle(
&mut self,
msg: actor::messages::AdvanceMainTo,
ctx: &mut Self::Context,
) -> Self::Result {
let Some(repo_config) = self.repo_details.repo_config.clone() else {
tracing::warn!("No config loaded");
return;
};
self.open_repository.iter().for_each(|open_repository| {
let open_repository = open_repository.duplicate();
let repo_details = self.repo_details.clone();
let repo_config = repo_config.clone();
let addr = ctx.address();
let msg = msg.clone();
let message_token = self.message_token;
async move {
match actor::branch::advance_main(
msg.unwrap(),
&repo_details,
&repo_config,
&*open_repository,
)
.await
{
Err(err) => {
tracing::warn!("advance main: {err}");
}
Ok(_) => match repo_config.source() {
git_next_config::RepoConfigSource::Repo => {
addr.do_send(actor::messages::LoadConfigFromRepo)
}
git_next_config::RepoConfigSource::Server => {
addr.do_send(actor::messages::ValidateRepo::new(message_token))
}
},
}
}
.in_current_span()
.into_actor(self)
.wait(ctx);
});
}
}

View file

@ -0,0 +1,37 @@
//
use actix::prelude::*;
use crate as actor;
use git_next_git as git;
impl Handler<actor::messages::CloneRepo> for actor::RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::CloneRepo", skip_all, fields(repo = %self.repo_details /*, gitdir = %self.repo_details.gitdir */))]
fn handle(
&mut self,
_msg: actor::messages::CloneRepo,
ctx: &mut Self::Context,
) -> Self::Result {
println!("handler clone repo start");
let gitdir = self.repo_details.gitdir.clone();
match git::repository::open(&*self.repository_factory, &self.repo_details, gitdir) {
Ok(repository) => {
println!("- open okay");
self.open_repository.replace(repository);
if self.repo_details.repo_config.is_none() {
println!("need to load config from repo");
ctx.address().do_send(actor::messages::LoadConfigFromRepo);
} else {
println!("need to validate repo");
ctx.address()
.do_send(actor::messages::ValidateRepo::new(self.message_token));
}
}
Err(err) => {
println!("err: {err:?}");
tracing::warn!("Could not open repo: {err}")
}
}
println!("handler clone repo finish");
}
}

View file

@ -0,0 +1,32 @@
//
use actix::prelude::*;
use tracing::Instrument as _;
use crate as actor;
impl Handler<actor::messages::LoadConfigFromRepo> for actor::RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::LoadConfigFromRepo", skip_all, fields(repo = %self.repo_details))]
fn handle(
&mut self,
_msg: actor::messages::LoadConfigFromRepo,
ctx: &mut Self::Context,
) -> Self::Result {
self.open_repository.iter().for_each(|open_repository| {
let open_repository = open_repository.duplicate();
let repo_details = self.repo_details.clone();
let addr = ctx.address();
async move {
match actor::load::config_from_repository(repo_details, &*open_repository).await {
Ok(repo_config) => {
addr.do_send(actor::messages::LoadedConfig::new(repo_config))
}
Err(err) => tracing::warn!(?err, "Failed to load config"),
}
}
.in_current_span()
.into_actor(self)
.wait(ctx);
});
}
}

View file

@ -0,0 +1,20 @@
//
use actix::prelude::*;
use crate as actor;
impl Handler<actor::messages::LoadedConfig> for actor::RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::LoadedConfig", skip_all, fields(repo = %self.repo_details, branches = ?msg))]
fn handle(
&mut self,
msg: actor::messages::LoadedConfig,
ctx: &mut Self::Context,
) -> Self::Result {
let repo_config = msg.unwrap();
self.repo_details.repo_config.replace(repo_config);
ctx.address()
.do_send(actor::messages::ValidateRepo::new(self.message_token));
}
}

View file

@ -0,0 +1,8 @@
pub mod advance_to_main;
pub mod clone;
pub mod load_config_from_repo;
pub mod loaded_config;
pub mod start_monitoring;
pub mod validate_repo;
pub mod webhook_message;
pub mod webhook_registered;

View file

@ -0,0 +1,88 @@
//
use actix::prelude::*;
use tracing::Instrument as _;
use crate as actor;
use git_next_git as git;
impl Handler<actor::messages::StartMonitoring> for actor::RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::StartMonitoring", skip_all,
fields(token = %self.message_token, repo = %self.repo_details, main = %msg.main(), next = %msg.next(), dev = %msg.dev()))
]
fn handle(
&mut self,
msg: actor::messages::StartMonitoring,
ctx: &mut Self::Context,
) -> Self::Result {
let Some(repo_config) = self.repo_details.repo_config.clone() else {
tracing::warn!("No config loaded");
return;
};
let next_ahead_of_main = msg.main() != msg.next();
let dev_ahead_of_next = msg.next() != msg.dev();
tracing::info!(next_ahead_of_main, dev_ahead_of_next, "StartMonitoring");
let addr = ctx.address();
let forge = self.forge.clone();
if next_ahead_of_main {
let message_token = self.message_token;
let sleep_duration = self.sleep_duration;
async move {
// get the status - pass, fail, pending (all others map to fail, e.g. error)
let status = forge.commit_status(msg.next()).await;
tracing::info!(?status, "Checking next branch");
match status {
git::forge::commit::Status::Pass => {
addr.do_send(actor::messages::AdvanceMainTo::new(msg.next().clone()));
}
git::forge::commit::Status::Pending => {
tokio::time::sleep(sleep_duration).await;
addr.do_send(actor::messages::ValidateRepo::new(message_token));
}
git::forge::commit::Status::Fail => {
tracing::warn!("Checks have failed");
}
}
}
.in_current_span()
.into_actor(self)
.wait(ctx);
} else if dev_ahead_of_next {
let message_token = self.message_token;
let sleep_duration = self.sleep_duration;
self.open_repository.iter().for_each(|open_repository| {
let open_repository = open_repository.duplicate();
let msg = msg.clone();
let repo_details = self.repo_details.clone();
let repo_config = repo_config.clone();
let addr = addr.clone();
async move {
match actor::branch::advance_next(
msg.next(),
msg.dev_commit_history(),
repo_details,
repo_config,
&*open_repository,
message_token,
)
.await
{
Ok(message_token) => {
// pause to allow any CI checks to be started
tokio::time::sleep(sleep_duration).await;
addr.do_send(actor::messages::ValidateRepo::new(message_token))
}
Err(err) => tracing::warn!("advance next: {err}"),
}
}
.in_current_span()
.into_actor(self)
.wait(ctx);
});
}
}
}

View file

@ -0,0 +1,99 @@
//
use actix::prelude::*;
use derive_more::Deref as _;
use tracing::Instrument as _;
use crate as actor;
use git_next_git as git;
impl Handler<actor::messages::ValidateRepo> for actor::RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::ValidateRepo", skip_all, fields(repo = %self.repo_details, token = %msg.deref()))]
fn handle(
&mut self,
msg: actor::messages::ValidateRepo,
ctx: &mut Self::Context,
) -> Self::Result {
println!("handler validate repo - start");
match msg.unwrap() {
message_token if self.message_token < message_token => {
tracing::info!(%message_token, "New message token");
self.message_token = message_token;
}
message_token if self.message_token > message_token => {
tracing::info!("Dropping message from previous generation");
return; // message is expired
}
_ => {
// do nothing
}
}
if self.webhook_id.is_none() {
let forge_alias = self.repo_details.forge.forge_alias();
let repo_alias = &self.repo_details.repo_alias;
let webhook_url = self.webhook.url(forge_alias, repo_alias);
let forge = self.forge.clone();
let addr = ctx.address();
async move {
if let Err(err) =
forge
.register_webhook(&webhook_url)
.await
.and_then(|registered_webhook| {
addr.try_send(actor::messages::WebhookRegistered::from(
registered_webhook,
))
.map_err(|e| {
git::forge::webhook::Error::FailedToNotifySelf(e.to_string())
})
})
{
tracing::warn!("registering webhook: {err}");
}
}
.in_current_span()
.into_actor(self)
.wait(ctx);
}
self.open_repository.iter().for_each(|open_repository| {
if let Some(repo_config) = self.repo_details.repo_config.clone() {
let repo_details = self.repo_details.clone();
let addr = ctx.address();
let message_token = self.message_token;
let sleep_duration = self.sleep_duration;
let open_repository = open_repository.duplicate();
async move {
match git::validation::positions::validate_positions(
&*open_repository,
&repo_details,
repo_config,
) {
Ok(git::validation::positions::Positions {
main,
next,
dev,
dev_commit_history,
}) => {
addr.do_send(actor::messages::StartMonitoring::new(
main,
next,
dev,
dev_commit_history,
));
}
Err(err) => {
tracing::warn!("{:?}", err);
tokio::time::sleep(sleep_duration).await;
addr.do_send(actor::messages::ValidateRepo::new(message_token));
}
}
}
.in_current_span()
.into_actor(self)
.wait(ctx);
}
});
println!("handler validate repo - finish");
}
}

View file

@ -1,13 +1,13 @@
//
use actix::prelude::*;
use crate::{RepoActor, ValidateRepo};
use crate as actor;
use git_next_config as config;
use git_next_git as git;
use tracing::{info, warn};
impl Handler<config::WebhookMessage> for RepoActor {
impl Handler<config::WebhookMessage> for actor::RepoActor {
type Result = ();
#[allow(clippy::cognitive_complexity)] // TODO: (#49) reduce complexity
@ -88,6 +88,7 @@ impl Handler<config::WebhookMessage> for RepoActor {
token = %message_token,
"New commit"
);
ctx.address().do_send(ValidateRepo { message_token });
ctx.address()
.do_send(actor::messages::ValidateRepo::new(message_token));
}
}

View file

@ -0,0 +1,17 @@
//
use actix::prelude::*;
use crate as actor;
impl Handler<actor::messages::WebhookRegistered> for actor::RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::WebhookRegistered", skip_all, fields(repo = %self.repo_details, webhook_id = %msg.webhook_id()))]
fn handle(
&mut self,
msg: actor::messages::WebhookRegistered,
_ctx: &mut Self::Context,
) -> Self::Result {
self.webhook_id.replace(msg.webhook_id().clone());
self.webhook_auth.replace(msg.webhook_auth().clone());
}
}

View file

@ -1,30 +1,58 @@
mod branch;
pub mod handlers;
mod load;
pub mod status;
pub mod webhook;
pub mod messages;
#[cfg(test)]
mod tests;
use std::time::Duration;
use actix::prelude::*;
use config::RegisteredWebhook;
use git::validation::positions::{validate_positions, Positions};
use crate as repo_actor;
use git_next_config as config;
use git_next_forge as forge;
use git_next_git as git;
use kxio::network::Network;
use tracing::{debug, info, warn, Instrument};
use tracing::{info, warn, Instrument};
#[derive(Debug, derive_more::Display)]
#[display("{}:{}:{}", generation, repo_details.forge.forge_alias(), repo_details.repo_alias)]
/// An actor that represents a Git Repository.
///
/// When this actor is started it is sent the [CloneRepo] message.
///
/// ```mermaid
/// stateDiagram-v2
/// [*] --> CloneRepo :START
///
/// CloneRepo --> LoadConfigFromRepo
/// CloneRepo --> ValidateRepo
///
/// LoadConfigFromRepo --> LoadedConfig
///
/// ValidateRepo --> WebhookRegistered
/// ValidateRepo --> StartMonitoring
/// ValidateRepo --> ValidateRepo :SLEEP 10s
///
/// LoadedConfig --> ValidateRepo
///
/// WebhookRegistered --> [*]
///
/// StartMonitoring --> AdvanceMainTo
/// StartMonitoring --> ValidateRepo :SLEEP 10s
///
/// AdvanceMainTo --> LoadConfigFromRepo
/// AdvanceMainTo --> ValidateRepo
///
/// [*] --> WebhookMessage :WEBHOOK
///
/// WebhookMessage --> ValidateRepo
/// ```
///
pub struct RepoActor {
sleep_duration: std::time::Duration,
generation: git::Generation,
message_token: MessageToken,
message_token: messages::MessageToken,
repo_details: git::RepoDetails,
webhook: config::server::Webhook,
webhook_id: Option<config::WebhookId>, // INFO: if [None] then no webhook is configured
@ -32,35 +60,37 @@ pub struct RepoActor {
last_main_commit: Option<git::Commit>,
last_next_commit: Option<git::Commit>,
last_dev_commit: Option<git::Commit>,
repository: Box<dyn git::repository::RepositoryFactory>,
repository_factory: Box<dyn git::repository::RepositoryFactory>,
open_repository: Option<Box<dyn git::repository::OpenRepositoryLike>>,
net: Network,
forge: forge::Forge,
}
impl RepoActor {
pub fn new(
details: git::RepoDetails,
repo_details: git::RepoDetails,
webhook: config::server::Webhook,
generation: git::Generation,
net: Network,
repository: Box<dyn git::repository::RepositoryFactory>,
repository_factory: Box<dyn git::repository::RepositoryFactory>,
sleep_duration: std::time::Duration,
) -> Self {
let forge = forge::Forge::new(details.clone(), net.clone());
debug!(?forge, "new");
let message_token = messages::MessageToken::default();
let forge = forge::Forge::new(repo_details.clone(), net.clone());
Self {
generation,
message_token: MessageToken::new(),
repo_details: details,
message_token,
repo_details,
webhook,
webhook_id: None,
webhook_auth: None,
last_main_commit: None,
last_next_commit: None,
last_dev_commit: None,
repository,
repository_factory,
open_repository: None,
net,
forge,
net,
sleep_duration,
}
}
}
@ -68,9 +98,11 @@ impl Actor for RepoActor {
type Context = Context<Self>;
#[tracing::instrument(name = "RepoActor::stopping", skip_all, fields(repo = %self.repo_details))]
fn stopping(&mut self, ctx: &mut Self::Context) -> Running {
eprintln!("stopping");
info!("Checking webhook");
match self.webhook_id.take() {
Some(webhook_id) => {
eprintln!("stopping - unregistering webhook");
info!(%webhook_id, "Unregistring webhook");
let forge = self.forge.clone();
async move {
@ -87,260 +119,3 @@ impl Actor for RepoActor {
}
}
}
#[derive(Message)]
#[rtype(result = "()")]
pub struct CloneRepo;
impl Handler<CloneRepo> for RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::CloneRepo", skip_all, fields(repo = %self.repo_details /*, gitdir = %self.repo_details.gitdir */))]
fn handle(&mut self, _msg: CloneRepo, ctx: &mut Self::Context) -> Self::Result {
let gitdir = self.repo_details.gitdir.clone();
match git::repository::open(&*self.repository, &self.repo_details, gitdir) {
Ok(repository) => {
self.open_repository.replace(repository);
if self.repo_details.repo_config.is_none() {
ctx.address().do_send(LoadConfigFromRepo);
} else {
ctx.address().do_send(ValidateRepo {
message_token: self.message_token,
});
}
}
Err(err) => warn!("Could not open repo: {err}"),
}
}
}
#[derive(Message)]
#[rtype(result = "()")]
pub struct LoadConfigFromRepo;
impl Handler<LoadConfigFromRepo> for RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::LoadConfigFromRepo", skip_all, fields(repo = %self.repo_details))]
fn handle(&mut self, _msg: LoadConfigFromRepo, ctx: &mut Self::Context) -> Self::Result {
let details = self.repo_details.clone();
let addr = ctx.address();
let Some(open_repository) = &self.open_repository else {
warn!("missing open repository - can't load configuration");
return;
};
let open_repository = open_repository.duplicate();
async move { repo_actor::load::load_file(details, addr, &*open_repository).await }
.in_current_span()
.into_actor(self)
.wait(ctx)
}
}
#[derive(Message)]
#[rtype(result = "()")]
struct LoadedConfig(git_next_config::RepoConfig);
impl Handler<LoadedConfig> for RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::LoadedConfig", skip_all, fields(repo = %self.repo_details, branches = %msg.0))]
fn handle(&mut self, msg: LoadedConfig, ctx: &mut Self::Context) -> Self::Result {
let repo_config = msg.0;
self.repo_details.repo_config.replace(repo_config);
ctx.address().do_send(ValidateRepo {
message_token: self.message_token,
});
}
}
#[derive(derive_more::Constructor, Message)]
#[rtype(result = "()")]
pub struct ValidateRepo {
message_token: MessageToken,
}
impl Handler<ValidateRepo> for RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::ValidateRepo", skip_all, fields(repo = %self.repo_details, token = %msg.message_token))]
fn handle(&mut self, msg: ValidateRepo, ctx: &mut Self::Context) -> Self::Result {
match msg.message_token {
message_token if self.message_token < message_token => {
info!(%message_token, "New message token");
self.message_token = msg.message_token;
}
message_token if self.message_token > message_token => {
info!("Dropping message from previous generation");
return; // message is expired
}
_ => {
// do nothing
}
}
if self.webhook_id.is_none() {
let forge_alias = self.repo_details.forge.forge_alias();
let repo_alias = &self.repo_details.repo_alias;
let webhook_url = self.webhook.url(forge_alias, repo_alias);
let forge = self.forge.clone();
let addr = ctx.address();
async move {
if let Err(err) =
forge
.register_webhook(&webhook_url)
.await
.and_then(|registered_webhook| {
addr.try_send(WebhookRegistered::from(registered_webhook))
.map_err(|e| {
git::forge::webhook::Error::FailedToNotifySelf(e.to_string())
})
})
{
warn!("registering webhook: {err}");
}
}
.in_current_span()
.into_actor(self)
.wait(ctx);
}
if let (Some(open_repository), Some(repo_config)) =
(&self.open_repository, self.repo_details.repo_config.clone())
{
let repo_details = self.repo_details.clone();
let addr = ctx.address();
let message_token = self.message_token;
let open_repository = open_repository.duplicate();
async move {
match validate_positions(&*open_repository, &repo_details, repo_config) {
Ok(Positions {
main,
next,
dev,
dev_commit_history,
}) => {
addr.do_send(StartMonitoring::new(main, next, dev, dev_commit_history));
}
Err(err) => {
warn!("{:?}", err);
tokio::time::sleep(Duration::from_secs(10)).await;
addr.do_send(ValidateRepo::new(message_token));
}
}
}
.in_current_span()
.into_actor(self)
.wait(ctx);
}
}
}
#[derive(Debug, derive_more::Constructor, Message)]
#[rtype(result = "()")]
pub struct StartMonitoring {
main: git::Commit,
next: git::Commit,
dev: git::Commit,
dev_commit_history: Vec<git::Commit>,
}
impl Handler<StartMonitoring> for RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::StartMonitoring", skip_all,
fields(token = %self.message_token, repo = %self.repo_details, main = %msg.main, next= %msg.next, dev = %msg.dev))
]
fn handle(&mut self, msg: StartMonitoring, ctx: &mut Self::Context) -> Self::Result {
let Some(repo_config) = self.repo_details.repo_config.clone() else {
warn!("No config loaded");
return;
};
let next_ahead_of_main = msg.main != msg.next;
let dev_ahead_of_next = msg.next != msg.dev;
info!(next_ahead_of_main, dev_ahead_of_next, "StartMonitoring");
let addr = ctx.address();
let forge = self.forge.clone();
if next_ahead_of_main {
status::check_next(msg.next, addr, forge, self.message_token)
.in_current_span()
.into_actor(self)
.wait(ctx);
} else if dev_ahead_of_next {
if let Some(open_repository) = &self.open_repository {
let open_repository = open_repository.duplicate();
let repo_details = self.repo_details.clone();
let message_token = self.message_token;
async move {
branch::advance_next(
msg.next,
msg.dev_commit_history,
repo_details,
repo_config,
&*open_repository,
addr,
message_token,
)
.await
}
.in_current_span()
.into_actor(self)
.wait(ctx);
}
}
}
}
#[derive(Message)]
#[rtype(result = "()")]
pub struct WebhookRegistered(config::WebhookId, config::WebhookAuth);
impl From<RegisteredWebhook> for WebhookRegistered {
fn from(value: RegisteredWebhook) -> Self {
Self(value.id().clone(), value.auth().clone())
}
}
impl Handler<WebhookRegistered> for RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::WebhookRegistered", skip_all, fields(repo = %self.repo_details, webhook_id = %msg.0))]
fn handle(&mut self, msg: WebhookRegistered, _ctx: &mut Self::Context) -> Self::Result {
self.webhook_id.replace(msg.0);
self.webhook_auth.replace(msg.1);
}
}
#[derive(Message)]
#[rtype(result = "()")]
pub struct AdvanceMainTo(git::Commit);
impl Handler<AdvanceMainTo> for RepoActor {
type Result = ();
#[tracing::instrument(name = "RepoActor::AdvanceMainTo", skip_all, fields(repo = %self.repo_details, commit = %msg.0))]
fn handle(&mut self, msg: AdvanceMainTo, ctx: &mut Self::Context) -> Self::Result {
let Some(repo_config) = self.repo_details.repo_config.clone() else {
warn!("No config loaded");
return;
};
let Some(open_repository) = &self.open_repository else {
warn!("No repository opened");
return;
};
let repo_details = self.repo_details.clone();
let addr = ctx.address();
let message_token = self.message_token;
let open_repository = open_repository.duplicate();
async move {
branch::advance_main(msg.0, &repo_details, &repo_config, &*open_repository).await;
match repo_config.source() {
git_next_config::RepoConfigSource::Repo => addr.do_send(LoadConfigFromRepo),
git_next_config::RepoConfigSource::Server => {
addr.do_send(ValidateRepo { message_token })
}
}
}
.in_current_span()
.into_actor(self)
.wait(ctx);
}
}
#[derive(Copy, Clone, Default, Debug, PartialEq, Eq, PartialOrd, Ord, derive_more::Display)]
pub struct MessageToken(u32);
impl MessageToken {
pub fn new() -> Self {
Self::default()
}
pub const fn next(&self) -> Self {
Self(self.0 + 1)
}
}

View file

@ -1,75 +1,54 @@
use std::path::PathBuf;
//
use actix::prelude::*;
use tracing::{error, info};
use derive_more::Display;
use std::path::PathBuf;
use tracing::info;
use git_next_config as config;
use git_next_git as git;
use super::{LoadedConfig, RepoActor};
/// Loads the [RepoConfig] from the `.git-next.toml` file in the repository
#[tracing::instrument(skip_all, fields(branch = %repo_details.branch))]
pub async fn load_file(
pub async fn config_from_repository(
repo_details: git::RepoDetails,
addr: Addr<RepoActor>,
open_repository: &dyn git::repository::OpenRepositoryLike,
) {
) -> Result<config::RepoConfig> {
info!("Loading .git-next.toml from repo");
let repo_config = match load(&repo_details, open_repository).await {
Ok(repo_config) => repo_config,
Err(err) => {
error!(?err, "Failed to load config");
return;
}
};
info!("Loaded .git-next.toml from repo");
addr.do_send(LoadedConfig(repo_config));
}
async fn load(
details: &git::RepoDetails,
open_repository: &dyn git::repository::OpenRepositoryLike,
) -> Result<config::RepoConfig, Error> {
let contents = open_repository.read_file(&details.branch, &PathBuf::from(".git-next.toml"))?;
let contents =
open_repository.read_file(&repo_details.branch, &PathBuf::from(".git-next.toml"))?;
let config = config::RepoConfig::parse(&contents)?;
let config = validate(config, open_repository).await?;
let branches = open_repository.remote_branches()?;
required_branch(&config.branches().main(), &branches)?;
required_branch(&config.branches().next(), &branches)?;
required_branch(&config.branches().dev(), &branches)?;
Ok(config)
}
#[derive(Debug, derive_more::From, derive_more::Display)]
fn required_branch(
branch_name: &config::BranchName,
branches: &[config::BranchName],
) -> Result<()> {
branches
.iter()
.find(|branch| *branch == branch_name)
.ok_or_else(|| Error::BranchNotFound(branch_name.clone()))?;
Ok(())
}
pub type Result<T> = core::result::Result<T, Error>;
#[derive(Debug, thiserror::Error, Display)]
pub enum Error {
File(git::file::Error),
Config(config::server::Error),
Toml(toml::de::Error),
Branch(git::push::Error),
#[display("file")]
File(#[from] git::file::Error),
#[display("config")]
Config(#[from] config::server::Error),
#[display("toml")]
Toml(#[from] toml::de::Error),
#[display("push")]
Push(#[from] git::push::Error),
#[display("branch not found: {}", 0)]
BranchNotFound(config::BranchName),
}
pub async fn validate(
config: config::RepoConfig,
open_repository: &dyn git::repository::OpenRepositoryLike,
) -> Result<config::RepoConfig, Error> {
let branches = open_repository.remote_branches()?;
if !branches
.iter()
.any(|branch| branch == &config.branches().main())
{
return Err(Error::BranchNotFound(config.branches().main()));
}
if !branches
.iter()
.any(|branch| branch == &config.branches().next())
{
return Err(Error::BranchNotFound(config.branches().next()));
}
if !branches
.iter()
.any(|branch| branch == &config.branches().dev())
{
return Err(Error::BranchNotFound(config.branches().dev()));
}
Ok(config)
}

View file

@ -0,0 +1,89 @@
//
use actix::prelude::*;
use config::newtype;
use derive_more::{Constructor, Display};
use git_next_config as config;
use git_next_git as git;
#[macro_export]
macro_rules! message {
($name:ident wraps $value:ty) => {
git_next_config::newtype!($name is a $value);
impl Message for $name {
type Result = ();
}
};
($name:ident) => {
git_next_config::newtype!($name);
impl Message for $name {
type Result = ();
}
};
($name:ident wraps $value:ty => $result:ty) => {
git_next_config::newtype!($name is a $value);
impl Message for $name {
type Result = $result;
}
};
($name:ident => $result:ty) => {
git_next_config::newtype!($name);
impl Message for $name {
type Result = $result;
}
};
}
message!(LoadConfigFromRepo);
message!(CloneRepo);
message!(LoadedConfig wraps config::RepoConfig);
message!(ValidateRepo wraps MessageToken);
#[derive(Clone, Debug, Constructor, Message)]
#[rtype(result = "()")]
pub struct StartMonitoring {
main: git::Commit,
next: git::Commit,
dev: git::Commit,
dev_commit_history: Vec<git::Commit>,
}
impl StartMonitoring {
pub const fn main(&self) -> &git::Commit {
&self.main
}
pub const fn next(&self) -> &git::Commit {
&self.next
}
pub const fn dev(&self) -> &git::Commit {
&self.dev
}
pub fn dev_commit_history(&self) -> &[git::Commit] {
&self.dev_commit_history
}
}
message!(WebhookRegistered wraps (config::WebhookId, config::WebhookAuth));
impl WebhookRegistered {
pub const fn webhook_id(&self) -> &config::WebhookId {
&self.0 .0
}
pub const fn webhook_auth(&self) -> &config::WebhookAuth {
&self.0 .1
}
}
impl From<config::RegisteredWebhook> for WebhookRegistered {
fn from(value: config::RegisteredWebhook) -> Self {
let webhook_id = value.id().clone();
let webhook_auth = value.auth().clone();
Self::from((webhook_id, webhook_auth))
}
}
message!(AdvanceMainTo wraps git::Commit);
newtype!(MessageToken is a u32, Copy, Default, Display);
impl MessageToken {
pub const fn next(&self) -> Self {
Self(self.0 + 1)
}
}

View file

@ -1,33 +0,0 @@
//
use actix::prelude::*;
use git_next_forge as forge;
use git_next_git as git;
use tracing::{info, warn};
use crate::{MessageToken, ValidateRepo};
use super::AdvanceMainTo;
pub async fn check_next(
next: git::Commit,
addr: Addr<super::RepoActor>,
forge: forge::Forge,
message_token: MessageToken,
) {
// get the status - pass, fail, pending (all others map to fail, e.g. error)
let status = forge.commit_status(&next).await;
info!(?status, "Checking next branch");
match status {
git::forge::commit::Status::Pass => {
addr.do_send(AdvanceMainTo(next));
}
git::forge::commit::Status::Pending => {
tokio::time::sleep(tokio::time::Duration::from_secs(10)).await;
addr.do_send(ValidateRepo { message_token });
}
git::forge::commit::Status::Fail => {
warn!("Checks have failed");
}
}
}

View file

@ -1,34 +1,955 @@
//
#![allow(unused_imports)] // TODO remove this
use crate as actor;
use git_next_config as config;
use git_next_forge as forge;
use git_next_git as git;
use super::*;
use assert2::let_assert;
type TestResult = Result<(), Box<dyn std::error::Error>>;
mod repo_actor {
use super::*;
use actix::prelude::*;
mod clone_repo {
use std::{
borrow::{Borrow, BorrowMut},
cell::{Cell, RefCell},
rc::Rc,
sync::{atomic::AtomicBool, Arc, Mutex},
};
use git::{
repository::{Direction, MockRepositoryFactory, RepositoryFactory},
validation::repo,
};
use crate::{
messages::{CloneRepo, WebhookRegistered},
tests::given,
};
use super::*;
#[actix::test]
async fn should_clone() -> TestResult {
let fs = given::a_filesystem();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
let git_remote = repo_details.git_remote();
open_repository
.expect_find_default_remote()
.with(mockall::predicate::eq(Direction::Push))
.return_once(|_| Some(git_remote));
let git_remote = repo_details.git_remote();
open_repository
.expect_find_default_remote()
.with(mockall::predicate::eq(Direction::Fetch))
.return_once(|_| Some(git_remote));
let net = given::a_network();
let mut repository_factory = MockRepositoryFactory::new();
let cloned = Arc::new(Mutex::new(vec![]));
let cloned_ref = cloned.clone();
repository_factory
.expect_git_clone()
.times(2)
.return_once(move |_| {
let _ = cloned_ref.lock().map(|mut l| l.push(()));
Ok(Box::new(open_repository))
});
let actor = given::a_repo_actor(repo_details, Box::new(repository_factory), net.into());
let addr = actor.start();
addr.send(CloneRepo::new()).await?;
System::current().stop();
let _ = cloned.lock().map(|o| assert_eq!(o.len(), 1));
Ok(())
}
#[actix::test]
async fn should_open() -> TestResult {
let fs = given::a_filesystem();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
let git_remote = repo_details.git_remote();
open_repository
.expect_find_default_remote()
.with(mockall::predicate::eq(Direction::Push))
.return_once(|_| Some(git_remote));
let git_remote = repo_details.git_remote();
open_repository
.expect_find_default_remote()
.with(mockall::predicate::eq(Direction::Fetch))
.return_once(|_| Some(git_remote));
let net = given::a_network();
let mut repository_factory = MockRepositoryFactory::new();
let opened = Arc::new(Mutex::new(vec![]));
let opened_ref = opened.clone();
repository_factory
.expect_open()
.times(1)
.return_once(move |_| {
let _ = opened_ref.lock().map(|mut l| l.push(()));
Ok(Box::new(open_repository))
});
fs.dir_create(&repo_details.gitdir)?;
let actor = given::a_repo_actor(repo_details, Box::new(repository_factory), net.into());
let addr = actor.start();
addr.send(CloneRepo::new()).await?;
System::current().stop();
let _ = opened.lock().map(|o| assert_eq!(o.len(), 1));
Ok(())
}
// TODO: when opening or cloning a repo, if the server config doesn't include repo config, then
// the .git-next.yaml file must be loaded from the repo
}
}
mod branch {
use super::super::branch::*;
use super::*;
mod advance_next {
use super::*;
mod when_at_dev {
// next and dev branches are the same
use super::*;
#[tokio::test]
async fn should_not_push() -> TestResult {
let next = given::a_commit();
let dev_commit_history = &[next.clone()];
let fs = given::a_filesystem();
let repo_config = given::a_repo_config();
let (open_repository, repo_details) = given::an_open_repository(&fs);
// no on_push defined - so any call to push will cause an error
let message_token = given::a_message_token();
let_assert!(
Err(err) = actor::branch::advance_next(
&next,
dev_commit_history,
repo_details,
repo_config,
&open_repository,
message_token,
)
.await
);
println!("Got: {err}");
assert!(matches!(err, actor::branch::Error::NextAtDev));
Ok(())
}
}
mod can_advance {
// dev has at least one commit ahead of next
use super::*;
mod to_wip_commit {
// commit on dev is either invalid message or a WIP
use super::*;
#[tokio::test]
async fn should_not_push() -> TestResult {
let next = given::a_commit();
let dev = given::a_commit_with_message(&git::commit::Message::new(
"wip: test: message".to_string(),
));
let dev_commit_history = &[dev.clone(), next.clone()];
let fs = given::a_filesystem();
let repo_config = given::a_repo_config();
let (open_repository, repo_details) = given::an_open_repository(&fs);
// no on_push defined - so any call to push will cause an error
let message_token = given::a_message_token();
let_assert!(
Err(err) = actor::branch::advance_next(
&next,
dev_commit_history,
repo_details,
repo_config,
&open_repository,
message_token,
)
.await
);
println!("Got: {err}");
assert!(matches!(err, actor::branch::Error::IsWorkInProgress));
Ok(())
}
}
mod to_invalid_commit {
// commit on dev is either invalid message or a WIP
use super::*;
#[tokio::test]
async fn should_not_push_and_error() -> TestResult {
let next = given::a_commit();
let dev = given::a_commit();
let dev_commit_history = &[dev.clone(), next.clone()];
let fs = given::a_filesystem();
let repo_config = given::a_repo_config();
let (open_repository, repo_details) = given::an_open_repository(&fs);
// no on_push defined - so any call to push will cause an error
let message_token = given::a_message_token();
let_assert!(
Err(err) = actor::branch::advance_next(
&next,
dev_commit_history,
repo_details,
repo_config,
&open_repository,
message_token,
)
.await
);
println!("Got: {err}");
assert!(matches!(
err,
actor::branch::Error::InvalidCommitMessage{reason}
if reason == "Missing type in the commit summary, expected `type: description`"
));
Ok(())
}
}
mod to_valid_commit {
// commit on dev is valid conventional commit message
use super::*;
mod push_is_err {
use git::repository::{OnFetch, OnPush};
// the git push command fails
use super::*;
#[tokio::test]
async fn should_error() -> TestResult {
let next = given::a_commit();
let dev = given::a_commit_with_message(&git::commit::Message::new(
"test: message".to_string(),
));
let dev_commit_history = &[dev.clone(), next.clone()];
let fs = given::a_filesystem();
let repo_config = given::a_repo_config();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
open_repository.expect_fetch().returning(|| Ok(()));
open_repository
.expect_push()
.returning(|_, _, _, _| Err(git::push::Error::Lock));
let message_token = given::a_message_token();
let_assert!(
Err(err) = actor::branch::advance_next(
&next,
dev_commit_history,
repo_details,
repo_config,
&open_repository,
message_token,
)
.await
);
println!("Got: {err:?}");
assert!(matches!(
err,
actor::branch::Error::Push(git::push::Error::Lock)
));
Ok(())
}
}
mod push_is_ok {
// the git push command succeeds
use git_next_git::repository::{OnFetch, OnPush};
// the git push command fails
use super::*;
#[tokio::test]
async fn should_ok() -> TestResult {
let next = given::a_commit();
let dev = given::a_commit_with_message(&git::commit::Message::new(
"test: message".to_string(),
));
let dev_commit_history = &[dev.clone(), next.clone()];
let fs = given::a_filesystem();
let repo_config = given::a_repo_config();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
open_repository.expect_fetch().returning(|| Ok(()));
open_repository.expect_push().returning(|_, _, _, _| Ok(()));
let message_token = given::a_message_token();
let_assert!(
Ok(mt) = actor::branch::advance_next(
&next,
dev_commit_history,
repo_details,
repo_config,
&open_repository,
message_token,
)
.await
);
println!("Got: {mt:?}");
assert_eq!(mt, message_token);
Ok(())
}
}
}
}
}
mod advance_main {
use git::repository::{OnFetch, OnPush, OpenRepositoryLike};
use super::*;
#[tokio::test]
async fn push_is_error_should_error() {
let commit = given::a_commit();
let fs = given::a_filesystem();
let repo_config = given::a_repo_config();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
open_repository.expect_fetch().returning(|| Ok(()));
open_repository
.expect_push()
.returning(|_, _, _, _| Err(git::push::Error::Lock));
let_assert!(
Err(err) = actor::branch::advance_main(
commit,
&repo_details,
&repo_config,
&open_repository
)
.await
);
assert!(matches!(
err,
actor::branch::Error::Push(git::push::Error::Lock)
));
}
#[tokio::test]
async fn push_is_ok_should_ok() {
let commit = given::a_commit();
let fs = given::a_filesystem();
let repo_config = given::a_repo_config();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
open_repository.expect_fetch().returning(|| Ok(()));
open_repository.expect_push().returning(|_, _, _, _| Ok(()));
assert!(actor::branch::advance_main(
commit,
&repo_details,
&repo_config,
&open_repository
)
.await
.is_ok());
}
}
#[actix_rt::test]
async fn test_find_next_commit_on_dev() {
let next = git::Commit::new(
git::commit::Sha::new("current-next".to_string()),
git::commit::Message::new("foo".to_string()),
);
let expected = git::Commit::new(
git::commit::Sha::new("dev-next".to_string()),
git::commit::Message::new("next-should-go-here".to_string()),
);
let next = given::a_commit();
let expected = given::a_commit();
let dev_commit_history = vec![
git::Commit::new(
git::commit::Sha::new("dev".to_string()),
git::commit::Message::new("future".to_string()),
),
given::a_commit(), // dev HEAD
expected.clone(),
next.clone(),
git::Commit::new(
git::commit::Sha::new("current-main".to_string()),
git::commit::Message::new("history".to_string()),
),
next.clone(), // next - advancing towards dev HEAD
given::a_commit(), // parent of next
];
let next_commit = find_next_commit_on_dev(next, dev_commit_history);
let next_commit = actor::branch::find_next_commit_on_dev(&next, &dev_commit_history);
assert_eq!(next_commit, Some(expected), "Found the wrong commit");
}
}
mod load {
use std::path::PathBuf;
use git_next_git::common::repo_details;
use super::*;
#[tokio::test]
async fn when_file_not_found_should_error() -> TestResult {
//given
let fs = given::a_filesystem();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
open_repository
.expect_read_file()
.returning(|_, _| Err(git::file::Error::FileNotFound));
//when
let_assert!(
Err(err) = actor::load::config_from_repository(repo_details, &open_repository).await
);
//then
println!("Got: {err:?}");
assert!(matches!(
err,
actor::load::Error::File(git::file::Error::FileNotFound)
));
Ok(())
}
#[tokio::test]
async fn when_file_format_invalid_should_error() -> TestResult {
//given
let fs = given::a_filesystem();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
let contents = given::a_name(); // not a valid file content
open_repository
.expect_read_file()
.return_once(move |_, _| Ok(contents));
//when
let_assert!(
Err(err) = actor::load::config_from_repository(repo_details, &open_repository).await
);
//then
println!("Got: {err:?}");
assert!(matches!(err, actor::load::Error::Toml(_)));
Ok(())
}
#[tokio::test]
async fn when_main_branch_is_missing_should_error() -> TestResult {
//given
let fs = given::a_filesystem();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
let branches = given::repo_branches();
let main = branches.main();
let next = branches.next();
let dev = branches.dev();
let contents = format!(
r#"
[branches]
main = "{main}"
next = "{next}"
dev = "{dev}"
"#
);
open_repository
.expect_read_file()
.return_once(|_, _| Ok(contents));
let branches = vec![next, dev];
open_repository
.expect_remote_branches()
.return_once(move || Ok(branches));
//when
let_assert!(
Err(err) = actor::load::config_from_repository(repo_details, &open_repository).await
);
//then
println!("Got: {err:?}");
assert!(matches!(err, actor::load::Error::BranchNotFound(branch) if branch == main));
Ok(())
}
#[tokio::test]
async fn when_next_branch_is_missing_should_error() -> TestResult {
//given
let fs = given::a_filesystem();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
let branches = given::repo_branches();
let main = branches.main();
let next = branches.next();
let dev = branches.dev();
let contents = format!(
r#"
[branches]
main = "{main}"
next = "{next}"
dev = "{dev}"
"#
);
open_repository
.expect_read_file()
.return_once(|_, _| Ok(contents));
let branches = vec![main, dev];
open_repository
.expect_remote_branches()
.return_once(move || Ok(branches));
//when
let_assert!(
Err(err) = actor::load::config_from_repository(repo_details, &open_repository).await
);
//then
println!("Got: {err:?}");
assert!(matches!(err, actor::load::Error::BranchNotFound(branch) if branch == next));
Ok(())
}
#[tokio::test]
async fn when_dev_branch_is_missing_should_error() -> TestResult {
//given
let fs = given::a_filesystem();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
let branches = given::repo_branches();
let main = branches.main();
let next = branches.next();
let dev = branches.dev();
let contents = format!(
r#"
[branches]
main = "{main}"
next = "{next}"
dev = "{dev}"
"#
);
open_repository
.expect_read_file()
.return_once(move |_, _| Ok(contents));
let branches = vec![main, next];
open_repository
.expect_remote_branches()
.return_once(move || Ok(branches));
//when
let_assert!(
Err(err) = actor::load::config_from_repository(repo_details, &open_repository).await
);
//then
println!("Got: {err:?}");
assert!(matches!(err, actor::load::Error::BranchNotFound(branch) if branch == dev));
Ok(())
}
#[tokio::test]
async fn when_valid_file_should_return_repo_config() -> TestResult {
//given
let fs = given::a_filesystem();
let (mut open_repository, repo_details) = given::an_open_repository(&fs);
let repo_config = given::a_repo_config();
let branches = repo_config.branches();
let main = branches.main();
let next = branches.next();
let dev = branches.dev();
let contents = format!(
r#"
[branches]
main = "{main}"
next = "{next}"
dev = "{dev}"
"#
);
open_repository
.expect_read_file()
.return_once(move |_, _| Ok(contents));
let branches = vec![main, next, dev];
open_repository
.expect_remote_branches()
.return_once(move || Ok(branches));
//when
let_assert!(
Ok(result) = actor::load::config_from_repository(repo_details, &open_repository).await
);
//then
println!("Got: {result:?}");
assert_eq!(result, repo_config);
Ok(())
}
}
pub mod given {
#![allow(dead_code)] // TODO: remove this
#![allow(unused_imports)] // TODO: remove this
use git_next_git::repository::RepositoryLike as _;
use rand::RngCore;
use std::path::PathBuf;
use super::*;
use config::{
server::{Webhook, WebhookUrl},
BranchName, ForgeAlias, ForgeConfig, ForgeType, GitDir, RepoAlias, RepoBranches,
RepoConfig, ServerRepoConfig, WebhookAuth, WebhookId,
};
use git::{repository::open::MockOpenRepositoryLike, Generation, RepoDetails};
pub fn a_webhook_auth() -> WebhookAuth {
WebhookAuth::generate()
}
pub enum Header {
Valid(WebhookAuth, config::webhook::message::Body),
Missing,
Invalid,
}
pub fn a_webhook_message_body() -> config::webhook::message::Body {
config::webhook::message::Body::new(a_name())
}
pub fn repo_branches() -> RepoBranches {
RepoBranches::new(
format!("main-{}", a_name()),
format!("next-{}", a_name()),
format!("dev-{}", a_name()),
)
}
pub fn a_forge_alias() -> ForgeAlias {
ForgeAlias::new(a_name())
}
pub fn a_repo_alias() -> RepoAlias {
RepoAlias::new(a_name())
}
pub fn a_network() -> kxio::network::MockNetwork {
kxio::network::MockNetwork::new()
}
pub fn a_webhook_url(
forge_alias: &ForgeAlias,
repo_alias: &RepoAlias,
) -> git_next_config::server::WebhookUrl {
config::server::Webhook::new(a_name()).url(forge_alias, repo_alias)
}
pub fn any_webhook_url() -> git_next_config::server::WebhookUrl {
a_webhook_url(&a_forge_alias(), &a_repo_alias())
}
pub fn a_pathbuf() -> PathBuf {
PathBuf::from(given::a_name())
}
pub fn a_name() -> String {
use rand::Rng;
use std::iter;
fn generate(len: usize) -> String {
const CHARSET: &[u8] = b"ABCDEFGHIJKLMNOPQRSTUVWXYZ0123456789";
let mut rng = rand::thread_rng();
let one_char = || CHARSET[rng.gen_range(0..CHARSET.len())] as char;
iter::repeat_with(one_char).take(len).collect()
}
generate(5)
}
pub fn a_webhook_id() -> WebhookId {
WebhookId::new(a_name())
}
pub fn a_github_webhook_id() -> i64 {
rand::thread_rng().next_u32().into()
}
pub fn a_branch_name() -> BranchName {
BranchName::new(a_name())
}
pub fn a_git_dir(fs: &kxio::fs::FileSystem) -> GitDir {
let dir_name = a_name();
let dir = fs.base().join(dir_name);
GitDir::new(dir)
}
pub fn a_forge_config() -> ForgeConfig {
ForgeConfig::new(
ForgeType::MockForge,
a_name(),
a_name(),
a_name(),
Default::default(), // no repos
)
}
pub fn a_server_repo_config() -> ServerRepoConfig {
let main = a_branch_name().to_string();
let next = a_branch_name().to_string();
let dev = a_branch_name().to_string();
ServerRepoConfig::new(
format!("{}/{}", a_name(), a_name()),
main.clone(),
None,
Some(main),
Some(next),
Some(dev),
)
}
pub fn a_repo_config() -> RepoConfig {
RepoConfig::new(given::repo_branches(), config::RepoConfigSource::Repo)
}
pub fn a_commit() -> git::Commit {
git::Commit::new(a_commit_sha(), a_commit_message())
}
pub fn a_commit_with_message(message: &git::commit::Message) -> git::Commit {
git::Commit::new(a_commit_sha(), message.to_owned())
}
pub fn a_commit_with_sha(sha: &git::commit::Sha) -> git::Commit {
git::Commit::new(sha.to_owned(), a_commit_message())
}
pub fn a_commit_with(sha: &git::commit::Sha, message: &git::commit::Message) -> git::Commit {
git::Commit::new(sha.to_owned(), message.to_owned())
}
pub fn a_commit_message() -> git::commit::Message {
git::commit::Message::new(a_name())
}
pub fn a_commit_sha() -> git::commit::Sha {
git::commit::Sha::new(a_name())
}
pub fn a_webhook_push(
sha: &git::commit::Sha,
message: &git::commit::Message,
) -> config::webhook::Push {
let branch = a_branch_name();
config::webhook::Push::new(branch, sha.to_string(), message.to_string())
}
pub fn a_filesystem() -> kxio::fs::FileSystem {
kxio::fs::temp().unwrap_or_else(|e| panic!("{}", e))
}
pub fn repo_details(fs: &kxio::fs::FileSystem) -> git::RepoDetails {
let generation = git::Generation::default();
let repo_alias = a_repo_alias();
let server_repo_config = a_server_repo_config();
let forge_alias = a_forge_alias();
let forge_config = a_forge_config();
let gitdir = a_git_dir(fs);
RepoDetails::new(
generation,
&repo_alias,
&server_repo_config,
&forge_alias,
&forge_config,
gitdir,
)
}
pub fn an_open_repository(
fs: &kxio::fs::FileSystem,
) -> (
git::repository::open::MockOpenRepositoryLike,
git::RepoDetails,
) {
let open_repository = MockOpenRepositoryLike::new();
let gitdir = given::a_git_dir(fs);
let hostname = given::a_hostname();
let repo_details = given::repo_details(fs)
.with_gitdir(gitdir)
.with_hostname(hostname);
(open_repository, repo_details)
}
pub fn a_message_token() -> messages::MessageToken {
messages::MessageToken::default()
}
pub fn a_webhook(url: &WebhookUrl) -> Webhook {
Webhook::new(url.clone().into())
}
pub fn a_repo_actor(
repo_details: git::RepoDetails,
repository_factory: Box<dyn git::repository::RepositoryFactory>,
net: kxio::network::Network,
) -> actor::RepoActor {
let forge_alias = repo_details.forge.forge_alias();
let repo_alias = &repo_details.repo_alias;
let webhook_url = given::a_webhook_url(forge_alias, repo_alias);
let webhook = given::a_webhook(&webhook_url);
let generation = Generation::default();
actor::RepoActor::new(
repo_details,
webhook,
generation,
net,
repository_factory,
std::time::Duration::from_nanos(1),
)
}
pub fn a_git_remote(repo_details: &git::RepoDetails) -> git::GitRemote {
let hostname = repo_details.forge.hostname().clone();
let repo_path = repo_details.repo_path.clone();
git::GitRemote::new(hostname, repo_path)
}
pub fn a_hostname() -> config::Hostname {
config::Hostname::new(given::a_name())
}
pub fn a_repo_path() -> config::RepoPath {
config::RepoPath::new(given::a_name())
}
}
pub mod then {
#![allow(dead_code)] // TODO: remove this
#![allow(unused_imports)] // TODO: remove this
use std::path::{Path, PathBuf};
type TestResult = Result<(), Box<dyn std::error::Error>>;
use super::*;
pub fn commit_named_file_to_branch(
file_name: &Path,
contents: &str,
fs: &kxio::fs::FileSystem,
gitdir: &config::GitDir,
branch_name: &config::BranchName,
) -> TestResult {
// git checkout ${branch_name}
git_checkout_new_branch(branch_name, gitdir)?;
// echo ${word} > file-${word}
let pathbuf = PathBuf::from(gitdir);
let file = fs.base().join(pathbuf).join(file_name);
#[allow(clippy::expect_used)]
fs.file_write(&file, contents)?;
// git add ${file}
git_add_file(gitdir, &file)?;
// git commit -m"Added ${file}"
git_commit(gitdir, &file)?;
then::push_branch(fs, gitdir, branch_name)?;
Ok(())
}
pub fn create_a_commit_on_branch(
fs: &kxio::fs::FileSystem,
gitdir: &config::GitDir,
branch_name: &config::BranchName,
) -> TestResult {
// git checkout ${branch_name}
git_checkout_new_branch(branch_name, gitdir)?;
// echo ${word} > file-${word}
let word = given::a_name();
let pathbuf = PathBuf::from(gitdir);
let file = fs.base().join(pathbuf).join(&word);
fs.file_write(&file, &word)?;
// git add ${file}
git_add_file(gitdir, &file)?;
// git commit -m"Added ${file}"
git_commit(gitdir, &file)?;
then::push_branch(fs, gitdir, branch_name)?;
Ok(())
}
fn push_branch(
fs: &kxio::fs::FileSystem,
gitdir: &config::GitDir,
branch_name: &config::BranchName,
) -> TestResult {
let gitrefs = fs
.base()
.join(gitdir.to_path_buf())
.join(".git")
.join("refs");
let local_branch = gitrefs.join("heads").join(branch_name.to_string().as_str());
let origin_heads = gitrefs.join("remotes").join("origin");
let remote_branch = origin_heads.join(branch_name.to_string().as_str());
let contents = fs.file_read_to_string(&local_branch)?;
fs.dir_create_all(&origin_heads)?;
fs.file_write(&remote_branch, &contents)?;
Ok(())
}
pub fn git_checkout_new_branch(
branch_name: &git_next_config::BranchName,
gitdir: &git_next_config::GitDir,
) -> TestResult {
exec(
format!("git checkout -b {}", branch_name),
std::process::Command::new("/usr/bin/git")
.current_dir(gitdir.to_path_buf())
.args(["checkout", "-b", branch_name.to_string().as_str()])
.output(),
)?;
Ok(())
}
pub fn git_switch(
branch_name: &git_next_config::BranchName,
gitdir: &git_next_config::GitDir,
) -> TestResult {
exec(
format!("git switch {}", branch_name),
std::process::Command::new("/usr/bin/git")
.current_dir(gitdir.to_path_buf())
.args(["switch", branch_name.to_string().as_str()])
.output(),
)
}
fn exec(label: String, output: Result<std::process::Output, std::io::Error>) -> TestResult {
println!("== {label}");
match output {
Ok(output) => {
println!(
"\nstdout:\n{}",
String::from_utf8_lossy(output.stdout.as_slice())
);
println!(
"\nstderr:\n{}",
String::from_utf8_lossy(output.stderr.as_slice())
);
println!("=============================");
Ok(())
}
Err(err) => {
println!("ERROR: {err:#?}");
Ok(Err(err)?)
}
}
}
fn git_add_file(gitdir: &git_next_config::GitDir, file: &Path) -> TestResult {
exec(
format!("git add {file:?}"),
std::process::Command::new("/usr/bin/git")
.current_dir(gitdir.to_path_buf())
.args(["add", file.display().to_string().as_str()])
.output(),
)
}
fn git_commit(gitdir: &git_next_config::GitDir, file: &Path) -> TestResult {
exec(
format!(r#"git commit -m"Added {file:?}""#),
std::process::Command::new("/usr/bin/git")
.current_dir(gitdir.to_path_buf())
.args([
"commit",
format!(r#"-m"Added {}"#, file.display().to_string().as_str()).as_str(),
])
.output(),
)
}
pub fn git_log_all(gitdir: &config::GitDir) -> TestResult {
exec(
"git log --all --oneline --decorate --graph".to_string(),
std::process::Command::new("/usr/bin/git")
.current_dir(gitdir.to_path_buf())
.args(["log", "--all", "--oneline", "--decorate", "--graph"])
.output(),
)
}
pub fn get_sha_for_branch(
fs: &kxio::fs::FileSystem,
gitdir: &git_next_config::GitDir,
branch_name: &git_next_config::BranchName,
) -> Result<git::commit::Sha, Box<dyn std::error::Error>> {
let main_ref = fs
.base()
.join(gitdir.to_path_buf())
.join(".git")
.join("refs")
.join("heads")
.join(branch_name.to_string().as_str());
let sha = fs.file_read_to_string(&main_ref)?;
Ok(git::commit::Sha::new(sha.trim().to_string()))
}
}

View file

@ -8,7 +8,8 @@ use git_next_config::{
self as config, ForgeAlias, ForgeConfig, GitDir, RepoAlias, ServerRepoConfig,
};
use git_next_git::{repository::RepositoryFactory, Generation, RepoDetails};
use git_next_repo_actor::{CloneRepo, RepoActor};
use git_next_repo_actor::messages::CloneRepo;
use git_next_repo_actor::RepoActor;
use kxio::{fs::FileSystem, network::Network};
use tracing::{error, info, warn};
@ -39,6 +40,7 @@ pub struct Server {
fs: FileSystem,
net: Network,
repository_factory: Box<dyn RepositoryFactory>,
sleep_duration: std::time::Duration,
}
impl Actor for Server {
type Context = Context<Self>;
@ -114,7 +116,12 @@ impl Handler<ServerConfig> for Server {
}
}
impl Server {
pub fn new(fs: FileSystem, net: Network, repo: Box<dyn RepositoryFactory>) -> Self {
pub fn new(
fs: FileSystem,
net: Network,
repo: Box<dyn RepositoryFactory>,
sleep_duration: std::time::Duration,
) -> Self {
let generation = Generation::default();
Self {
generation,
@ -122,6 +129,7 @@ impl Server {
fs,
net,
repository_factory: repo,
sleep_duration,
}
}
fn create_forge_data_directories(
@ -182,6 +190,7 @@ impl Server {
let net = self.net.clone();
let repository_factory = self.repository_factory.duplicate();
let generation = self.generation;
let sleep_duration = self.sleep_duration;
move |(repo_alias, server_repo_config)| {
let span = tracing::info_span!("create_actor", alias = %repo_alias, config = %server_repo_config);
let _guard = span.enter();
@ -214,6 +223,7 @@ impl Server {
generation,
net.clone(),
repository_factory.duplicate(),
sleep_duration,
);
(forge_name.clone(), repo_alias, actor)
}

View file

@ -37,11 +37,16 @@ pub fn init(fs: FileSystem) {
}
}
pub async fn start(fs: FileSystem, net: Network, repo: Box<dyn RepositoryFactory>) {
pub async fn start(
fs: FileSystem,
net: Network,
repo: Box<dyn RepositoryFactory>,
sleep_duration: std::time::Duration,
) {
init_logging();
info!("Starting Server...");
let server = Server::new(fs.clone(), net.clone(), repo).start();
let server = Server::new(fs.clone(), net.clone(), repo, sleep_duration).start();
server.do_send(FileUpdated);
info!("Starting File Watcher...");