mirror of
https://github.com/LemmyNet/lemmy.git
synced 2024-11-25 13:51:19 +00:00
wip
This commit is contained in:
parent
44e9622b71
commit
0783e07ce5
4 changed files with 181 additions and 85 deletions
2
Cargo.lock
generated
2
Cargo.lock
generated
|
@ -17,7 +17,7 @@ checksum = "8f27d075294830fcab6f66e320dab524bc6d048f4a151698e153205559113772"
|
||||||
[[package]]
|
[[package]]
|
||||||
name = "activitypub_federation"
|
name = "activitypub_federation"
|
||||||
version = "0.5.2"
|
version = "0.5.2"
|
||||||
source = "git+https://github.com/LemmyNet/activitypub-federation-rust.git?branch=actix-inbox-parts#b393221b10ed6fdd879e78e6c842b9714baa0f95"
|
source = "git+https://github.com/LemmyNet/activitypub-federation-rust.git?branch=actix-inbox-parts#d848b5981bf60bfec4239d00ba5c98155de0d505"
|
||||||
dependencies = [
|
dependencies = [
|
||||||
"activitystreams-kinds",
|
"activitystreams-kinds",
|
||||||
"actix-web",
|
"actix-web",
|
||||||
|
|
|
@ -11,7 +11,7 @@ killall -s1 lemmy_server || true
|
||||||
popd
|
popd
|
||||||
|
|
||||||
pnpm i
|
pnpm i
|
||||||
pnpm api-test || true
|
pnpm api-test-post || true
|
||||||
|
|
||||||
killall -s1 lemmy_server || true
|
killall -s1 lemmy_server || true
|
||||||
killall -s1 pict-rs || true
|
killall -s1 pict-rs || true
|
||||||
|
|
|
@ -73,19 +73,16 @@ async fn start_stop_federation_workers(
|
||||||
// create new worker
|
// create new worker
|
||||||
let config = federation_config.clone();
|
let config = federation_config.clone();
|
||||||
let stats_sender = stats_sender.clone();
|
let stats_sender = stats_sender.clone();
|
||||||
let pool = pool.clone();
|
|
||||||
workers.insert(
|
workers.insert(
|
||||||
instance.id,
|
instance.id,
|
||||||
CancellableTask::spawn(WORKER_EXIT_TIMEOUT, move |stop| {
|
CancellableTask::spawn(WORKER_EXIT_TIMEOUT, move |stop| {
|
||||||
let instance = instance.clone();
|
let instance = instance.clone();
|
||||||
let req_data = config.clone().to_request_data();
|
let req_data = config.clone().to_request_data();
|
||||||
let stats_sender = stats_sender.clone();
|
let stats_sender = stats_sender.clone();
|
||||||
let pool = pool.clone();
|
|
||||||
async move {
|
async move {
|
||||||
InstanceWorker::init_and_loop(
|
InstanceWorker::init_and_loop(
|
||||||
instance,
|
instance,
|
||||||
req_data,
|
req_data,
|
||||||
&mut DbPool::Pool(&pool),
|
|
||||||
stop,
|
stop,
|
||||||
stats_sender,
|
stats_sender,
|
||||||
)
|
)
|
||||||
|
|
|
@ -30,9 +30,14 @@ use reqwest::Url;
|
||||||
use std::{
|
use std::{
|
||||||
collections::{HashMap, HashSet},
|
collections::{HashMap, HashSet},
|
||||||
ops::{Add, Deref},
|
ops::{Add, Deref},
|
||||||
|
sync::{
|
||||||
|
atomic::{AtomicU8, Ordering},
|
||||||
|
Arc,
|
||||||
|
Mutex,
|
||||||
|
},
|
||||||
time::Duration,
|
time::Duration,
|
||||||
};
|
};
|
||||||
use tokio::{sync::mpsc::UnboundedSender, time::sleep};
|
use tokio::{spawn, sync::mpsc::UnboundedSender, time::sleep};
|
||||||
use tokio_util::sync::CancellationToken;
|
use tokio_util::sync::CancellationToken;
|
||||||
|
|
||||||
/// Check whether to save state to db every n sends if there's no failures (during failures state is saved after every attempt)
|
/// Check whether to save state to db every n sends if there's no failures (during failures state is saved after every attempt)
|
||||||
|
@ -57,67 +62,128 @@ static FOLLOW_ADDITIONS_RECHECK_DELAY: Lazy<chrono::TimeDelta> = Lazy::new(|| {
|
||||||
/// This is expected to happen pretty rarely and updating it in a timely manner is not too important.
|
/// This is expected to happen pretty rarely and updating it in a timely manner is not too important.
|
||||||
static FOLLOW_REMOVALS_RECHECK_DELAY: Lazy<chrono::TimeDelta> =
|
static FOLLOW_REMOVALS_RECHECK_DELAY: Lazy<chrono::TimeDelta> =
|
||||||
Lazy::new(|| chrono::TimeDelta::try_hours(1).expect("TimeDelta out of bounds"));
|
Lazy::new(|| chrono::TimeDelta::try_hours(1).expect("TimeDelta out of bounds"));
|
||||||
|
|
||||||
|
const MAX_INFLIGHT_REQUESTS: u8 = 5;
|
||||||
|
|
||||||
|
#[derive(Clone)]
|
||||||
pub(crate) struct InstanceWorker {
|
pub(crate) struct InstanceWorker {
|
||||||
instance: Instance,
|
instance: Instance,
|
||||||
|
context: Data<LemmyContext>,
|
||||||
|
data: Arc<Mutex<InstanceWorkerData>>,
|
||||||
|
stats_sender: UnboundedSender<(String, FederationQueueState)>,
|
||||||
|
}
|
||||||
|
impl InstanceWorker {
|
||||||
|
fn is_cancelled(&self) -> bool {
|
||||||
|
self.data.lock().unwrap().stop.is_cancelled()
|
||||||
|
}
|
||||||
|
async fn cancelled(&self) {
|
||||||
|
let stop = {
|
||||||
|
let lock = self.data.lock().unwrap();
|
||||||
|
lock.stop.clone()
|
||||||
|
};
|
||||||
|
stop.cancelled().await
|
||||||
|
}
|
||||||
|
fn state(&self) -> FederationQueueState {
|
||||||
|
self.data.lock().unwrap().state.clone()
|
||||||
|
}
|
||||||
|
fn last_state_insert(&self) -> DateTime<Utc> {
|
||||||
|
self.data.lock().unwrap().last_state_insert.clone()
|
||||||
|
}
|
||||||
|
async fn site(&self, pool: &mut DbPool<'_>) -> Option<Site> {
|
||||||
|
let site_loaded = {
|
||||||
|
let lock = self.data.lock().unwrap();
|
||||||
|
lock.site_loaded
|
||||||
|
};
|
||||||
|
if !site_loaded {
|
||||||
|
let site = Site::read_from_instance_id(pool, self.instance.id)
|
||||||
|
.await
|
||||||
|
.unwrap();
|
||||||
|
let mut lock = self.data.lock().unwrap();
|
||||||
|
lock.site = site;
|
||||||
|
lock.site_loaded = true;
|
||||||
|
}
|
||||||
|
self.data.lock().unwrap().site.clone()
|
||||||
|
}
|
||||||
|
async fn update_communities(&self, pool: &mut DbPool<'_>) {
|
||||||
|
let mut communities = {
|
||||||
|
let lock = self.data.lock().unwrap();
|
||||||
|
lock.communities.clone()
|
||||||
|
};
|
||||||
|
communities
|
||||||
|
.update_communities(self.instance.id, pool)
|
||||||
|
.await
|
||||||
|
.unwrap();
|
||||||
|
self.data.lock().unwrap().communities = communities;
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
struct InstanceWorkerData {
|
||||||
// load site lazily because if an instance is first seen due to being on allowlist,
|
// load site lazily because if an instance is first seen due to being on allowlist,
|
||||||
// the corresponding row in `site` may not exist yet since that is only added once
|
// the corresponding row in `site` may not exist yet since that is only added once
|
||||||
// `fetch_instance_actor_for_object` is called.
|
// `fetch_instance_actor_for_object` is called.
|
||||||
// (this should be unlikely to be relevant outside of the federation tests)
|
// (this should be unlikely to be relevant outside of the federation tests)
|
||||||
site_loaded: bool,
|
site_loaded: bool,
|
||||||
site: Option<Site>,
|
site: Option<Site>,
|
||||||
followed_communities: HashMap<CommunityId, HashSet<Url>>,
|
|
||||||
stop: CancellationToken,
|
stop: CancellationToken,
|
||||||
context: Data<LemmyContext>,
|
|
||||||
stats_sender: UnboundedSender<(String, FederationQueueState)>,
|
|
||||||
last_full_communities_fetch: DateTime<Utc>,
|
|
||||||
last_incremental_communities_fetch: DateTime<Utc>,
|
|
||||||
state: FederationQueueState,
|
state: FederationQueueState,
|
||||||
last_state_insert: DateTime<Utc>,
|
last_state_insert: DateTime<Utc>,
|
||||||
|
communities: InstanceWorkerCommunities,
|
||||||
|
}
|
||||||
|
|
||||||
|
#[derive(Clone)]
|
||||||
|
struct InstanceWorkerCommunities {
|
||||||
|
followed_communities: HashMap<CommunityId, HashSet<Url>>,
|
||||||
|
last_full_communities_fetch: DateTime<Utc>,
|
||||||
|
last_incremental_communities_fetch: DateTime<Utc>,
|
||||||
}
|
}
|
||||||
|
|
||||||
impl InstanceWorker {
|
impl InstanceWorker {
|
||||||
pub(crate) async fn init_and_loop(
|
pub(crate) async fn init_and_loop(
|
||||||
instance: Instance,
|
instance: Instance,
|
||||||
context: Data<LemmyContext>,
|
context: Data<LemmyContext>,
|
||||||
pool: &mut DbPool<'_>, // in theory there's a ref to the pool in context, but i couldn't get that to work wrt lifetimes
|
|
||||||
stop: CancellationToken,
|
stop: CancellationToken,
|
||||||
stats_sender: UnboundedSender<(String, FederationQueueState)>,
|
stats_sender: UnboundedSender<(String, FederationQueueState)>,
|
||||||
) -> Result<(), anyhow::Error> {
|
) -> Result<(), anyhow::Error> {
|
||||||
let state = FederationQueueState::load(pool, instance.id).await?;
|
let state = FederationQueueState::load(&mut context.pool(), instance.id).await?;
|
||||||
let mut worker = InstanceWorker {
|
let mut worker = InstanceWorker {
|
||||||
instance,
|
instance,
|
||||||
site_loaded: false,
|
context: context.reset_request_count(),
|
||||||
site: None,
|
|
||||||
followed_communities: HashMap::new(),
|
|
||||||
stop,
|
|
||||||
context,
|
|
||||||
stats_sender,
|
stats_sender,
|
||||||
last_full_communities_fetch: Utc.timestamp_nanos(0),
|
data: Arc::new(Mutex::new(InstanceWorkerData {
|
||||||
last_incremental_communities_fetch: Utc.timestamp_nanos(0),
|
site_loaded: false,
|
||||||
state,
|
site: None,
|
||||||
last_state_insert: Utc.timestamp_nanos(0),
|
stop,
|
||||||
|
state,
|
||||||
|
last_state_insert: Utc.timestamp_nanos(0),
|
||||||
|
communities: InstanceWorkerCommunities {
|
||||||
|
followed_communities: HashMap::new(),
|
||||||
|
last_full_communities_fetch: Utc.timestamp_nanos(0),
|
||||||
|
last_incremental_communities_fetch: Utc.timestamp_nanos(0),
|
||||||
|
},
|
||||||
|
})),
|
||||||
};
|
};
|
||||||
worker.loop_until_stopped(pool).await
|
worker.loop_until_stopped(&context).await
|
||||||
}
|
}
|
||||||
/// loop fetch new activities from db and send them to the inboxes of the given instances
|
/// loop fetch new activities from db and send them to the inboxes of the given instances
|
||||||
/// this worker only returns if (a) there is an internal error or (b) the cancellation token is cancelled (graceful exit)
|
/// this worker only returns if (a) there is an internal error or (b) the cancellation token is cancelled (graceful exit)
|
||||||
pub(crate) async fn loop_until_stopped(
|
pub(crate) async fn loop_until_stopped(
|
||||||
&mut self,
|
&mut self,
|
||||||
pool: &mut DbPool<'_>,
|
context: &LemmyContext,
|
||||||
) -> Result<(), anyhow::Error> {
|
) -> Result<(), anyhow::Error> {
|
||||||
|
let pool = &mut context.pool();
|
||||||
let save_state_every = chrono::Duration::from_std(SAVE_STATE_EVERY_TIME).expect("not negative");
|
let save_state_every = chrono::Duration::from_std(SAVE_STATE_EVERY_TIME).expect("not negative");
|
||||||
|
|
||||||
self.update_communities(pool).await?;
|
self.update_communities(pool).await;
|
||||||
self.initial_fail_sleep().await?;
|
self.initial_fail_sleep().await?;
|
||||||
while !self.stop.is_cancelled() {
|
while !self.is_cancelled() {
|
||||||
self.loop_batch(pool).await?;
|
self.loop_batch(&context).await?;
|
||||||
if self.stop.is_cancelled() {
|
if self.is_cancelled() {
|
||||||
break;
|
break;
|
||||||
}
|
}
|
||||||
if (Utc::now() - self.last_state_insert) > save_state_every {
|
if (Utc::now() - self.last_state_insert()) > save_state_every {
|
||||||
self.save_and_send_state(pool).await?;
|
self.save_and_send_state(pool).await?;
|
||||||
}
|
}
|
||||||
self.update_communities(pool).await?;
|
self.update_communities(pool).await;
|
||||||
}
|
}
|
||||||
// final update of state in db
|
// final update of state in db
|
||||||
self.save_and_send_state(pool).await?;
|
self.save_and_send_state(pool).await?;
|
||||||
|
@ -126,74 +192,99 @@ impl InstanceWorker {
|
||||||
|
|
||||||
async fn initial_fail_sleep(&mut self) -> Result<()> {
|
async fn initial_fail_sleep(&mut self) -> Result<()> {
|
||||||
// before starting queue, sleep remaining duration if last request failed
|
// before starting queue, sleep remaining duration if last request failed
|
||||||
if self.state.fail_count > 0 {
|
if self.state().fail_count > 0 {
|
||||||
let last_retry = self
|
let last_retry = self
|
||||||
.state
|
.state()
|
||||||
.last_retry
|
.last_retry
|
||||||
.context("impossible: if fail count set last retry also set")?;
|
.context("impossible: if fail count set last retry also set")?;
|
||||||
let elapsed = (Utc::now() - last_retry).to_std()?;
|
let elapsed = (Utc::now() - last_retry).to_std()?;
|
||||||
let required = federate_retry_sleep_duration(self.state.fail_count);
|
let required = federate_retry_sleep_duration(self.state().fail_count);
|
||||||
if elapsed >= required {
|
if elapsed >= required {
|
||||||
return Ok(());
|
return Ok(());
|
||||||
}
|
}
|
||||||
let remaining = required - elapsed;
|
let remaining = required - elapsed;
|
||||||
tokio::select! {
|
tokio::select! {
|
||||||
() = sleep(remaining) => {},
|
() = sleep(remaining) => {},
|
||||||
() = self.stop.cancelled() => {}
|
() = self.cancelled() => {}
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
Ok(())
|
Ok(())
|
||||||
}
|
}
|
||||||
/// send out a batch of CHECK_SAVE_STATE_EVERY_IT activities
|
/// send out a batch of CHECK_SAVE_STATE_EVERY_IT activities
|
||||||
async fn loop_batch(&mut self, pool: &mut DbPool<'_>) -> Result<()> {
|
async fn loop_batch(&mut self, context: &LemmyContext) -> Result<()> {
|
||||||
let latest_id = get_latest_activity_id(pool).await?;
|
let latest_id = get_latest_activity_id(&mut context.pool()).await?;
|
||||||
let mut id = if let Some(id) = self.state.last_successful_id {
|
let mut id = if let Some(id) = self.state().last_successful_id {
|
||||||
id
|
id
|
||||||
} else {
|
} else {
|
||||||
// this is the initial creation (instance first seen) of the federation queue for this instance
|
// this is the initial creation (instance first seen) of the federation queue for this instance
|
||||||
// skip all past activities:
|
// skip all past activities:
|
||||||
self.state.last_successful_id = Some(latest_id);
|
self.state().last_successful_id = Some(latest_id);
|
||||||
// save here to ensure it's not read as 0 again later if no activities have happened
|
// save here to ensure it's not read as 0 again later if no activities have happened
|
||||||
self.save_and_send_state(pool).await?;
|
self.save_and_send_state(&mut context.pool()).await?;
|
||||||
latest_id
|
latest_id
|
||||||
};
|
};
|
||||||
if id >= latest_id {
|
if id >= latest_id {
|
||||||
|
if latest_id.0 != 0 {
|
||||||
|
dbg!("work done", id, latest_id);
|
||||||
|
}
|
||||||
// no more work to be done, wait before rechecking
|
// no more work to be done, wait before rechecking
|
||||||
tokio::select! {
|
tokio::select! {
|
||||||
() = sleep(*WORK_FINISHED_RECHECK_DELAY) => {},
|
() = sleep(*WORK_FINISHED_RECHECK_DELAY) => {},
|
||||||
() = self.stop.cancelled() => {}
|
() = self.cancelled() => {}
|
||||||
}
|
}
|
||||||
return Ok(());
|
return Ok(());
|
||||||
}
|
}
|
||||||
|
// TODO: somehow its not reaching here and not sending anything
|
||||||
|
dbg!("loop 1");
|
||||||
let mut processed_activities = 0;
|
let mut processed_activities = 0;
|
||||||
while id < latest_id
|
let inflight_requests = Arc::new(AtomicU8::new(0));
|
||||||
&& processed_activities < CHECK_SAVE_STATE_EVERY_IT
|
dbg!("loop 2");
|
||||||
&& !self.stop.is_cancelled()
|
while id < latest_id && processed_activities < CHECK_SAVE_STATE_EVERY_IT && !self.is_cancelled()
|
||||||
{
|
{
|
||||||
|
dbg!("loop 3");
|
||||||
|
while dbg!(inflight_requests.load(Ordering::Relaxed)) >= MAX_INFLIGHT_REQUESTS {
|
||||||
|
dbg!("sleep");
|
||||||
|
sleep(Duration::from_millis(100)).await;
|
||||||
|
}
|
||||||
id = ActivityId(id.0 + 1);
|
id = ActivityId(id.0 + 1);
|
||||||
processed_activities += 1;
|
processed_activities += 1;
|
||||||
let Some(ele) = get_activity_cached(pool, id)
|
dbg!("even before sending activity", id);
|
||||||
|
let Some(ele) = get_activity_cached(&mut context.pool(), id)
|
||||||
.await
|
.await
|
||||||
.context("failed reading activity from db")?
|
.context("failed reading activity from db")?
|
||||||
else {
|
else {
|
||||||
|
dbg!("first send, set last successful to current");
|
||||||
tracing::debug!("{}: {:?} does not exist", self.instance.domain, id);
|
tracing::debug!("{}: {:?} does not exist", self.instance.domain, id);
|
||||||
self.state.last_successful_id = Some(id);
|
self.state().last_successful_id = Some(id);
|
||||||
continue;
|
continue;
|
||||||
};
|
};
|
||||||
if let Err(e) = self.send_retry_loop(pool, &ele.0, &ele.1).await {
|
let context = context.clone();
|
||||||
tracing::warn!(
|
let inflight_requests = inflight_requests.clone();
|
||||||
"sending {} errored internally, skipping activity: {:?}",
|
let mut self_ = self.clone();
|
||||||
ele.0.ap_id,
|
dbg!(&ele);
|
||||||
e
|
dbg!("before sending activity", ele.0.id);
|
||||||
);
|
spawn(async move {
|
||||||
}
|
dbg!("during sending activity", ele.0.id);
|
||||||
if self.stop.is_cancelled() {
|
dbg!(inflight_requests.fetch_add(1, Ordering::Relaxed) + 1);
|
||||||
|
if let Err(e) = self_
|
||||||
|
.send_retry_loop(&mut context.pool(), &ele.0, &ele.1)
|
||||||
|
.await
|
||||||
|
{
|
||||||
|
tracing::warn!(
|
||||||
|
"sending {} errored internally, skipping activity: {:?}",
|
||||||
|
ele.0.ap_id,
|
||||||
|
e
|
||||||
|
);
|
||||||
|
}
|
||||||
|
inflight_requests.fetch_sub(1, Ordering::Relaxed);
|
||||||
|
// send success!
|
||||||
|
self_.state().last_successful_id = Some(id);
|
||||||
|
self_.state().last_successful_published_time = Some(ele.0.published);
|
||||||
|
self_.state().fail_count = 0;
|
||||||
|
});
|
||||||
|
if self.is_cancelled() {
|
||||||
return Ok(());
|
return Ok(());
|
||||||
}
|
}
|
||||||
// send success!
|
|
||||||
self.state.last_successful_id = Some(id);
|
|
||||||
self.state.last_successful_published_time = Some(ele.0.published);
|
|
||||||
self.state.fail_count = 0;
|
|
||||||
}
|
}
|
||||||
Ok(())
|
Ok(())
|
||||||
}
|
}
|
||||||
|
@ -212,8 +303,8 @@ impl InstanceWorker {
|
||||||
.context("failed figuring out inbox urls")?;
|
.context("failed figuring out inbox urls")?;
|
||||||
if inbox_urls.is_empty() {
|
if inbox_urls.is_empty() {
|
||||||
tracing::debug!("{}: {:?} no inboxes", self.instance.domain, activity.id);
|
tracing::debug!("{}: {:?} no inboxes", self.instance.domain, activity.id);
|
||||||
self.state.last_successful_id = Some(activity.id);
|
self.state().last_successful_id = Some(activity.id);
|
||||||
self.state.last_successful_published_time = Some(activity.published);
|
self.state().last_successful_published_time = Some(activity.published);
|
||||||
return Ok(());
|
return Ok(());
|
||||||
}
|
}
|
||||||
let Some(actor_apub_id) = &activity.actor_apub_id else {
|
let Some(actor_apub_id) = &activity.actor_apub_id else {
|
||||||
|
@ -231,19 +322,19 @@ impl InstanceWorker {
|
||||||
// usually only one due to shared inbox
|
// usually only one due to shared inbox
|
||||||
tracing::debug!("sending out {}", task);
|
tracing::debug!("sending out {}", task);
|
||||||
while let Err(e) = task.sign_and_send(&self.context).await {
|
while let Err(e) = task.sign_and_send(&self.context).await {
|
||||||
self.state.fail_count += 1;
|
self.state().fail_count += 1;
|
||||||
self.state.last_retry = Some(Utc::now());
|
self.state().last_retry = Some(Utc::now());
|
||||||
let retry_delay: Duration = federate_retry_sleep_duration(self.state.fail_count);
|
let retry_delay: Duration = federate_retry_sleep_duration(self.state().fail_count);
|
||||||
tracing::info!(
|
tracing::info!(
|
||||||
"{}: retrying {:?} attempt {} with delay {retry_delay:.2?}. ({e})",
|
"{}: retrying {:?} attempt {} with delay {retry_delay:.2?}. ({e})",
|
||||||
self.instance.domain,
|
self.instance.domain,
|
||||||
activity.id,
|
activity.id,
|
||||||
self.state.fail_count
|
self.state().fail_count
|
||||||
);
|
);
|
||||||
self.save_and_send_state(pool).await?;
|
self.save_and_send_state(pool).await?;
|
||||||
tokio::select! {
|
tokio::select! {
|
||||||
() = sleep(retry_delay) => {},
|
() = sleep(retry_delay) => {},
|
||||||
() = self.stop.cancelled() => {
|
() = self.cancelled() => {
|
||||||
// save state to db and exit
|
// save state to db and exit
|
||||||
return Ok(());
|
return Ok(());
|
||||||
}
|
}
|
||||||
|
@ -277,17 +368,20 @@ impl InstanceWorker {
|
||||||
let mut inbox_urls: HashSet<Url> = HashSet::new();
|
let mut inbox_urls: HashSet<Url> = HashSet::new();
|
||||||
|
|
||||||
if activity.send_all_instances {
|
if activity.send_all_instances {
|
||||||
if !self.site_loaded {
|
if let Some(site) = &self.site(pool).await {
|
||||||
self.site = Site::read_from_instance_id(pool, self.instance.id).await?;
|
|
||||||
self.site_loaded = true;
|
|
||||||
}
|
|
||||||
if let Some(site) = &self.site {
|
|
||||||
// Nutomic: Most non-lemmy software wont have a site row. That means it cant handle these activities. So handling it like this is fine.
|
// Nutomic: Most non-lemmy software wont have a site row. That means it cant handle these activities. So handling it like this is fine.
|
||||||
inbox_urls.insert(site.inbox_url.inner().clone());
|
inbox_urls.insert(site.inbox_url.inner().clone());
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
if let Some(t) = &activity.send_community_followers_of {
|
if let Some(t) = &activity.send_community_followers_of {
|
||||||
if let Some(urls) = self.followed_communities.get(t) {
|
if let Some(urls) = self
|
||||||
|
.data
|
||||||
|
.lock()
|
||||||
|
.unwrap()
|
||||||
|
.communities
|
||||||
|
.followed_communities
|
||||||
|
.get(t)
|
||||||
|
{
|
||||||
inbox_urls.extend(urls.iter().cloned());
|
inbox_urls.extend(urls.iter().cloned());
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -302,22 +396,35 @@ impl InstanceWorker {
|
||||||
Ok(inbox_urls)
|
Ok(inbox_urls)
|
||||||
}
|
}
|
||||||
|
|
||||||
async fn update_communities(&mut self, pool: &mut DbPool<'_>) -> Result<()> {
|
async fn save_and_send_state(&mut self, pool: &mut DbPool<'_>) -> Result<()> {
|
||||||
|
{
|
||||||
|
self.data.lock().unwrap().last_state_insert = Utc::now();
|
||||||
|
}
|
||||||
|
FederationQueueState::upsert(pool, &self.state()).await?;
|
||||||
|
self
|
||||||
|
.stats_sender
|
||||||
|
.send((self.instance.domain.clone(), self.state().clone()))?;
|
||||||
|
Ok(())
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
impl InstanceWorkerCommunities {
|
||||||
|
async fn update_communities(
|
||||||
|
&mut self,
|
||||||
|
instance_id: InstanceId,
|
||||||
|
pool: &mut DbPool<'_>,
|
||||||
|
) -> Result<()> {
|
||||||
if (Utc::now() - self.last_full_communities_fetch) > *FOLLOW_REMOVALS_RECHECK_DELAY {
|
if (Utc::now() - self.last_full_communities_fetch) > *FOLLOW_REMOVALS_RECHECK_DELAY {
|
||||||
// process removals every hour
|
// process removals every hour
|
||||||
(self.followed_communities, self.last_full_communities_fetch) = self
|
(self.followed_communities, self.last_full_communities_fetch) = self
|
||||||
.get_communities(pool, self.instance.id, Utc.timestamp_nanos(0))
|
.get_communities(pool, instance_id, Utc.timestamp_nanos(0))
|
||||||
.await?;
|
.await?;
|
||||||
self.last_incremental_communities_fetch = self.last_full_communities_fetch;
|
self.last_incremental_communities_fetch = self.last_full_communities_fetch;
|
||||||
}
|
}
|
||||||
if (Utc::now() - self.last_incremental_communities_fetch) > *FOLLOW_ADDITIONS_RECHECK_DELAY {
|
if (Utc::now() - self.last_incremental_communities_fetch) > *FOLLOW_ADDITIONS_RECHECK_DELAY {
|
||||||
// process additions every minute
|
// process additions every minute
|
||||||
let (news, time) = self
|
let (news, time) = self
|
||||||
.get_communities(
|
.get_communities(pool, instance_id, self.last_incremental_communities_fetch)
|
||||||
pool,
|
|
||||||
self.instance.id,
|
|
||||||
self.last_incremental_communities_fetch,
|
|
||||||
)
|
|
||||||
.await?;
|
.await?;
|
||||||
self.followed_communities.extend(news);
|
self.followed_communities.extend(news);
|
||||||
self.last_incremental_communities_fetch = time;
|
self.last_incremental_communities_fetch = time;
|
||||||
|
@ -345,12 +452,4 @@ impl InstanceWorker {
|
||||||
new_last_fetch,
|
new_last_fetch,
|
||||||
))
|
))
|
||||||
}
|
}
|
||||||
async fn save_and_send_state(&mut self, pool: &mut DbPool<'_>) -> Result<()> {
|
|
||||||
self.last_state_insert = Utc::now();
|
|
||||||
FederationQueueState::upsert(pool, &self.state).await?;
|
|
||||||
self
|
|
||||||
.stats_sender
|
|
||||||
.send((self.instance.domain.clone(), self.state.clone()))?;
|
|
||||||
Ok(())
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
|
|
Loading…
Reference in a new issue