mirror of
https://github.com/LemmyNet/lemmy.git
synced 2024-11-22 20:31:19 +00:00
Merge branch 'main' into fix-dupe-activity-sending
This commit is contained in:
commit
4aea0aea32
7 changed files with 54 additions and 86 deletions
|
@ -1,5 +1,4 @@
|
||||||
use crate::structs::{CommentView, LocalUserView};
|
use crate::structs::{CommentView, LocalUserView};
|
||||||
use chrono::{DateTime, Utc};
|
|
||||||
use diesel::{
|
use diesel::{
|
||||||
dsl::{exists, not},
|
dsl::{exists, not},
|
||||||
pg::Pg,
|
pg::Pg,
|
||||||
|
@ -63,17 +62,6 @@ fn queries<'a>() -> Queries<
|
||||||
)
|
)
|
||||||
};
|
};
|
||||||
|
|
||||||
let is_saved = |person_id| {
|
|
||||||
comment_saved::table
|
|
||||||
.filter(
|
|
||||||
comment::id
|
|
||||||
.eq(comment_saved::comment_id)
|
|
||||||
.and(comment_saved::person_id.eq(person_id)),
|
|
||||||
)
|
|
||||||
.select(comment_saved::published.nullable())
|
|
||||||
.single_value()
|
|
||||||
};
|
|
||||||
|
|
||||||
let is_community_followed = |person_id| {
|
let is_community_followed = |person_id| {
|
||||||
community_follower::table
|
community_follower::table
|
||||||
.filter(
|
.filter(
|
||||||
|
@ -147,14 +135,6 @@ fn queries<'a>() -> Queries<
|
||||||
Box::new(None::<bool>.into_sql::<sql_types::Nullable<sql_types::Bool>>())
|
Box::new(None::<bool>.into_sql::<sql_types::Nullable<sql_types::Bool>>())
|
||||||
};
|
};
|
||||||
|
|
||||||
let is_saved_selection: Box<
|
|
||||||
dyn BoxableExpression<_, Pg, SqlType = sql_types::Nullable<sql_types::Timestamptz>>,
|
|
||||||
> = if let Some(person_id) = my_person_id {
|
|
||||||
Box::new(is_saved(person_id))
|
|
||||||
} else {
|
|
||||||
Box::new(None::<DateTime<Utc>>.into_sql::<sql_types::Nullable<sql_types::Timestamptz>>())
|
|
||||||
};
|
|
||||||
|
|
||||||
let is_creator_blocked_selection: Box<dyn BoxableExpression<_, Pg, SqlType = sql_types::Bool>> =
|
let is_creator_blocked_selection: Box<dyn BoxableExpression<_, Pg, SqlType = sql_types::Bool>> =
|
||||||
if let Some(person_id) = my_person_id {
|
if let Some(person_id) = my_person_id {
|
||||||
Box::new(is_creator_blocked(person_id))
|
Box::new(is_creator_blocked(person_id))
|
||||||
|
@ -167,6 +147,13 @@ fn queries<'a>() -> Queries<
|
||||||
.inner_join(post::table)
|
.inner_join(post::table)
|
||||||
.inner_join(community::table.on(post::community_id.eq(community::id)))
|
.inner_join(community::table.on(post::community_id.eq(community::id)))
|
||||||
.inner_join(comment_aggregates::table)
|
.inner_join(comment_aggregates::table)
|
||||||
|
.left_join(
|
||||||
|
comment_saved::table.on(
|
||||||
|
comment::id
|
||||||
|
.eq(comment_saved::comment_id)
|
||||||
|
.and(comment_saved::person_id.eq(my_person_id.unwrap_or(PersonId(-1)))),
|
||||||
|
),
|
||||||
|
)
|
||||||
.select((
|
.select((
|
||||||
comment::all_columns,
|
comment::all_columns,
|
||||||
person::all_columns,
|
person::all_columns,
|
||||||
|
@ -178,7 +165,7 @@ fn queries<'a>() -> Queries<
|
||||||
creator_is_moderator,
|
creator_is_moderator,
|
||||||
creator_is_admin,
|
creator_is_admin,
|
||||||
subscribed_type_selection,
|
subscribed_type_selection,
|
||||||
is_saved_selection.is_not_null(),
|
comment_saved::person_id.nullable().is_not_null(),
|
||||||
is_creator_blocked_selection,
|
is_creator_blocked_selection,
|
||||||
score_selection,
|
score_selection,
|
||||||
))
|
))
|
||||||
|
@ -260,8 +247,8 @@ fn queries<'a>() -> Queries<
|
||||||
// If its saved only, then filter, and order by the saved time, not the comment creation time.
|
// If its saved only, then filter, and order by the saved time, not the comment creation time.
|
||||||
if options.saved_only {
|
if options.saved_only {
|
||||||
query = query
|
query = query
|
||||||
.filter(is_saved(person_id_join).is_not_null())
|
.filter(comment_saved::person_id.is_not_null())
|
||||||
.then_order_by(is_saved(person_id_join).desc());
|
.then_order_by(comment_saved::published.desc());
|
||||||
}
|
}
|
||||||
|
|
||||||
if let Some(my_id) = my_person_id {
|
if let Some(my_id) = my_person_id {
|
||||||
|
|
|
@ -1,5 +1,4 @@
|
||||||
use crate::structs::{LocalUserView, PaginationCursor, PostView};
|
use crate::structs::{LocalUserView, PaginationCursor, PostView};
|
||||||
use chrono::{DateTime, Utc};
|
|
||||||
use diesel::{
|
use diesel::{
|
||||||
debug_query,
|
debug_query,
|
||||||
dsl::{exists, not, IntervalDsl},
|
dsl::{exists, not, IntervalDsl},
|
||||||
|
@ -100,17 +99,6 @@ fn queries<'a>() -> Queries<
|
||||||
),
|
),
|
||||||
);
|
);
|
||||||
|
|
||||||
let is_saved = |person_id| {
|
|
||||||
post_saved::table
|
|
||||||
.filter(
|
|
||||||
post_aggregates::post_id
|
|
||||||
.eq(post_saved::post_id)
|
|
||||||
.and(post_saved::person_id.eq(person_id)),
|
|
||||||
)
|
|
||||||
.select(post_saved::published.nullable())
|
|
||||||
.single_value()
|
|
||||||
};
|
|
||||||
|
|
||||||
let is_read = |person_id| {
|
let is_read = |person_id| {
|
||||||
exists(
|
exists(
|
||||||
post_read::table.filter(
|
post_read::table.filter(
|
||||||
|
@ -162,14 +150,6 @@ fn queries<'a>() -> Queries<
|
||||||
Box::new(false.into_sql::<sql_types::Bool>())
|
Box::new(false.into_sql::<sql_types::Bool>())
|
||||||
};
|
};
|
||||||
|
|
||||||
let is_saved_selection: Box<
|
|
||||||
dyn BoxableExpression<_, Pg, SqlType = sql_types::Nullable<sql_types::Timestamptz>>,
|
|
||||||
> = if let Some(person_id) = my_person_id {
|
|
||||||
Box::new(is_saved(person_id))
|
|
||||||
} else {
|
|
||||||
Box::new(None::<DateTime<Utc>>.into_sql::<sql_types::Nullable<sql_types::Timestamptz>>())
|
|
||||||
};
|
|
||||||
|
|
||||||
let is_read_selection: Box<dyn BoxableExpression<_, Pg, SqlType = sql_types::Bool>> =
|
let is_read_selection: Box<dyn BoxableExpression<_, Pg, SqlType = sql_types::Bool>> =
|
||||||
if let Some(person_id) = my_person_id {
|
if let Some(person_id) = my_person_id {
|
||||||
Box::new(is_read(person_id))
|
Box::new(is_read(person_id))
|
||||||
|
@ -237,6 +217,13 @@ fn queries<'a>() -> Queries<
|
||||||
.inner_join(person::table)
|
.inner_join(person::table)
|
||||||
.inner_join(community::table)
|
.inner_join(community::table)
|
||||||
.inner_join(post::table)
|
.inner_join(post::table)
|
||||||
|
.left_join(
|
||||||
|
post_saved::table.on(
|
||||||
|
post_aggregates::post_id
|
||||||
|
.eq(post_saved::post_id)
|
||||||
|
.and(post_saved::person_id.eq(my_person_id.unwrap_or(PersonId(-1)))),
|
||||||
|
),
|
||||||
|
)
|
||||||
.select((
|
.select((
|
||||||
post::all_columns,
|
post::all_columns,
|
||||||
person::all_columns,
|
person::all_columns,
|
||||||
|
@ -247,7 +234,7 @@ fn queries<'a>() -> Queries<
|
||||||
creator_is_admin,
|
creator_is_admin,
|
||||||
post_aggregates::all_columns,
|
post_aggregates::all_columns,
|
||||||
subscribed_type_selection,
|
subscribed_type_selection,
|
||||||
is_saved_selection.is_not_null(),
|
post_saved::person_id.nullable().is_not_null(),
|
||||||
is_read_selection,
|
is_read_selection,
|
||||||
is_hidden_selection,
|
is_hidden_selection,
|
||||||
is_creator_blocked_selection,
|
is_creator_blocked_selection,
|
||||||
|
@ -426,10 +413,10 @@ fn queries<'a>() -> Queries<
|
||||||
};
|
};
|
||||||
|
|
||||||
// If its saved only, then filter, and order by the saved time, not the comment creation time.
|
// If its saved only, then filter, and order by the saved time, not the comment creation time.
|
||||||
if let (true, Some(person_id)) = (options.saved_only, my_person_id) {
|
if let (true, Some(_person_id)) = (options.saved_only, my_person_id) {
|
||||||
query = query
|
query = query
|
||||||
.filter(is_saved(person_id).is_not_null())
|
.filter(post_saved::person_id.is_not_null())
|
||||||
.then_order_by(is_saved(person_id).desc());
|
.then_order_by(post_saved::published.desc());
|
||||||
}
|
}
|
||||||
// Only hide the read posts, if the saved_only is false. Otherwise ppl with the hide_read
|
// Only hide the read posts, if the saved_only is false. Otherwise ppl with the hide_read
|
||||||
// setting wont be able to see saved posts.
|
// setting wont be able to see saved posts.
|
||||||
|
|
|
@ -1,10 +1,7 @@
|
||||||
use crate::{util::CancellableTask, worker::InstanceWorker};
|
use crate::{util::CancellableTask, worker::InstanceWorker};
|
||||||
use activitypub_federation::config::FederationConfig;
|
use activitypub_federation::config::FederationConfig;
|
||||||
use lemmy_api_common::context::LemmyContext;
|
use lemmy_api_common::context::LemmyContext;
|
||||||
use lemmy_db_schema::{
|
use lemmy_db_schema::{newtypes::InstanceId, source::instance::Instance};
|
||||||
newtypes::InstanceId,
|
|
||||||
source::{federation_queue_state::FederationQueueState, instance::Instance},
|
|
||||||
};
|
|
||||||
use lemmy_utils::error::LemmyResult;
|
use lemmy_utils::error::LemmyResult;
|
||||||
use stats::receive_print_stats;
|
use stats::receive_print_stats;
|
||||||
use std::{collections::HashMap, time::Duration};
|
use std::{collections::HashMap, time::Duration};
|
||||||
|
@ -15,6 +12,7 @@ use tokio::{
|
||||||
};
|
};
|
||||||
use tokio_util::sync::CancellationToken;
|
use tokio_util::sync::CancellationToken;
|
||||||
use tracing::info;
|
use tracing::info;
|
||||||
|
use util::FederationQueueStateWithDomain;
|
||||||
|
|
||||||
mod stats;
|
mod stats;
|
||||||
mod util;
|
mod util;
|
||||||
|
@ -38,7 +36,7 @@ pub struct SendManager {
|
||||||
opts: Opts,
|
opts: Opts,
|
||||||
workers: HashMap<InstanceId, CancellableTask>,
|
workers: HashMap<InstanceId, CancellableTask>,
|
||||||
context: FederationConfig<LemmyContext>,
|
context: FederationConfig<LemmyContext>,
|
||||||
stats_sender: UnboundedSender<(InstanceId, FederationQueueState)>,
|
stats_sender: UnboundedSender<FederationQueueStateWithDomain>,
|
||||||
exit_print: JoinHandle<()>,
|
exit_print: JoinHandle<()>,
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -197,7 +195,7 @@ mod test {
|
||||||
collections::HashSet,
|
collections::HashSet,
|
||||||
sync::{Arc, Mutex},
|
sync::{Arc, Mutex},
|
||||||
};
|
};
|
||||||
use tokio::{spawn, time::sleep};
|
use tokio::spawn;
|
||||||
|
|
||||||
struct TestData {
|
struct TestData {
|
||||||
send_manager: SendManager,
|
send_manager: SendManager,
|
||||||
|
|
|
@ -1,15 +1,11 @@
|
||||||
use crate::util::get_latest_activity_id;
|
use crate::util::{get_latest_activity_id, FederationQueueStateWithDomain};
|
||||||
use chrono::Local;
|
use chrono::Local;
|
||||||
use diesel::result::Error::NotFound;
|
|
||||||
use lemmy_api_common::federate_retry_sleep_duration;
|
use lemmy_api_common::federate_retry_sleep_duration;
|
||||||
use lemmy_db_schema::{
|
use lemmy_db_schema::{
|
||||||
newtypes::InstanceId,
|
newtypes::InstanceId,
|
||||||
source::{federation_queue_state::FederationQueueState, instance::Instance},
|
|
||||||
utils::{ActualDbPool, DbPool},
|
utils::{ActualDbPool, DbPool},
|
||||||
};
|
};
|
||||||
use lemmy_utils::{error::LemmyResult, CACHE_DURATION_FEDERATION};
|
use lemmy_utils::error::LemmyResult;
|
||||||
use moka::future::Cache;
|
|
||||||
use once_cell::sync::Lazy;
|
|
||||||
use std::{collections::HashMap, time::Duration};
|
use std::{collections::HashMap, time::Duration};
|
||||||
use tokio::{sync::mpsc::UnboundedReceiver, time::interval};
|
use tokio::{sync::mpsc::UnboundedReceiver, time::interval};
|
||||||
use tracing::{debug, info, warn};
|
use tracing::{debug, info, warn};
|
||||||
|
@ -18,7 +14,7 @@ use tracing::{debug, info, warn};
|
||||||
/// dropped)
|
/// dropped)
|
||||||
pub(crate) async fn receive_print_stats(
|
pub(crate) async fn receive_print_stats(
|
||||||
pool: ActualDbPool,
|
pool: ActualDbPool,
|
||||||
mut receiver: UnboundedReceiver<(InstanceId, FederationQueueState)>,
|
mut receiver: UnboundedReceiver<FederationQueueStateWithDomain>,
|
||||||
) {
|
) {
|
||||||
let pool = &mut DbPool::Pool(&pool);
|
let pool = &mut DbPool::Pool(&pool);
|
||||||
let mut printerval = interval(Duration::from_secs(60));
|
let mut printerval = interval(Duration::from_secs(60));
|
||||||
|
@ -28,7 +24,7 @@ pub(crate) async fn receive_print_stats(
|
||||||
ele = receiver.recv() => {
|
ele = receiver.recv() => {
|
||||||
match ele {
|
match ele {
|
||||||
// update stats for instance
|
// update stats for instance
|
||||||
Some((instance_id, ele)) => {stats.insert(instance_id, ele);},
|
Some(ele) => {stats.insert(ele.state.instance_id, ele);},
|
||||||
// receiver closed, print stats and exit
|
// receiver closed, print stats and exit
|
||||||
None => {
|
None => {
|
||||||
print_stats(pool, &stats).await;
|
print_stats(pool, &stats).await;
|
||||||
|
@ -43,7 +39,10 @@ pub(crate) async fn receive_print_stats(
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
async fn print_stats(pool: &mut DbPool<'_>, stats: &HashMap<InstanceId, FederationQueueState>) {
|
async fn print_stats(
|
||||||
|
pool: &mut DbPool<'_>,
|
||||||
|
stats: &HashMap<InstanceId, FederationQueueStateWithDomain>,
|
||||||
|
) {
|
||||||
let res = print_stats_with_error(pool, stats).await;
|
let res = print_stats_with_error(pool, stats).await;
|
||||||
if let Err(e) = res {
|
if let Err(e) = res {
|
||||||
warn!("Failed to print stats: {e}");
|
warn!("Failed to print stats: {e}");
|
||||||
|
@ -52,18 +51,8 @@ async fn print_stats(pool: &mut DbPool<'_>, stats: &HashMap<InstanceId, Federati
|
||||||
|
|
||||||
async fn print_stats_with_error(
|
async fn print_stats_with_error(
|
||||||
pool: &mut DbPool<'_>,
|
pool: &mut DbPool<'_>,
|
||||||
stats: &HashMap<InstanceId, FederationQueueState>,
|
stats: &HashMap<InstanceId, FederationQueueStateWithDomain>,
|
||||||
) -> LemmyResult<()> {
|
) -> LemmyResult<()> {
|
||||||
static INSTANCE_CACHE: Lazy<Cache<(), Vec<Instance>>> = Lazy::new(|| {
|
|
||||||
Cache::builder()
|
|
||||||
.max_capacity(1)
|
|
||||||
.time_to_live(CACHE_DURATION_FEDERATION)
|
|
||||||
.build()
|
|
||||||
});
|
|
||||||
let instances = INSTANCE_CACHE
|
|
||||||
.try_get_with((), async { Instance::read_all(pool).await })
|
|
||||||
.await?;
|
|
||||||
|
|
||||||
let last_id = get_latest_activity_id(pool).await?;
|
let last_id = get_latest_activity_id(pool).await?;
|
||||||
|
|
||||||
// it's expected that the values are a bit out of date, everything < SAVE_STATE_EVERY should be
|
// it's expected that the values are a bit out of date, everything < SAVE_STATE_EVERY should be
|
||||||
|
@ -72,12 +61,9 @@ async fn print_stats_with_error(
|
||||||
// todo: more stats (act/sec, avg http req duration)
|
// todo: more stats (act/sec, avg http req duration)
|
||||||
let mut ok_count = 0;
|
let mut ok_count = 0;
|
||||||
let mut behind_count = 0;
|
let mut behind_count = 0;
|
||||||
for (instance_id, stat) in stats {
|
for ele in stats.values() {
|
||||||
let domain = &instances
|
let stat = &ele.state;
|
||||||
.iter()
|
let domain = &ele.domain;
|
||||||
.find(|i| &i.id == instance_id)
|
|
||||||
.ok_or(NotFound)?
|
|
||||||
.domain;
|
|
||||||
let behind = last_id.0 - stat.last_successful_id.map(|e| e.0).unwrap_or(0);
|
let behind = last_id.0 - stat.last_successful_id.map(|e| e.0).unwrap_or(0);
|
||||||
if stat.fail_count > 0 {
|
if stat.fail_count > 0 {
|
||||||
info!(
|
info!(
|
||||||
|
|
|
@ -11,6 +11,7 @@ use lemmy_db_schema::{
|
||||||
source::{
|
source::{
|
||||||
activity::{ActorType, SentActivity},
|
activity::{ActorType, SentActivity},
|
||||||
community::Community,
|
community::Community,
|
||||||
|
federation_queue_state::FederationQueueState,
|
||||||
person::Person,
|
person::Person,
|
||||||
site::Site,
|
site::Site,
|
||||||
},
|
},
|
||||||
|
@ -57,7 +58,7 @@ pub struct CancellableTask {
|
||||||
|
|
||||||
impl CancellableTask {
|
impl CancellableTask {
|
||||||
/// spawn a task but with graceful shutdown
|
/// spawn a task but with graceful shutdown
|
||||||
pub fn spawn<F, R: Debug>(
|
pub fn spawn<F, R>(
|
||||||
timeout: Duration,
|
timeout: Duration,
|
||||||
task: impl Fn(CancellationToken) -> F + Send + 'static,
|
task: impl Fn(CancellationToken) -> F + Send + 'static,
|
||||||
) -> CancellableTask
|
) -> CancellableTask
|
||||||
|
@ -188,3 +189,10 @@ pub(crate) async fn get_latest_activity_id(pool: &mut DbPool<'_>) -> Result<Acti
|
||||||
.await
|
.await
|
||||||
.map_err(|e| anyhow::anyhow!("err getting id: {e:?}"))
|
.map_err(|e| anyhow::anyhow!("err getting id: {e:?}"))
|
||||||
}
|
}
|
||||||
|
|
||||||
|
/// the domain name is needed for logging, pass it to the stats printer so it doesn't need to look
|
||||||
|
/// up the domain itself
|
||||||
|
pub(crate) struct FederationQueueStateWithDomain {
|
||||||
|
pub domain: String,
|
||||||
|
pub state: FederationQueueState,
|
||||||
|
}
|
||||||
|
|
|
@ -2,6 +2,7 @@ use crate::util::{
|
||||||
get_activity_cached,
|
get_activity_cached,
|
||||||
get_actor_cached,
|
get_actor_cached,
|
||||||
get_latest_activity_id,
|
get_latest_activity_id,
|
||||||
|
FederationQueueStateWithDomain,
|
||||||
LEMMY_TEST_FAST_FEDERATION,
|
LEMMY_TEST_FAST_FEDERATION,
|
||||||
WORK_FINISHED_RECHECK_DELAY,
|
WORK_FINISHED_RECHECK_DELAY,
|
||||||
};
|
};
|
||||||
|
@ -75,7 +76,7 @@ pub(crate) struct InstanceWorker {
|
||||||
followed_communities: HashMap<CommunityId, HashSet<Url>>,
|
followed_communities: HashMap<CommunityId, HashSet<Url>>,
|
||||||
stop: CancellationToken,
|
stop: CancellationToken,
|
||||||
context: Data<LemmyContext>,
|
context: Data<LemmyContext>,
|
||||||
stats_sender: UnboundedSender<(InstanceId, FederationQueueState)>,
|
stats_sender: UnboundedSender<FederationQueueStateWithDomain>,
|
||||||
last_full_communities_fetch: DateTime<Utc>,
|
last_full_communities_fetch: DateTime<Utc>,
|
||||||
last_incremental_communities_fetch: DateTime<Utc>,
|
last_incremental_communities_fetch: DateTime<Utc>,
|
||||||
state: FederationQueueState,
|
state: FederationQueueState,
|
||||||
|
@ -87,7 +88,7 @@ impl InstanceWorker {
|
||||||
instance: Instance,
|
instance: Instance,
|
||||||
context: Data<LemmyContext>,
|
context: Data<LemmyContext>,
|
||||||
stop: CancellationToken,
|
stop: CancellationToken,
|
||||||
stats_sender: UnboundedSender<(InstanceId, FederationQueueState)>,
|
stats_sender: UnboundedSender<FederationQueueStateWithDomain>,
|
||||||
) -> Result<(), anyhow::Error> {
|
) -> Result<(), anyhow::Error> {
|
||||||
let mut pool = context.pool();
|
let mut pool = context.pool();
|
||||||
let state = FederationQueueState::load(&mut pool, instance.id).await?;
|
let state = FederationQueueState::load(&mut pool, instance.id).await?;
|
||||||
|
@ -350,9 +351,10 @@ impl InstanceWorker {
|
||||||
async fn save_and_send_state(&mut self) -> Result<()> {
|
async fn save_and_send_state(&mut self) -> Result<()> {
|
||||||
self.last_state_insert = Utc::now();
|
self.last_state_insert = Utc::now();
|
||||||
FederationQueueState::upsert(&mut self.context.pool(), &self.state).await?;
|
FederationQueueState::upsert(&mut self.context.pool(), &self.state).await?;
|
||||||
self
|
self.stats_sender.send(FederationQueueStateWithDomain {
|
||||||
.stats_sender
|
state: self.state.clone(),
|
||||||
.send((self.instance.id, self.state.clone()))?;
|
domain: self.instance.domain.clone(),
|
||||||
|
})?;
|
||||||
Ok(())
|
Ok(())
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
|
@ -53,7 +53,7 @@ services:
|
||||||
|
|
||||||
lemmy-ui:
|
lemmy-ui:
|
||||||
# use "image" to pull down an already compiled lemmy-ui. make sure to comment out "build".
|
# use "image" to pull down an already compiled lemmy-ui. make sure to comment out "build".
|
||||||
image: dessalines/lemmy-ui:0.19.3
|
image: dessalines/lemmy-ui:0.19.4-rc.3
|
||||||
# platform: linux/x86_64 # no arm64 support. uncomment platform if using m1.
|
# platform: linux/x86_64 # no arm64 support. uncomment platform if using m1.
|
||||||
# use "build" to build your local lemmy ui image for development. make sure to comment out "image".
|
# use "build" to build your local lemmy ui image for development. make sure to comment out "image".
|
||||||
# run: docker compose up --build
|
# run: docker compose up --build
|
||||||
|
|
Loading…
Reference in a new issue