fix the task cancelation

This commit is contained in:
Tamo 2024-11-19 01:47:42 +01:00
parent b5bea0cf56
commit e3ddf9ef9a
No known key found for this signature in database
GPG Key ID: 20CD8020AFA88D69
180 changed files with 524 additions and 644 deletions

View File

@ -667,7 +667,11 @@ impl IndexScheduler {
/// list is updated accordingly, with the exception of the its date fields /// list is updated accordingly, with the exception of the its date fields
/// [`finished_at`](meilisearch_types::tasks::Task::finished_at) and [`started_at`](meilisearch_types::tasks::Task::started_at). /// [`finished_at`](meilisearch_types::tasks::Task::finished_at) and [`started_at`](meilisearch_types::tasks::Task::started_at).
#[tracing::instrument(level = "trace", skip(self, batch), target = "indexing::scheduler", fields(batch=batch.to_string()))] #[tracing::instrument(level = "trace", skip(self, batch), target = "indexing::scheduler", fields(batch=batch.to_string()))]
pub(crate) fn process_batch(&self, batch: Batch) -> Result<Vec<Task>> { pub(crate) fn process_batch(
&self,
batch: Batch,
current_batch: &mut ProcessingBatch,
) -> Result<Vec<Task>> {
#[cfg(test)] #[cfg(test)]
{ {
self.maybe_fail(crate::tests::FailureLocation::InsideProcessBatch)?; self.maybe_fail(crate::tests::FailureLocation::InsideProcessBatch)?;
@ -685,47 +689,25 @@ impl IndexScheduler {
unreachable!() unreachable!()
}; };
let mut wtxn = self.env.write_txn()?; let rtxn = self.env.read_txn()?;
let canceled_tasks_content_uuids = self.cancel_matched_tasks( let mut canceled_tasks =
&mut wtxn, self.cancel_matched_tasks(&rtxn, task.uid, current_batch, matched_tasks)?;
task.uid,
matched_tasks,
previous_started_at,
&previous_processing_tasks,
)?;
task.status = Status::Succeeded; task.status = Status::Succeeded;
match &mut task.details { match &mut task.details {
Some(Details::TaskCancelation { Some(Details::TaskCancelation {
matched_tasks: _, matched_tasks: _,
canceled_tasks, canceled_tasks: canceled_tasks_details,
original_filter: _, original_filter: _,
}) => { }) => {
*canceled_tasks = Some(canceled_tasks_content_uuids.len() as u64); *canceled_tasks_details = Some(canceled_tasks.len() as u64);
} }
_ => unreachable!(), _ => unreachable!(),
} }
// We must only remove the content files if the transaction is successfully committed canceled_tasks.push(task);
// and if errors occurs when we are deleting files we must do our best to delete
// everything. We do not return the encountered errors when deleting the content
// files as it is not a breaking operation and we can safely continue our job.
match wtxn.commit() {
Ok(()) => {
for content_uuid in canceled_tasks_content_uuids {
if let Err(error) = self.delete_update_file(content_uuid) {
tracing::error!(
file_content_uuid = %content_uuid,
%error,
"Failed deleting content file"
)
}
}
}
Err(e) => return Err(e.into()),
}
Ok(vec![task]) Ok(canceled_tasks)
} }
Batch::TaskDeletions(mut tasks) => { Batch::TaskDeletions(mut tasks) => {
// 1. Retrieve the tasks that matched the query at enqueue-time. // 1. Retrieve the tasks that matched the query at enqueue-time.
@ -1090,7 +1072,10 @@ impl IndexScheduler {
} }
self.index_mapper.create_index(wtxn, &index_uid, None)?; self.index_mapper.create_index(wtxn, &index_uid, None)?;
self.process_batch(Batch::IndexUpdate { index_uid, primary_key, task }) self.process_batch(
Batch::IndexUpdate { index_uid, primary_key, task },
current_batch,
)
} }
Batch::IndexUpdate { index_uid, primary_key, mut task } => { Batch::IndexUpdate { index_uid, primary_key, mut task } => {
let rtxn = self.env.read_txn()?; let rtxn = self.env.read_txn()?;
@ -1744,41 +1729,31 @@ impl IndexScheduler {
/// Cancel each given task from all the databases (if it is cancelable). /// Cancel each given task from all the databases (if it is cancelable).
/// ///
/// Returns the content files that the transaction owner must delete if the commit is successful. /// Returns the list of tasks that matched the filter and must be written in the database.
fn cancel_matched_tasks( fn cancel_matched_tasks(
&self, &self,
wtxn: &mut RwTxn, rtxn: &RoTxn,
cancel_task_id: TaskId, cancel_task_id: TaskId,
current_batch: &mut ProcessingBatch,
matched_tasks: &RoaringBitmap, matched_tasks: &RoaringBitmap,
previous_started_at: OffsetDateTime, ) -> Result<Vec<Task>> {
previous_processing_tasks: &RoaringBitmap,
) -> Result<Vec<Uuid>> {
let now = OffsetDateTime::now_utc();
// 1. Remove from this list the tasks that we are not allowed to cancel // 1. Remove from this list the tasks that we are not allowed to cancel
// Notice that only the _enqueued_ ones are cancelable and we should // Notice that only the _enqueued_ ones are cancelable and we should
// have already aborted the indexation of the _processing_ ones // have already aborted the indexation of the _processing_ ones
let cancelable_tasks = self.get_status(wtxn, Status::Enqueued)?; let cancelable_tasks = self.get_status(rtxn, Status::Enqueued)?;
let tasks_to_cancel = cancelable_tasks & matched_tasks; let tasks_to_cancel = cancelable_tasks & matched_tasks;
// 2. We now have a list of tasks to cancel, cancel them // 2. We now have a list of tasks to cancel, cancel them
let mut content_files_to_delete = Vec::new(); let mut tasks = self.get_existing_tasks(rtxn, tasks_to_cancel.iter())?;
for mut task in self.get_existing_tasks(wtxn, tasks_to_cancel.iter())? {
if let Some(uuid) = task.content_uuid() { for task in tasks.iter_mut() {
content_files_to_delete.push(uuid);
}
if previous_processing_tasks.contains(task.uid) {
task.started_at = Some(previous_started_at);
}
task.status = Status::Canceled; task.status = Status::Canceled;
task.canceled_by = Some(cancel_task_id); task.canceled_by = Some(cancel_task_id);
task.finished_at = Some(now); task.details = task.details.as_ref().map(|d| d.to_failed());
task.details = task.details.map(|d| d.to_failed()); current_batch.processing(Some(task));
self.update_task(wtxn, &task)?;
} }
self.canceled_by.put(wtxn, &cancel_task_id, &tasks_to_cancel)?;
Ok(content_files_to_delete) Ok(tasks)
} }
} }

View File

@ -40,7 +40,6 @@ pub fn snapshot_index_scheduler(scheduler: &IndexScheduler) -> String {
batch_status, batch_status,
batch_kind, batch_kind,
batch_index_tasks, batch_index_tasks,
batch_canceled_by,
batch_enqueued_at, batch_enqueued_at,
batch_started_at, batch_started_at,
batch_finished_at, batch_finished_at,
@ -131,10 +130,6 @@ pub fn snapshot_index_scheduler(scheduler: &IndexScheduler) -> String {
snap.push_str(&snapshot_index_tasks(&rtxn, *batch_index_tasks)); snap.push_str(&snapshot_index_tasks(&rtxn, *batch_index_tasks));
snap.push_str("----------------------------------------------------------------------\n"); snap.push_str("----------------------------------------------------------------------\n");
snap.push_str("### Batches Canceled By:\n");
snap.push_str(&snapshot_canceled_by(&rtxn, *batch_canceled_by));
snap.push_str("\n----------------------------------------------------------------------\n");
snap.push_str("### Batches Enqueued At:\n"); snap.push_str("### Batches Enqueued At:\n");
snap.push_str(&snapshot_date_db(&rtxn, *batch_enqueued_at)); snap.push_str(&snapshot_date_db(&rtxn, *batch_enqueued_at));
snap.push_str("----------------------------------------------------------------------\n"); snap.push_str("----------------------------------------------------------------------\n");

View File

@ -225,7 +225,6 @@ mod db_name {
pub const BATCH_STATUS: &str = "batch-status"; pub const BATCH_STATUS: &str = "batch-status";
pub const BATCH_KIND: &str = "batch-kind"; pub const BATCH_KIND: &str = "batch-kind";
pub const BATCH_INDEX_TASKS: &str = "batch-index-tasks"; pub const BATCH_INDEX_TASKS: &str = "batch-index-tasks";
pub const BATCH_CANCELED_BY: &str = "batch-canceled_by";
pub const BATCH_ENQUEUED_AT: &str = "batch-enqueued-at"; pub const BATCH_ENQUEUED_AT: &str = "batch-enqueued-at";
pub const BATCH_STARTED_AT: &str = "batch-started-at"; pub const BATCH_STARTED_AT: &str = "batch-started-at";
pub const BATCH_FINISHED_AT: &str = "batch-finished-at"; pub const BATCH_FINISHED_AT: &str = "batch-finished-at";
@ -341,8 +340,6 @@ pub struct IndexScheduler {
pub(crate) batch_kind: Database<SerdeBincode<Kind>, RoaringBitmapCodec>, pub(crate) batch_kind: Database<SerdeBincode<Kind>, RoaringBitmapCodec>,
/// Store the batches associated to an index. /// Store the batches associated to an index.
pub(crate) batch_index_tasks: Database<Str, RoaringBitmapCodec>, pub(crate) batch_index_tasks: Database<Str, RoaringBitmapCodec>,
/// Store the batches containing a task canceled by a task uid
pub(crate) batch_canceled_by: Database<BEU32, RoaringBitmapCodec>,
/// Store the batches containing tasks which were enqueued at a specific date /// Store the batches containing tasks which were enqueued at a specific date
pub(crate) batch_enqueued_at: Database<BEI128, CboRoaringBitmapCodec>, pub(crate) batch_enqueued_at: Database<BEI128, CboRoaringBitmapCodec>,
/// Store the batches containing finished tasks started at a specific date /// Store the batches containing finished tasks started at a specific date
@ -434,7 +431,6 @@ impl IndexScheduler {
batch_status: self.batch_status, batch_status: self.batch_status,
batch_kind: self.batch_kind, batch_kind: self.batch_kind,
batch_index_tasks: self.batch_index_tasks, batch_index_tasks: self.batch_index_tasks,
batch_canceled_by: self.batch_canceled_by,
batch_enqueued_at: self.batch_enqueued_at, batch_enqueued_at: self.batch_enqueued_at,
batch_started_at: self.batch_started_at, batch_started_at: self.batch_started_at,
batch_finished_at: self.batch_finished_at, batch_finished_at: self.batch_finished_at,
@ -498,7 +494,7 @@ impl IndexScheduler {
let env = unsafe { let env = unsafe {
heed::EnvOpenOptions::new() heed::EnvOpenOptions::new()
.max_dbs(20) .max_dbs(19)
.map_size(budget.task_db_size) .map_size(budget.task_db_size)
.open(options.tasks_path) .open(options.tasks_path)
}?; }?;
@ -524,7 +520,6 @@ impl IndexScheduler {
let batch_status = env.create_database(&mut wtxn, Some(db_name::BATCH_STATUS))?; let batch_status = env.create_database(&mut wtxn, Some(db_name::BATCH_STATUS))?;
let batch_kind = env.create_database(&mut wtxn, Some(db_name::BATCH_KIND))?; let batch_kind = env.create_database(&mut wtxn, Some(db_name::BATCH_KIND))?;
let batch_index_tasks = env.create_database(&mut wtxn, Some(db_name::BATCH_INDEX_TASKS))?; let batch_index_tasks = env.create_database(&mut wtxn, Some(db_name::BATCH_INDEX_TASKS))?;
let batch_canceled_by = env.create_database(&mut wtxn, Some(db_name::BATCH_CANCELED_BY))?;
let batch_enqueued_at = env.create_database(&mut wtxn, Some(db_name::BATCH_ENQUEUED_AT))?; let batch_enqueued_at = env.create_database(&mut wtxn, Some(db_name::BATCH_ENQUEUED_AT))?;
let batch_started_at = env.create_database(&mut wtxn, Some(db_name::BATCH_STARTED_AT))?; let batch_started_at = env.create_database(&mut wtxn, Some(db_name::BATCH_STARTED_AT))?;
let batch_finished_at = env.create_database(&mut wtxn, Some(db_name::BATCH_FINISHED_AT))?; let batch_finished_at = env.create_database(&mut wtxn, Some(db_name::BATCH_FINISHED_AT))?;
@ -551,7 +546,6 @@ impl IndexScheduler {
batch_status, batch_status,
batch_kind, batch_kind,
batch_index_tasks, batch_index_tasks,
batch_canceled_by,
batch_enqueued_at, batch_enqueued_at,
batch_started_at, batch_started_at,
batch_finished_at, batch_finished_at,
@ -990,16 +984,23 @@ impl IndexScheduler {
batches &= batches_by_task_uids; batches &= batches_by_task_uids;
} }
// There is no database for this query, we must retrieve the task queried by the client and ensure it's valid
if let Some(canceled_by) = &query.canceled_by { if let Some(canceled_by) = &query.canceled_by {
let mut all_canceled_batches = RoaringBitmap::new(); let mut all_canceled_batches = RoaringBitmap::new();
for cancel_uid in canceled_by { for cancel_uid in canceled_by {
if let Some(canceled_by_uid) = self.batch_canceled_by.get(rtxn, cancel_uid)? { if let Some(task) = self.get_task(rtxn, *cancel_uid)? {
all_canceled_batches |= canceled_by_uid; if task.kind.as_kind() == Kind::TaskCancelation
&& task.status == Status::Succeeded
{
if let Some(batch_uid) = task.batch_uid {
all_canceled_batches.insert(batch_uid);
}
}
} }
} }
// if the canceled_by has been specified but no batch // if the canceled_by has been specified but no batch
// matches then we prefer matching zero than all tasks. // matches then we prefer matching zero than all batches.
if all_canceled_batches.is_empty() { if all_canceled_batches.is_empty() {
return Ok(RoaringBitmap::new()); return Ok(RoaringBitmap::new());
} else { } else {
@ -1253,24 +1254,35 @@ impl IndexScheduler {
} }
} }
// Any task that is internally associated with a non-authorized index // Any batch that is internally associated with at least one authorized index
// must be discarded. // must be returned.
// This works because currently batches cannot contains tasks from multiple indexes at the same time.
if !filters.all_indexes_authorized() { if !filters.all_indexes_authorized() {
let mut valid_indexes = RoaringBitmap::new();
let mut forbidden_indexes = RoaringBitmap::new();
let all_indexes_iter = self.batch_index_tasks.iter(rtxn)?; let all_indexes_iter = self.batch_index_tasks.iter(rtxn)?;
for result in all_indexes_iter { for result in all_indexes_iter {
let (index, index_tasks) = result?; let (index, index_tasks) = result?;
if !filters.is_index_authorized(index) { if filters.is_index_authorized(index) {
batches -= index_tasks; valid_indexes |= index_tasks;
} else {
forbidden_indexes |= index_tasks;
} }
} }
if let Some(batch) = processing.batch.as_ref() { if let Some(batch) = processing.batch.as_ref() {
for index in &batch.indexes { for index in &batch.indexes {
if !filters.is_index_authorized(index) { if filters.is_index_authorized(index) {
batches.remove(batch.uid); valid_indexes.insert(batch.uid);
} else {
forbidden_indexes.insert(batch.uid);
} }
} }
} }
// If a batch had ONE valid task then it should be returned
let invalid_batches = forbidden_indexes - valid_indexes;
batches -= invalid_batches;
} }
Ok((batches, total_batches.len())) Ok((batches, total_batches.len()))
@ -1543,11 +1555,16 @@ impl IndexScheduler {
// 2. Process the tasks // 2. Process the tasks
let res = { let res = {
let cloned_index_scheduler = self.private_clone(); let cloned_index_scheduler = self.private_clone();
let handle = std::thread::Builder::new() let processing_batch = &mut processing_batch;
.name(String::from("batch-operation")) std::thread::scope(|s| {
.spawn(move || cloned_index_scheduler.process_batch(batch)) let handle = std::thread::Builder::new()
.unwrap(); .name(String::from("batch-operation"))
handle.join().unwrap_or(Err(Error::ProcessBatchPanicked)) .spawn_scoped(s, move || {
cloned_index_scheduler.process_batch(batch, processing_batch)
})
.unwrap();
handle.join().unwrap_or(Err(Error::ProcessBatchPanicked))
})
}; };
// Reset the currently updating index to relinquish the index handle // Reset the currently updating index to relinquish the index handle
@ -1566,11 +1583,20 @@ impl IndexScheduler {
let mut success = 0; let mut success = 0;
let mut failure = 0; let mut failure = 0;
let mut canceled_by = None;
let mut canceled = RoaringBitmap::new();
dbg!(&tasks);
#[allow(unused_variables)] #[allow(unused_variables)]
for (i, mut task) in tasks.into_iter().enumerate() { for (i, mut task) in tasks.into_iter().enumerate() {
task.started_at = Some(processing_batch.started_at); if task.status != Status::Canceled {
task.finished_at = Some(finished_at); task.started_at = Some(processing_batch.started_at);
task.finished_at = Some(finished_at);
} else {
canceled.insert(task.uid);
canceled_by = task.canceled_by;
}
#[cfg(test)] #[cfg(test)]
self.maybe_fail( self.maybe_fail(
@ -1588,6 +1614,10 @@ impl IndexScheduler {
.map_err(|e| Error::TaskDatabaseUpdate(Box::new(e)))?; .map_err(|e| Error::TaskDatabaseUpdate(Box::new(e)))?;
processing_batch.update(&task); processing_batch.update(&task);
} }
if let Some(canceled_by) = canceled_by {
println!("inserting the canceled by {canceled_by}: {canceled:?}");
self.canceled_by.put(&mut wtxn, &canceled_by, &canceled)?;
}
tracing::info!("A batch of tasks was successfully completed with {success} successful tasks and {failure} failed tasks."); tracing::info!("A batch of tasks was successfully completed with {success} successful tasks and {failure} failed tasks.");
} }
// If we have an abortion error we must stop the tick here and re-schedule tasks. // If we have an abortion error we must stop the tick here and re-schedule tasks.
@ -4120,6 +4150,7 @@ mod tests {
tasks: [0, 1, 2, 3].into_iter().collect(), tasks: [0, 1, 2, 3].into_iter().collect(),
}; };
let task_cancelation = index_scheduler.register(kind, None, false).unwrap(); let task_cancelation = index_scheduler.register(kind, None, false).unwrap();
println!("HEEERE");
handle.advance_n_successful_batches(1); handle.advance_n_successful_batches(1);
snapshot!(snapshot_index_scheduler(&index_scheduler), name: "start"); snapshot!(snapshot_index_scheduler(&index_scheduler), name: "start");
@ -4561,13 +4592,12 @@ mod tests {
let (batches, _) = index_scheduler let (batches, _) = index_scheduler
.get_batch_ids_from_authorized_indexes(&rtxn, &query, &AuthFilter::default()) .get_batch_ids_from_authorized_indexes(&rtxn, &query, &AuthFilter::default())
.unwrap(); .unwrap();
// 0 is not returned because it was not canceled, 3 is not returned because it is the uid of the // The batch zero was the index creation task, the 1 is the task cancellation
// taskCancelation itself snapshot!(snapshot_bitmap(&batches), @"[1,]");
snapshot!(snapshot_bitmap(&batches), @"[1,2,]");
let query = Query { canceled_by: Some(vec![task_cancelation.uid]), ..Query::default() }; let query = Query { canceled_by: Some(vec![task_cancelation.uid]), ..Query::default() };
let (batches, _) = index_scheduler let (batches, _) = index_scheduler
.get_task_ids_from_authorized_indexes( .get_batch_ids_from_authorized_indexes(
&rtxn, &rtxn,
&query, &query,
&AuthFilter::with_allowed_indexes( &AuthFilter::with_allowed_indexes(
@ -5869,7 +5899,7 @@ mod tests {
let kind = KindWithContent::IndexCreation { index_uid: S("doggo"), primary_key: None }; let kind = KindWithContent::IndexCreation { index_uid: S("doggo"), primary_key: None };
let task = index_scheduler.register(kind, None, true).unwrap(); let task = index_scheduler.register(kind, None, true).unwrap();
snapshot!(task.uid, @"0"); snapshot!(task.uid, @"0");
snapshot!(snapshot_index_scheduler(&index_scheduler), @r###" snapshot!(snapshot_index_scheduler(&index_scheduler), @r"
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
[] []
@ -5903,9 +5933,6 @@ mod tests {
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------
@ -5916,12 +5943,12 @@ mod tests {
### File Store: ### File Store:
---------------------------------------------------------------------- ----------------------------------------------------------------------
"###); ");
let kind = KindWithContent::IndexCreation { index_uid: S("doggo"), primary_key: None }; let kind = KindWithContent::IndexCreation { index_uid: S("doggo"), primary_key: None };
let task = index_scheduler.register(kind, Some(12), true).unwrap(); let task = index_scheduler.register(kind, Some(12), true).unwrap();
snapshot!(task.uid, @"12"); snapshot!(task.uid, @"12");
snapshot!(snapshot_index_scheduler(&index_scheduler), @r###" snapshot!(snapshot_index_scheduler(&index_scheduler), @r"
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
[] []
@ -5955,9 +5982,6 @@ mod tests {
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------
@ -5968,7 +5992,7 @@ mod tests {
### File Store: ### File Store:
---------------------------------------------------------------------- ----------------------------------------------------------------------
"###); ");
} }
#[test] #[test]

View File

@ -1,13 +1,14 @@
--- ---
source: index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing Tasks: ### Processing batch None:
[] []
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Tasks: ### All Tasks:
0 {uid: 0, status: canceled, canceled_by: 1, details: { received_documents: 1, indexed_documents: Some(0) }, kind: DocumentAdditionOrUpdate { index_uid: "catto", primary_key: None, method: ReplaceDocuments, content_file: 00000000-0000-0000-0000-000000000000, documents_count: 1, allow_index_creation: true }} 0 {uid: 0, batch_uid: 0, status: canceled, canceled_by: 1, details: { received_documents: 1, indexed_documents: Some(0) }, kind: DocumentAdditionOrUpdate { index_uid: "catto", primary_key: None, method: ReplaceDocuments, content_file: 00000000-0000-0000-0000-000000000000, documents_count: 1, allow_index_creation: true }}
1 {uid: 1, status: succeeded, details: { matched_tasks: 1, canceled_tasks: Some(1), original_filter: "test_query" }, kind: TaskCancelation { query: "test_query", tasks: RoaringBitmap<[0]> }} 1 {uid: 1, batch_uid: 0, status: succeeded, details: { matched_tasks: 1, canceled_tasks: Some(1), original_filter: "test_query" }, kind: TaskCancelation { query: "test_query", tasks: RoaringBitmap<[0]> }}
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Status: ### Status:
enqueued [] enqueued []
@ -36,10 +37,35 @@ catto [0,]
[timestamp] [1,] [timestamp] [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Finished At: ### Finished At:
[timestamp] [0,]
[timestamp] [1,] [timestamp] [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches:
0 {uid: 0, }
----------------------------------------------------------------------
### Batch to tasks mapping:
0 [1,]
----------------------------------------------------------------------
### Batches Status:
succeeded [0,]
----------------------------------------------------------------------
### Batches Kind:
"documentAdditionOrUpdate" [0,]
"taskCancelation" [0,]
----------------------------------------------------------------------
### Batches Index Tasks:
catto [0,]
----------------------------------------------------------------------
### Batches Enqueued At:
[timestamp] [0,]
[timestamp] [0,]
----------------------------------------------------------------------
### Batches Started At:
[timestamp] [0,]
----------------------------------------------------------------------
### Batches Finished At:
[timestamp] [0,]
----------------------------------------------------------------------
### File Store: ### File Store:
00000000-0000-0000-0000-000000000000
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -42,9 +43,6 @@ catto [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(1): ### Processing batch Some(1):
@ -58,9 +59,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
catto [0,] catto [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,15 +1,16 @@
--- ---
source: index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing Tasks: ### Processing batch None:
[] []
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Tasks: ### All Tasks:
0 {uid: 0, status: succeeded, details: { received_documents: 1, indexed_documents: Some(1) }, kind: DocumentAdditionOrUpdate { index_uid: "catto", primary_key: None, method: ReplaceDocuments, content_file: 00000000-0000-0000-0000-000000000000, documents_count: 1, allow_index_creation: true }} 0 {uid: 0, batch_uid: 0, status: succeeded, details: { received_documents: 1, indexed_documents: Some(1) }, kind: DocumentAdditionOrUpdate { index_uid: "catto", primary_key: None, method: ReplaceDocuments, content_file: 00000000-0000-0000-0000-000000000000, documents_count: 1, allow_index_creation: true }}
1 {uid: 1, status: canceled, canceled_by: 3, details: { received_documents: 1, indexed_documents: Some(0) }, kind: DocumentAdditionOrUpdate { index_uid: "beavero", primary_key: None, method: ReplaceDocuments, content_file: 00000000-0000-0000-0000-000000000001, documents_count: 1, allow_index_creation: true }} 1 {uid: 1, batch_uid: 1, status: canceled, canceled_by: 3, details: { received_documents: 1, indexed_documents: Some(0) }, kind: DocumentAdditionOrUpdate { index_uid: "beavero", primary_key: None, method: ReplaceDocuments, content_file: 00000000-0000-0000-0000-000000000001, documents_count: 1, allow_index_creation: true }}
2 {uid: 2, status: canceled, canceled_by: 3, details: { received_documents: 1, indexed_documents: Some(0) }, kind: DocumentAdditionOrUpdate { index_uid: "wolfo", primary_key: None, method: ReplaceDocuments, content_file: 00000000-0000-0000-0000-000000000002, documents_count: 1, allow_index_creation: true }} 2 {uid: 2, batch_uid: 1, status: canceled, canceled_by: 3, details: { received_documents: 1, indexed_documents: Some(0) }, kind: DocumentAdditionOrUpdate { index_uid: "wolfo", primary_key: None, method: ReplaceDocuments, content_file: 00000000-0000-0000-0000-000000000002, documents_count: 1, allow_index_creation: true }}
3 {uid: 3, status: succeeded, details: { matched_tasks: 3, canceled_tasks: Some(2), original_filter: "test_query" }, kind: TaskCancelation { query: "test_query", tasks: RoaringBitmap<[0, 1, 2]> }} 3 {uid: 3, batch_uid: 1, status: succeeded, details: { matched_tasks: 3, canceled_tasks: Some(2), original_filter: "test_query" }, kind: TaskCancelation { query: "test_query", tasks: RoaringBitmap<[0, 1, 2]> }}
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Status: ### Status:
enqueued [] enqueued []
@ -42,15 +43,47 @@ catto: { number_of_documents: 1, field_distribution: {"id": 1} }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Started At: ### Started At:
[timestamp] [0,] [timestamp] [0,]
[timestamp] [1,]
[timestamp] [3,] [timestamp] [3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Finished At: ### Finished At:
[timestamp] [0,] [timestamp] [0,]
[timestamp] [1,2,]
[timestamp] [3,] [timestamp] [3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches:
0 {uid: 0, }
1 {uid: 1, }
----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [3,]
----------------------------------------------------------------------
### Batches Status:
succeeded [0,1,]
----------------------------------------------------------------------
### Batches Kind:
"documentAdditionOrUpdate" [0,1,]
"taskCancelation" [1,]
----------------------------------------------------------------------
### Batches Index Tasks:
beavero [1,]
catto [0,]
wolfo [1,]
----------------------------------------------------------------------
### Batches Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [1,]
----------------------------------------------------------------------
### Batches Started At:
[timestamp] [0,]
[timestamp] [1,]
----------------------------------------------------------------------
### Batches Finished At:
[timestamp] [0,]
[timestamp] [1,]
----------------------------------------------------------------------
### File Store: ### File Store:
00000000-0000-0000-0000-000000000001
00000000-0000-0000-0000-000000000002
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -54,9 +55,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
catto [0,] catto [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(1): ### Processing batch Some(1):
@ -57,9 +58,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
catto [0,] catto [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -38,9 +39,6 @@ enqueued [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,13 +1,14 @@
--- ---
source: index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing Tasks: ### Processing batch None:
[] []
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Tasks: ### All Tasks:
0 {uid: 0, status: canceled, canceled_by: 1, details: { dump_uid: None }, kind: DumpCreation { keys: [], instance_uid: None }} 0 {uid: 0, batch_uid: 0, status: canceled, canceled_by: 1, details: { dump_uid: None }, kind: DumpCreation { keys: [], instance_uid: None }}
1 {uid: 1, status: succeeded, details: { matched_tasks: 1, canceled_tasks: Some(0), original_filter: "cancel dump" }, kind: TaskCancelation { query: "cancel dump", tasks: RoaringBitmap<[0]> }} 1 {uid: 1, batch_uid: 0, status: succeeded, details: { matched_tasks: 1, canceled_tasks: Some(1), original_filter: "cancel dump" }, kind: TaskCancelation { query: "cancel dump", tasks: RoaringBitmap<[0]> }}
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Status: ### Status:
enqueued [] enqueued []
@ -32,14 +33,36 @@ canceled [0,]
[timestamp] [1,] [timestamp] [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Started At: ### Started At:
[timestamp] [0,]
[timestamp] [1,] [timestamp] [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Finished At: ### Finished At:
[timestamp] [0,]
[timestamp] [1,] [timestamp] [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches:
0 {uid: 0, }
----------------------------------------------------------------------
### Batch to tasks mapping:
0 [1,]
----------------------------------------------------------------------
### Batches Status:
succeeded [0,]
----------------------------------------------------------------------
### Batches Kind:
"taskCancelation" [0,]
"dumpCreation" [0,]
----------------------------------------------------------------------
### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Enqueued At:
[timestamp] [0,]
[timestamp] [0,]
----------------------------------------------------------------------
### Batches Started At:
[timestamp] [0,]
----------------------------------------------------------------------
### Batches Finished At:
[timestamp] [0,]
----------------------------------------------------------------------
### File Store: ### File Store:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -41,9 +42,6 @@ enqueued [0,1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -43,9 +44,6 @@ catto: { number_of_documents: 0, field_distribution: {} }
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,13 +1,14 @@
--- ---
source: index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing Tasks: ### Processing batch None:
[] []
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Tasks: ### All Tasks:
0 {uid: 0, status: canceled, canceled_by: 1, details: { received_documents: 1, indexed_documents: Some(0) }, kind: DocumentAdditionOrUpdate { index_uid: "catto", primary_key: None, method: ReplaceDocuments, content_file: 00000000-0000-0000-0000-000000000000, documents_count: 1, allow_index_creation: true }} 0 {uid: 0, batch_uid: 0, status: canceled, canceled_by: 1, details: { received_documents: 1, indexed_documents: Some(0) }, kind: DocumentAdditionOrUpdate { index_uid: "catto", primary_key: None, method: ReplaceDocuments, content_file: 00000000-0000-0000-0000-000000000000, documents_count: 1, allow_index_creation: true }}
1 {uid: 1, status: succeeded, details: { matched_tasks: 1, canceled_tasks: Some(1), original_filter: "test_query" }, kind: TaskCancelation { query: "test_query", tasks: RoaringBitmap<[0]> }} 1 {uid: 1, batch_uid: 0, status: succeeded, details: { matched_tasks: 1, canceled_tasks: Some(1), original_filter: "test_query" }, kind: TaskCancelation { query: "test_query", tasks: RoaringBitmap<[0]> }}
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Status: ### Status:
enqueued [] enqueued []
@ -34,14 +35,38 @@ catto: { number_of_documents: 0, field_distribution: {} }
[timestamp] [1,] [timestamp] [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Started At: ### Started At:
[timestamp] [0,]
[timestamp] [1,] [timestamp] [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Finished At: ### Finished At:
[timestamp] [0,]
[timestamp] [1,] [timestamp] [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches:
0 {uid: 0, }
----------------------------------------------------------------------
### Batch to tasks mapping:
0 [1,]
----------------------------------------------------------------------
### Batches Status:
succeeded [0,]
----------------------------------------------------------------------
### Batches Kind:
"documentAdditionOrUpdate" [0,]
"taskCancelation" [0,]
----------------------------------------------------------------------
### Batches Index Tasks:
catto [0,]
----------------------------------------------------------------------
### Batches Enqueued At:
[timestamp] [0,]
[timestamp] [0,]
----------------------------------------------------------------------
### Batches Started At:
[timestamp] [0,]
----------------------------------------------------------------------
### Batches Finished At:
[timestamp] [0,]
----------------------------------------------------------------------
### File Store: ### File Store:
00000000-0000-0000-0000-000000000000
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -42,9 +43,6 @@ catto [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -39,9 +40,6 @@ catto [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ catto [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -25,7 +26,6 @@ catto: { number_of_documents: 1, field_distribution: {"id": 1} }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Canceled By: ### Canceled By:
1 []
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Enqueued At: ### Enqueued At:
@ -57,9 +57,6 @@ succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
catto [0,] catto [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -48,9 +49,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
catto [0,] catto [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ catto [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -86,9 +87,6 @@ succeeded [0,1,2,3,4,5,]
cattos [1,4,] cattos [1,4,]
doggos [0,3,] doggos [0,3,]
girafos [2,5,] girafos [2,5,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -48,9 +49,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -52,9 +53,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -42,9 +43,6 @@ doggos [0,1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -54,9 +55,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -59,9 +60,6 @@ succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,] doggos [0,1,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -42,9 +43,6 @@ doggos [0,1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -45,9 +46,6 @@ doggos [0,1,2,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -42,9 +43,6 @@ doggos [0,1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -51,9 +52,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -50,9 +51,6 @@ failed [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -58,9 +59,6 @@ failed [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,] doggos [0,1,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -42,9 +43,6 @@ doggos [0,1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -47,9 +48,6 @@ failed [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -56,9 +57,6 @@ succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,] doggos [0,1,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -51,9 +52,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -63,7 +64,6 @@ doggos: { number_of_documents: 1, field_distribution: {"doggo": 1, "id": 1} }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,] succeeded [0,1,2,]
failed [2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:
"documentAdditionOrUpdate" [1,] "documentAdditionOrUpdate" [1,]
@ -72,9 +72,6 @@ failed [2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,2,] doggos [0,1,2,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -65,9 +66,6 @@ succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,] doggos [0,1,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -42,9 +43,6 @@ doggos [0,1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ catto [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -47,9 +48,6 @@ failed [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
catto [0,] catto [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -40,9 +41,6 @@ doggos: { number_of_documents: 1, field_distribution: {"doggo": 1, "id": 1} }
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -40,9 +41,6 @@ doggos: { number_of_documents: 1, field_distribution: {"doggo": 1, "id": 1} }
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -48,9 +49,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -62,9 +63,6 @@ succeeded [0,1,2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,2,] doggos [0,1,2,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -58,9 +59,6 @@ succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,] doggos [0,1,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -56,9 +57,6 @@ succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,] doggos [0,1,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -51,9 +52,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -48,9 +49,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -39,9 +40,6 @@ index_a [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ index_a [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -42,9 +43,6 @@ index_b [1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch Some(0): ### Processing batch Some(0):
@ -45,9 +46,6 @@ index_b [1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -47,9 +48,6 @@ failed [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
catto [0,] catto [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ catto [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -54,9 +55,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -60,9 +61,6 @@ succeeded [0,1,]
### Batches Index Tasks: ### Batches Index Tasks:
cattos [1,] cattos [1,]
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -64,9 +65,6 @@ succeeded [0,1,2,]
### Batches Index Tasks: ### Batches Index Tasks:
cattos [1,] cattos [1,]
doggos [0,2,] doggos [0,2,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -42,9 +43,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -45,9 +46,6 @@ doggos [0,2,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = false ### Autobatching Enabled = false
### Processing batch None: ### Processing batch None:
@ -55,9 +56,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,] doggos [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = false ### Autobatching Enabled = false
### Processing batch None: ### Processing batch None:
@ -68,9 +69,6 @@ succeeded [0,1,2,3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,2,3,] doggos [0,1,2,3,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = false ### Autobatching Enabled = false
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggos [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = false ### Autobatching Enabled = false
### Processing batch None: ### Processing batch None:
@ -46,9 +47,6 @@ doggos [0,1,2,3,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = false ### Autobatching Enabled = false
### Processing batch None: ### Processing batch None:
@ -42,9 +43,6 @@ doggos [0,1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = false ### Autobatching Enabled = false
### Processing batch None: ### Processing batch None:
@ -44,9 +45,6 @@ doggos [0,1,2,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = false ### Autobatching Enabled = false
### Processing batch None: ### Processing batch None:
@ -60,9 +61,6 @@ succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,] doggos [0,1,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = false ### Autobatching Enabled = false
### Processing batch None: ### Processing batch None:
@ -64,9 +65,6 @@ succeeded [0,1,2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
doggos [0,1,2,] doggos [0,1,2,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -0,0 +1,86 @@
---
source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
---
### Autobatching Enabled = true
### Processing batch None:
[]
----------------------------------------------------------------------
### All Tasks:
0 {uid: 0, batch_uid: 0, status: succeeded, details: { primary_key: Some("mouse") }, kind: IndexCreation { index_uid: "catto", primary_key: Some("mouse") }}
1 {uid: 1, batch_uid: 1, status: canceled, canceled_by: 3, details: { primary_key: Some("sheep") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("sheep") }}
2 {uid: 2, batch_uid: 1, status: canceled, canceled_by: 3, details: { swaps: [IndexSwap { indexes: ("catto", "doggo") }] }, kind: IndexSwap { swaps: [IndexSwap { indexes: ("catto", "doggo") }] }}
3 {uid: 3, batch_uid: 1, status: succeeded, details: { matched_tasks: 3, canceled_tasks: Some(2), original_filter: "test_query" }, kind: TaskCancelation { query: "test_query", tasks: RoaringBitmap<[0, 1, 2]> }}
----------------------------------------------------------------------
### Status:
enqueued []
succeeded [0,3,]
canceled [1,2,]
----------------------------------------------------------------------
### Kind:
"indexCreation" [0,1,]
"indexSwap" [2,]
"taskCancelation" [3,]
----------------------------------------------------------------------
### Index Tasks:
catto [0,2,]
doggo [1,2,]
----------------------------------------------------------------------
### Index Mapper:
catto: { number_of_documents: 0, field_distribution: {} }
----------------------------------------------------------------------
### Canceled By:
3 [1,2,]
----------------------------------------------------------------------
### Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
[timestamp] [3,]
----------------------------------------------------------------------
### Started At:
[timestamp] [0,]
[timestamp] [3,]
----------------------------------------------------------------------
### Finished At:
[timestamp] [0,]
[timestamp] [3,]
----------------------------------------------------------------------
### All Batches:
0 {uid: 0, }
1 {uid: 1, }
----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [3,]
----------------------------------------------------------------------
### Batches Status:
succeeded [0,1,]
----------------------------------------------------------------------
### Batches Kind:
"indexCreation" [0,1,]
"indexSwap" [1,]
"taskCancelation" [1,]
----------------------------------------------------------------------
### Batches Index Tasks:
catto [0,1,]
doggo [1,]
----------------------------------------------------------------------
### Batches Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [1,]
----------------------------------------------------------------------
### Batches Started At:
[timestamp] [0,]
[timestamp] [1,]
----------------------------------------------------------------------
### Batches Finished At:
[timestamp] [0,]
[timestamp] [1,]
----------------------------------------------------------------------
### File Store:
----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -66,9 +67,6 @@ succeeded [0,1,2,]
catto [2,] catto [2,]
doggo [0,] doggo [0,]
whalo [1,] whalo [1,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggo [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -42,9 +43,6 @@ whalo [1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -45,9 +46,6 @@ whalo [1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -67,9 +68,6 @@ failed [2,]
catto [0,] catto [0,]
doggo [1,] doggo [1,]
whalo [2,] whalo [2,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -45,9 +46,6 @@ whalo [2,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -75,9 +76,6 @@ failed [2,3,]
catto [0,2,3,] catto [0,2,3,]
doggo [1,2,] doggo [1,2,]
whalo [3,] whalo [3,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -48,9 +49,6 @@ whalo [3,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,15 +1,16 @@
--- ---
source: index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing Tasks: ### Processing batch None:
[] []
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Tasks: ### All Tasks:
0 {uid: 0, status: succeeded, details: { primary_key: Some("mouse") }, kind: IndexCreation { index_uid: "catto", primary_key: Some("mouse") }} 0 {uid: 0, batch_uid: 0, status: succeeded, details: { primary_key: Some("mouse") }, kind: IndexCreation { index_uid: "catto", primary_key: Some("mouse") }}
1 {uid: 1, status: canceled, canceled_by: 3, details: { primary_key: Some("sheep") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("sheep") }} 1 {uid: 1, batch_uid: 1, status: canceled, canceled_by: 3, details: { primary_key: Some("sheep") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("sheep") }}
2 {uid: 2, status: canceled, canceled_by: 3, details: { swaps: [IndexSwap { indexes: ("catto", "doggo") }] }, kind: IndexSwap { swaps: [IndexSwap { indexes: ("catto", "doggo") }] }} 2 {uid: 2, batch_uid: 1, status: canceled, canceled_by: 3, details: { swaps: [IndexSwap { indexes: ("catto", "doggo") }] }, kind: IndexSwap { swaps: [IndexSwap { indexes: ("catto", "doggo") }] }}
3 {uid: 3, status: succeeded, details: { matched_tasks: 3, canceled_tasks: Some(0), original_filter: "test_query" }, kind: TaskCancelation { query: "test_query", tasks: RoaringBitmap<[0, 1, 2]> }} 3 {uid: 3, batch_uid: 1, status: succeeded, details: { matched_tasks: 3, canceled_tasks: Some(2), original_filter: "test_query" }, kind: TaskCancelation { query: "test_query", tasks: RoaringBitmap<[0, 1, 2]> }}
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Status: ### Status:
enqueued [] enqueued []
@ -45,10 +46,41 @@ catto: { number_of_documents: 0, field_distribution: {} }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Finished At: ### Finished At:
[timestamp] [0,] [timestamp] [0,]
[timestamp] [1,2,]
[timestamp] [3,] [timestamp] [3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches:
0 {uid: 0, }
1 {uid: 1, }
----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [3,]
----------------------------------------------------------------------
### Batches Status:
succeeded [0,1,]
----------------------------------------------------------------------
### Batches Kind:
"indexCreation" [0,1,]
"indexSwap" [1,]
"taskCancelation" [1,]
----------------------------------------------------------------------
### Batches Index Tasks:
catto [0,1,]
doggo [1,]
----------------------------------------------------------------------
### Batches Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [1,]
----------------------------------------------------------------------
### Batches Started At:
[timestamp] [0,]
[timestamp] [1,]
----------------------------------------------------------------------
### Batches Finished At:
[timestamp] [0,]
[timestamp] [1,]
----------------------------------------------------------------------
### File Store: ### File Store:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -66,9 +67,6 @@ succeeded [0,1,2,]
catto [2,] catto [2,]
doggo [0,] doggo [0,]
whalo [1,] whalo [1,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -39,9 +40,6 @@ doggo [0,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -42,9 +43,6 @@ whalo [1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -45,9 +46,6 @@ whalo [1,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -67,9 +68,6 @@ failed [2,]
catto [0,] catto [0,]
doggo [1,] doggo [1,]
whalo [2,] whalo [2,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -45,9 +46,6 @@ whalo [2,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -48,9 +49,6 @@ whalo [3,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -47,9 +48,6 @@ doggo [3,]
### Batches Kind: ### Batches Kind:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -57,9 +58,6 @@ succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Index Tasks: ### Batches Index Tasks:
a [0,] a [0,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -63,9 +64,6 @@ succeeded [0,1,]
### Batches Index Tasks: ### Batches Index Tasks:
a [0,] a [0,]
b [1,] b [1,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

View File

@ -1,5 +1,6 @@
--- ---
source: crates/index-scheduler/src/lib.rs source: crates/index-scheduler/src/lib.rs
snapshot_kind: text
--- ---
### Autobatching Enabled = true ### Autobatching Enabled = true
### Processing batch None: ### Processing batch None:
@ -69,9 +70,6 @@ succeeded [0,1,2,]
a [0,] a [0,]
b [1,] b [1,]
c [2,] c [2,]
----------------------------------------------------------------------
### Batches Canceled By:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Enqueued At: ### Batches Enqueued At:
[timestamp] [0,] [timestamp] [0,]

Some files were not shown because too many files have changed in this diff Show More