Compare commits

..

4 Commits

178 changed files with 1961 additions and 256 deletions

View File

@ -24,7 +24,6 @@ use std::fs::{self, File};
use std::io::BufWriter; use std::io::BufWriter;
use dump::IndexMetadata; use dump::IndexMetadata;
use meilisearch_types::batches::BatchId;
use meilisearch_types::error::Code; use meilisearch_types::error::Code;
use meilisearch_types::heed::{RoTxn, RwTxn}; use meilisearch_types::heed::{RoTxn, RwTxn};
use meilisearch_types::milli::documents::{obkv_to_object, DocumentsBatchReader}; use meilisearch_types::milli::documents::{obkv_to_object, DocumentsBatchReader};
@ -45,7 +44,7 @@ use time::OffsetDateTime;
use uuid::Uuid; use uuid::Uuid;
use crate::autobatcher::{self, BatchKind}; use crate::autobatcher::{self, BatchKind};
use crate::utils::{self, swap_index_uid_in_task}; use crate::utils::{self, swap_index_uid_in_task, ProcessingBatch};
use crate::{Error, IndexScheduler, MustStopProcessing, ProcessingTasks, Result, TaskId}; use crate::{Error, IndexScheduler, MustStopProcessing, ProcessingTasks, Result, TaskId};
/// Represents a combination of tasks that can all be processed at the same time. /// Represents a combination of tasks that can all be processed at the same time.
@ -280,22 +279,24 @@ impl IndexScheduler {
rtxn: &RoTxn, rtxn: &RoTxn,
index_uid: String, index_uid: String,
batch: BatchKind, batch: BatchKind,
batch_id: BatchId, current_batch: &mut ProcessingBatch,
must_create_index: bool, must_create_index: bool,
) -> Result<Option<Batch>> { ) -> Result<Option<Batch>> {
match batch { match batch {
BatchKind::DocumentClear { ids } => Ok(Some(Batch::IndexOperation { BatchKind::DocumentClear { ids } => Ok(Some(Batch::IndexOperation {
op: IndexOperation::DocumentClear { op: IndexOperation::DocumentClear {
tasks: self.get_existing_tasks_with_batch_id(rtxn, batch_id, ids)?, tasks: self.get_existing_tasks_with_processing_batch(
rtxn,
current_batch,
ids,
)?,
index_uid, index_uid,
}, },
must_create_index, must_create_index,
})), })),
BatchKind::DocumentEdition { id } => { BatchKind::DocumentEdition { id } => {
let task = self let mut task = self.get_task(rtxn, id)?.ok_or(Error::CorruptedTaskQueue)?;
.get_task(rtxn, id)? current_batch.processing(Some(&mut task));
.ok_or(Error::CorruptedTaskQueue)?
.with_batch_id(batch_id);
match &task.kind { match &task.kind {
KindWithContent::DocumentEdition { index_uid, .. } => { KindWithContent::DocumentEdition { index_uid, .. } => {
Ok(Some(Batch::IndexOperation { Ok(Some(Batch::IndexOperation {
@ -310,7 +311,11 @@ impl IndexScheduler {
} }
} }
BatchKind::DocumentOperation { method, operation_ids, .. } => { BatchKind::DocumentOperation { method, operation_ids, .. } => {
let tasks = self.get_existing_tasks_with_batch_id(rtxn, batch_id, operation_ids)?; let tasks = self.get_existing_tasks_with_processing_batch(
rtxn,
current_batch,
operation_ids,
)?;
let primary_key = tasks let primary_key = tasks
.iter() .iter()
.find_map(|task| match task.kind { .find_map(|task| match task.kind {
@ -357,7 +362,11 @@ impl IndexScheduler {
})) }))
} }
BatchKind::DocumentDeletion { deletion_ids, includes_by_filter: _ } => { BatchKind::DocumentDeletion { deletion_ids, includes_by_filter: _ } => {
let tasks = self.get_existing_tasks_with_batch_id(rtxn, batch_id, deletion_ids)?; let tasks = self.get_existing_tasks_with_processing_batch(
rtxn,
current_batch,
deletion_ids,
)?;
Ok(Some(Batch::IndexOperation { Ok(Some(Batch::IndexOperation {
op: IndexOperation::DocumentDeletion { index_uid, tasks }, op: IndexOperation::DocumentDeletion { index_uid, tasks },
@ -365,7 +374,11 @@ impl IndexScheduler {
})) }))
} }
BatchKind::Settings { settings_ids, .. } => { BatchKind::Settings { settings_ids, .. } => {
let tasks = self.get_existing_tasks_with_batch_id(rtxn, batch_id, settings_ids)?; let tasks = self.get_existing_tasks_with_processing_batch(
rtxn,
current_batch,
settings_ids,
)?;
let mut settings = Vec::new(); let mut settings = Vec::new();
for task in &tasks { for task in &tasks {
@ -388,7 +401,7 @@ impl IndexScheduler {
rtxn, rtxn,
index_uid, index_uid,
BatchKind::Settings { settings_ids, allow_index_creation }, BatchKind::Settings { settings_ids, allow_index_creation },
batch_id, current_batch,
must_create_index, must_create_index,
)? )?
.unwrap() .unwrap()
@ -404,7 +417,7 @@ impl IndexScheduler {
rtxn, rtxn,
index_uid, index_uid,
BatchKind::DocumentClear { ids: other }, BatchKind::DocumentClear { ids: other },
batch_id, current_batch,
must_create_index, must_create_index,
)? )?
.unwrap() .unwrap()
@ -437,7 +450,7 @@ impl IndexScheduler {
rtxn, rtxn,
index_uid.clone(), index_uid.clone(),
BatchKind::Settings { settings_ids, allow_index_creation }, BatchKind::Settings { settings_ids, allow_index_creation },
batch_id, current_batch,
must_create_index, must_create_index,
)?; )?;
@ -450,7 +463,7 @@ impl IndexScheduler {
primary_key, primary_key,
operation_ids, operation_ids,
}, },
batch_id, current_batch,
must_create_index, must_create_index,
)?; )?;
@ -488,10 +501,8 @@ impl IndexScheduler {
} }
} }
BatchKind::IndexCreation { id } => { BatchKind::IndexCreation { id } => {
let task = self let mut task = self.get_task(rtxn, id)?.ok_or(Error::CorruptedTaskQueue)?;
.get_task(rtxn, id)? current_batch.processing(Some(&mut task));
.ok_or(Error::CorruptedTaskQueue)?
.with_batch_id(batch_id);
let (index_uid, primary_key) = match &task.kind { let (index_uid, primary_key) = match &task.kind {
KindWithContent::IndexCreation { index_uid, primary_key } => { KindWithContent::IndexCreation { index_uid, primary_key } => {
(index_uid.clone(), primary_key.clone()) (index_uid.clone(), primary_key.clone())
@ -501,10 +512,8 @@ impl IndexScheduler {
Ok(Some(Batch::IndexCreation { index_uid, primary_key, task })) Ok(Some(Batch::IndexCreation { index_uid, primary_key, task }))
} }
BatchKind::IndexUpdate { id } => { BatchKind::IndexUpdate { id } => {
let task = self let mut task = self.get_task(rtxn, id)?.ok_or(Error::CorruptedTaskQueue)?;
.get_task(rtxn, id)? current_batch.processing(Some(&mut task));
.ok_or(Error::CorruptedTaskQueue)?
.with_batch_id(batch_id);
let primary_key = match &task.kind { let primary_key = match &task.kind {
KindWithContent::IndexUpdate { primary_key, .. } => primary_key.clone(), KindWithContent::IndexUpdate { primary_key, .. } => primary_key.clone(),
_ => unreachable!(), _ => unreachable!(),
@ -514,13 +523,11 @@ impl IndexScheduler {
BatchKind::IndexDeletion { ids } => Ok(Some(Batch::IndexDeletion { BatchKind::IndexDeletion { ids } => Ok(Some(Batch::IndexDeletion {
index_uid, index_uid,
index_has_been_created: must_create_index, index_has_been_created: must_create_index,
tasks: self.get_existing_tasks_with_batch_id(rtxn, batch_id, ids)?, tasks: self.get_existing_tasks_with_processing_batch(rtxn, current_batch, ids)?,
})), })),
BatchKind::IndexSwap { id } => { BatchKind::IndexSwap { id } => {
let task = self let mut task = self.get_task(rtxn, id)?.ok_or(Error::CorruptedTaskQueue)?;
.get_task(rtxn, id)? current_batch.processing(Some(&mut task));
.ok_or(Error::CorruptedTaskQueue)?
.with_batch_id(batch_id);
Ok(Some(Batch::IndexSwap { task })) Ok(Some(Batch::IndexSwap { task }))
} }
} }
@ -533,11 +540,16 @@ impl IndexScheduler {
/// 4. We get the *next* dump to process. /// 4. We get the *next* dump to process.
/// 5. We get the *next* tasks to process for a specific index. /// 5. We get the *next* tasks to process for a specific index.
#[tracing::instrument(level = "trace", skip(self, rtxn), target = "indexing::scheduler")] #[tracing::instrument(level = "trace", skip(self, rtxn), target = "indexing::scheduler")]
pub(crate) fn create_next_batch(&self, rtxn: &RoTxn) -> Result<Option<(Batch, BatchId)>> { pub(crate) fn create_next_batch(
&self,
rtxn: &RoTxn,
) -> Result<Option<(Batch, ProcessingBatch)>> {
#[cfg(test)] #[cfg(test)]
self.maybe_fail(crate::tests::FailureLocation::InsideCreateBatch)?; self.maybe_fail(crate::tests::FailureLocation::InsideCreateBatch)?;
let batch_id = self.next_batch_id(rtxn)?; let batch_id = self.next_batch_id(rtxn)?;
let mut current_batch = ProcessingBatch::new(batch_id);
let enqueued = &self.get_status(rtxn, Status::Enqueued)?; let enqueued = &self.get_status(rtxn, Status::Enqueued)?;
let to_cancel = self.get_kind(rtxn, Kind::TaskCancelation)? & enqueued; let to_cancel = self.get_kind(rtxn, Kind::TaskCancelation)? & enqueued;
@ -547,63 +559,51 @@ impl IndexScheduler {
// We must *not* reset the processing tasks before calling this method. // We must *not* reset the processing tasks before calling this method.
// Displaying the `batch_id` would make a strange error message since this task cancelation is going to // Displaying the `batch_id` would make a strange error message since this task cancelation is going to
// replace the canceled batch. It's better to avoid mentioning it in the error message. // replace the canceled batch. It's better to avoid mentioning it in the error message.
let ProcessingTasks { started_at, batch_id: _, processing } = let ProcessingTasks { batch: previous_batch, processing } =
&*self.processing_tasks.read().unwrap(); &*self.processing_tasks.read().unwrap();
let mut task = self.get_task(rtxn, task_id)?.ok_or(Error::CorruptedTaskQueue)?;
current_batch.processing(Some(&mut task));
return Ok(Some(( return Ok(Some((
Batch::TaskCancelation { Batch::TaskCancelation {
task: self task,
.get_task(rtxn, task_id)? // We should never be in a case where we don't have a previous_batch, but let's not crash if it happens
.ok_or(Error::CorruptedTaskQueue)? previous_started_at: previous_batch
.with_batch_id(batch_id), .as_ref()
previous_started_at: *started_at, .map_or_else(OffsetDateTime::now_utc, |batch| batch.started_at),
previous_processing_tasks: processing.clone(), previous_processing_tasks: processing.clone(),
}, },
batch_id, current_batch,
))); )));
} }
// 2. we get the next task to delete // 2. we get the next task to delete
let to_delete = self.get_kind(rtxn, Kind::TaskDeletion)? & enqueued; let to_delete = self.get_kind(rtxn, Kind::TaskDeletion)? & enqueued;
if !to_delete.is_empty() { if !to_delete.is_empty() {
let tasks = self let mut tasks = self.get_existing_tasks(rtxn, to_delete)?;
.get_existing_tasks(rtxn, to_delete)? current_batch.processing(&mut tasks);
.into_iter() return Ok(Some((Batch::TaskDeletions(tasks), current_batch)));
.map(|task| task.with_batch_id(batch_id))
.collect();
return Ok(Some((Batch::TaskDeletions(tasks), batch_id)));
} }
// 3. we batch the snapshot. // 3. we batch the snapshot.
let to_snapshot = self.get_kind(rtxn, Kind::SnapshotCreation)? & enqueued; let to_snapshot = self.get_kind(rtxn, Kind::SnapshotCreation)? & enqueued;
if !to_snapshot.is_empty() { if !to_snapshot.is_empty() {
return Ok(Some(( let mut tasks = self.get_existing_tasks(rtxn, to_snapshot)?;
Batch::SnapshotCreation( current_batch.processing(&mut tasks);
self.get_existing_tasks(rtxn, to_snapshot)? return Ok(Some((Batch::SnapshotCreation(tasks), current_batch)));
.into_iter()
.map(|task| task.with_batch_id(batch_id))
.collect(),
),
batch_id,
)));
} }
// 4. we batch the dumps. // 4. we batch the dumps.
let to_dump = self.get_kind(rtxn, Kind::DumpCreation)? & enqueued; let to_dump = self.get_kind(rtxn, Kind::DumpCreation)? & enqueued;
if let Some(to_dump) = to_dump.min() { if let Some(to_dump) = to_dump.min() {
return Ok(Some(( let mut task = self.get_task(rtxn, to_dump)?.ok_or(Error::CorruptedTaskQueue)?;
Batch::Dump( current_batch.processing(Some(&mut task));
self.get_task(rtxn, to_dump)? return Ok(Some((Batch::Dump(task), current_batch)));
.ok_or(Error::CorruptedTaskQueue)?
.with_batch_id(batch_id),
),
batch_id,
)));
} }
// 5. We make a batch from the unprioritised tasks. Start by taking the next enqueued task. // 5. We make a batch from the unprioritised tasks. Start by taking the next enqueued task.
let task_id = if let Some(task_id) = enqueued.min() { task_id } else { return Ok(None) }; let task_id = if let Some(task_id) = enqueued.min() { task_id } else { return Ok(None) };
let task = let mut task = self.get_task(rtxn, task_id)?.ok_or(Error::CorruptedTaskQueue)?;
self.get_task(rtxn, task_id)?.ok_or(Error::CorruptedTaskQueue)?.with_batch_id(batch_id); current_batch.processing(Some(&mut task));
// If the task is not associated with any index, verify that it is an index swap and // If the task is not associated with any index, verify that it is an index swap and
// create the batch directly. Otherwise, get the index name associated with the task // create the batch directly. Otherwise, get the index name associated with the task
@ -613,7 +613,7 @@ impl IndexScheduler {
index_name index_name
} else { } else {
assert!(matches!(&task.kind, KindWithContent::IndexSwap { swaps } if swaps.is_empty())); assert!(matches!(&task.kind, KindWithContent::IndexSwap { swaps } if swaps.is_empty()));
return Ok(Some((Batch::IndexSwap { task }, batch_id))); return Ok(Some((Batch::IndexSwap { task }, current_batch)));
}; };
let index_already_exists = self.index_mapper.exists(rtxn, index_name)?; let index_already_exists = self.index_mapper.exists(rtxn, index_name)?;
@ -649,10 +649,10 @@ impl IndexScheduler {
rtxn, rtxn,
index_name.to_string(), index_name.to_string(),
batchkind, batchkind,
batch_id, &mut current_batch,
create_index, create_index,
)? )?
.map(|batch| (batch, batch_id))); .map(|batch| (batch, current_batch)));
} }
// If we found no tasks then we were notified for something that got autobatched // If we found no tasks then we were notified for something that got autobatched

View File

@ -26,6 +26,7 @@ pub fn snapshot_index_scheduler(scheduler: &IndexScheduler) -> String {
env, env,
all_tasks, all_tasks,
all_batches, all_batches,
batch_to_tasks_mapping,
// task reverse index // task reverse index
status, status,
kind, kind,
@ -67,7 +68,10 @@ pub fn snapshot_index_scheduler(scheduler: &IndexScheduler) -> String {
let processing = processing_tasks.read().unwrap().clone(); let processing = processing_tasks.read().unwrap().clone();
snap.push_str(&format!("### Autobatching Enabled = {autobatching_enabled}\n")); snap.push_str(&format!("### Autobatching Enabled = {autobatching_enabled}\n"));
snap.push_str(&format!("### Processing batch {:?}:\n", processing.batch_id)); snap.push_str(&format!(
"### Processing batch {:?}:\n",
processing.batch.map(|batch| batch.uid)
));
snap.push_str(&snapshot_bitmap(&processing.processing)); snap.push_str(&snapshot_bitmap(&processing.processing));
snap.push_str("\n----------------------------------------------------------------------\n"); snap.push_str("\n----------------------------------------------------------------------\n");
@ -111,6 +115,10 @@ pub fn snapshot_index_scheduler(scheduler: &IndexScheduler) -> String {
snap.push_str(&snapshot_all_batches(&rtxn, *all_batches)); snap.push_str(&snapshot_all_batches(&rtxn, *all_batches));
snap.push_str("----------------------------------------------------------------------\n"); snap.push_str("----------------------------------------------------------------------\n");
snap.push_str("### Batch to tasks mapping:\n");
snap.push_str(&snapshot_batches_to_tasks_mappings(&rtxn, *batch_to_tasks_mapping));
snap.push_str("----------------------------------------------------------------------\n");
snap.push_str("### Batches Status:\n"); snap.push_str("### Batches Status:\n");
snap.push_str(&snapshot_status(&rtxn, *batch_status)); snap.push_str(&snapshot_status(&rtxn, *batch_status));
snap.push_str("----------------------------------------------------------------------\n"); snap.push_str("----------------------------------------------------------------------\n");
@ -186,6 +194,19 @@ pub fn snapshot_all_batches(rtxn: &RoTxn, db: Database<BEU32, SerdeJson<Batch>>)
snap snap
} }
pub fn snapshot_batches_to_tasks_mappings(
rtxn: &RoTxn,
db: Database<BEU32, CboRoaringBitmapCodec>,
) -> String {
let mut snap = String::new();
let iter = db.iter(rtxn).unwrap();
for next in iter {
let (batch_id, tasks) = next.unwrap();
snap.push_str(&format!("{batch_id} {}\n", snapshot_bitmap(&tasks)));
}
snap
}
pub fn snapshot_date_db(rtxn: &RoTxn, db: Database<BEI128, CboRoaringBitmapCodec>) -> String { pub fn snapshot_date_db(rtxn: &RoTxn, db: Database<BEI128, CboRoaringBitmapCodec>) -> String {
let mut snap = String::new(); let mut snap = String::new();
let iter = db.iter(rtxn).unwrap(); let iter = db.iter(rtxn).unwrap();

File diff suppressed because it is too large Load Diff

View File

@ -35,6 +35,8 @@ catto [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -47,6 +47,9 @@ catto: { number_of_documents: 1, field_distribution: {"id": 1} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -43,6 +43,9 @@ catto: { number_of_documents: 1, field_distribution: {"id": 1} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -46,6 +46,9 @@ catto: { number_of_documents: 1, field_distribution: {"id": 1} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -31,6 +31,8 @@ enqueued [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -34,6 +34,8 @@ enqueued [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -36,6 +36,8 @@ catto: { number_of_documents: 0, field_distribution: {} }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -35,6 +35,8 @@ catto [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -32,6 +32,8 @@ catto [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -32,6 +32,8 @@ catto [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -44,6 +44,10 @@ catto: { number_of_documents: 1, field_distribution: {"id": 1} }
0 {uid: 0, } 0 {uid: 0, }
1 {uid: 1, } 1 {uid: 1, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,] succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -37,6 +37,9 @@ catto: { number_of_documents: 1, field_distribution: {"id": 1} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ catto [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -67,6 +67,14 @@ girafos: { number_of_documents: 0, field_distribution: {} }
4 {uid: 4, } 4 {uid: 4, }
5 {uid: 5, } 5 {uid: 5, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
3 [3,]
4 [4,]
5 [5,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,3,4,5,] succeeded [0,1,2,3,4,5,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -37,6 +37,9 @@ doggos: { number_of_documents: 1, field_distribution: {"doggo": 1, "id": 1} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -40,6 +40,9 @@ doggos: { number_of_documents: 1, field_distribution: {"doggo": 1, "id": 1} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -35,6 +35,8 @@ doggos [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -43,6 +43,9 @@ doggos: { number_of_documents: 0, field_distribution: {} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -45,6 +45,10 @@ doggos [0,1,2,]
0 {uid: 0, } 0 {uid: 0, }
1 {uid: 1, } 1 {uid: 1, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,2,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,] succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -35,6 +35,8 @@ doggos [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -38,6 +38,8 @@ doggos [0,1,2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -35,6 +35,8 @@ doggos [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -39,6 +39,9 @@ doggos [0,1,]
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -39,6 +39,9 @@ doggos [0,1,]
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
failed [0,] failed [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -44,6 +44,10 @@ doggos: { number_of_documents: 3, field_distribution: {"catto": 1, "doggo": 2, "
0 {uid: 0, } 0 {uid: 0, }
1 {uid: 1, } 1 {uid: 1, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [1,] succeeded [1,]
failed [0,] failed [0,]

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -35,6 +35,8 @@ doggos [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -36,6 +36,9 @@ doggos [0,]
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
failed [0,] failed [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -43,6 +43,10 @@ doggos: { number_of_documents: 3, field_distribution: {"catto": 1, "doggo": 2, "
0 {uid: 0, } 0 {uid: 0, }
1 {uid: 1, } 1 {uid: 1, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,] succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -40,6 +40,9 @@ doggos: { number_of_documents: 0, field_distribution: {} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -56,6 +56,11 @@ doggos: { number_of_documents: 1, field_distribution: {"doggo": 1, "id": 1} }
1 {uid: 1, } 1 {uid: 1, }
2 {uid: 2, } 2 {uid: 2, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,3,4,5,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,] succeeded [0,1,2,]
failed [2,] failed [2,]

View File

@ -52,6 +52,10 @@ doggos: { number_of_documents: 3, field_distribution: {"catto": 1, "doggo": 2, "
0 {uid: 0, } 0 {uid: 0, }
1 {uid: 1, } 1 {uid: 1, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,] succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -35,6 +35,8 @@ doggos [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -32,6 +32,8 @@ catto [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -36,6 +36,9 @@ catto [0,]
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
failed [0,] failed [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -33,6 +33,8 @@ doggos: { number_of_documents: 1, field_distribution: {"doggo": 1, "id": 1} }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -33,6 +33,8 @@ doggos: { number_of_documents: 1, field_distribution: {"doggo": 1, "id": 1} }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -37,6 +37,9 @@ doggos: { number_of_documents: 1, field_distribution: {"doggo": 1, "id": 1} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -48,6 +48,11 @@ doggos: { number_of_documents: 1, field_distribution: {"_vectors": 1, "breed": 1
1 {uid: 1, } 1 {uid: 1, }
2 {uid: 2, } 2 {uid: 2, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,] succeeded [0,1,2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -45,6 +45,10 @@ doggos: { number_of_documents: 1, field_distribution: {"_vectors": 1, "breed": 1
0 {uid: 0, } 0 {uid: 0, }
1 {uid: 1, } 1 {uid: 1, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,] succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -43,6 +43,10 @@ doggos: { number_of_documents: 1, field_distribution: {"_vectors": 1, "breed": 1
0 {uid: 0, } 0 {uid: 0, }
1 {uid: 1, } 1 {uid: 1, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,] succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -40,6 +40,9 @@ doggos: { number_of_documents: 0, field_distribution: {} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -37,6 +37,9 @@ doggos: { number_of_documents: 0, field_distribution: {} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ index_a [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -32,6 +32,8 @@ index_a [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -35,6 +35,8 @@ index_b [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -38,6 +38,8 @@ index_b [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -36,6 +36,9 @@ catto [0,]
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
failed [0,] failed [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ catto [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -43,6 +43,9 @@ doggos: { number_of_documents: 0, field_distribution: {} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -47,6 +47,10 @@ doggos: { number_of_documents: 0, field_distribution: {} }
0 {uid: 0, } 0 {uid: 0, }
1 {uid: 1, } 1 {uid: 1, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,] succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -49,6 +49,11 @@ cattos: { number_of_documents: 0, field_distribution: {} }
1 {uid: 1, } 1 {uid: 1, }
2 {uid: 2, } 2 {uid: 2, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,] succeeded [0,1,2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -35,6 +35,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -38,6 +38,8 @@ doggos [0,2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -44,6 +44,9 @@ doggos: { number_of_documents: 0, field_distribution: {} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -53,6 +53,12 @@ doggos: { number_of_documents: 0, field_distribution: {} }
2 {uid: 2, } 2 {uid: 2, }
3 {uid: 3, } 3 {uid: 3, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
3 [3,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,3,] succeeded [0,1,2,3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ doggos [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -39,6 +39,8 @@ doggos [0,1,2,3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -35,6 +35,8 @@ doggos [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -37,6 +37,8 @@ doggos [0,1,2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -47,6 +47,10 @@ doggos: { number_of_documents: 0, field_distribution: {} }
0 {uid: 0, } 0 {uid: 0, }
1 {uid: 1, } 1 {uid: 1, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,] succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -50,6 +50,11 @@ doggos: { number_of_documents: 0, field_distribution: {} }
1 {uid: 1, } 1 {uid: 1, }
2 {uid: 2, } 2 {uid: 2, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,] succeeded [0,1,2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -0,0 +1,90 @@
---
source: crates/index-scheduler/src/lib.rs
---
### Autobatching Enabled = true
### Processing batch None:
[]
----------------------------------------------------------------------
### All Tasks:
0 {uid: 0, batch_uid: 0, status: succeeded, details: { primary_key: Some("bone") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("bone") }}
1 {uid: 1, batch_uid: 1, status: succeeded, details: { primary_key: Some("plankton") }, kind: IndexCreation { index_uid: "whalo", primary_key: Some("plankton") }}
2 {uid: 2, batch_uid: 2, status: succeeded, details: { primary_key: Some("his_own_vomit") }, kind: IndexCreation { index_uid: "catto", primary_key: Some("his_own_vomit") }}
----------------------------------------------------------------------
### Status:
enqueued []
succeeded [0,1,2,]
----------------------------------------------------------------------
### Kind:
"indexCreation" [0,1,2,]
----------------------------------------------------------------------
### Index Tasks:
catto [2,]
doggo [0,]
whalo [1,]
----------------------------------------------------------------------
### Index Mapper:
catto: { number_of_documents: 0, field_distribution: {} }
doggo: { number_of_documents: 0, field_distribution: {} }
whalo: { number_of_documents: 0, field_distribution: {} }
----------------------------------------------------------------------
### Canceled By:
----------------------------------------------------------------------
### Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### Started At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### Finished At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### All Batches:
0 {uid: 0, }
1 {uid: 1, }
2 {uid: 2, }
----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
----------------------------------------------------------------------
### Batches Status:
succeeded [0,1,2,]
----------------------------------------------------------------------
### Batches Kind:
"indexCreation" [0,1,2,]
----------------------------------------------------------------------
### Batches Index Tasks:
catto [2,]
doggo [0,]
whalo [1,]
----------------------------------------------------------------------
### Batches Canceled By:
----------------------------------------------------------------------
### Batches Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### Batches Started At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### Batches Finished At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### File Store:
----------------------------------------------------------------------

View File

@ -0,0 +1,54 @@
---
source: crates/index-scheduler/src/lib.rs
---
### Autobatching Enabled = true
### Processing batch None:
[]
----------------------------------------------------------------------
### All Tasks:
0 {uid: 0, status: enqueued, details: { primary_key: Some("bone") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("bone") }}
----------------------------------------------------------------------
### Status:
enqueued [0,]
----------------------------------------------------------------------
### Kind:
"indexCreation" [0,]
----------------------------------------------------------------------
### Index Tasks:
doggo [0,]
----------------------------------------------------------------------
### Index Mapper:
----------------------------------------------------------------------
### Canceled By:
----------------------------------------------------------------------
### Enqueued At:
[timestamp] [0,]
----------------------------------------------------------------------
### Started At:
----------------------------------------------------------------------
### Finished At:
----------------------------------------------------------------------
### All Batches:
----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status:
----------------------------------------------------------------------
### Batches Kind:
----------------------------------------------------------------------
### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
----------------------------------------------------------------------
### Batches Enqueued At:
----------------------------------------------------------------------
### Batches Started At:
----------------------------------------------------------------------
### Batches Finished At:
----------------------------------------------------------------------
### File Store:
----------------------------------------------------------------------

View File

@ -0,0 +1,57 @@
---
source: crates/index-scheduler/src/lib.rs
---
### Autobatching Enabled = true
### Processing batch None:
[]
----------------------------------------------------------------------
### All Tasks:
0 {uid: 0, status: enqueued, details: { primary_key: Some("bone") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("bone") }}
1 {uid: 1, status: enqueued, details: { primary_key: Some("plankton") }, kind: IndexCreation { index_uid: "whalo", primary_key: Some("plankton") }}
----------------------------------------------------------------------
### Status:
enqueued [0,1,]
----------------------------------------------------------------------
### Kind:
"indexCreation" [0,1,]
----------------------------------------------------------------------
### Index Tasks:
doggo [0,]
whalo [1,]
----------------------------------------------------------------------
### Index Mapper:
----------------------------------------------------------------------
### Canceled By:
----------------------------------------------------------------------
### Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
----------------------------------------------------------------------
### Started At:
----------------------------------------------------------------------
### Finished At:
----------------------------------------------------------------------
### All Batches:
----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status:
----------------------------------------------------------------------
### Batches Kind:
----------------------------------------------------------------------
### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
----------------------------------------------------------------------
### Batches Enqueued At:
----------------------------------------------------------------------
### Batches Started At:
----------------------------------------------------------------------
### Batches Finished At:
----------------------------------------------------------------------
### File Store:
----------------------------------------------------------------------

View File

@ -0,0 +1,60 @@
---
source: crates/index-scheduler/src/lib.rs
---
### Autobatching Enabled = true
### Processing batch None:
[]
----------------------------------------------------------------------
### All Tasks:
0 {uid: 0, status: enqueued, details: { primary_key: Some("bone") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("bone") }}
1 {uid: 1, status: enqueued, details: { primary_key: Some("plankton") }, kind: IndexCreation { index_uid: "whalo", primary_key: Some("plankton") }}
2 {uid: 2, status: enqueued, details: { primary_key: Some("his_own_vomit") }, kind: IndexCreation { index_uid: "catto", primary_key: Some("his_own_vomit") }}
----------------------------------------------------------------------
### Status:
enqueued [0,1,2,]
----------------------------------------------------------------------
### Kind:
"indexCreation" [0,1,2,]
----------------------------------------------------------------------
### Index Tasks:
catto [2,]
doggo [0,]
whalo [1,]
----------------------------------------------------------------------
### Index Mapper:
----------------------------------------------------------------------
### Canceled By:
----------------------------------------------------------------------
### Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### Started At:
----------------------------------------------------------------------
### Finished At:
----------------------------------------------------------------------
### All Batches:
----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status:
----------------------------------------------------------------------
### Batches Kind:
----------------------------------------------------------------------
### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
----------------------------------------------------------------------
### Batches Enqueued At:
----------------------------------------------------------------------
### Batches Started At:
----------------------------------------------------------------------
### Batches Finished At:
----------------------------------------------------------------------
### File Store:
----------------------------------------------------------------------

View File

@ -0,0 +1,91 @@
---
source: crates/index-scheduler/src/lib.rs
---
### 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: succeeded, details: { primary_key: Some("sheep") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("sheep") }}
2 {uid: 2, batch_uid: 2, status: failed, error: ResponseError { code: 200, message: "Planned failure for tests.", error_code: "internal", error_type: "internal", error_link: "https://docs.meilisearch.com/errors#internal" }, details: { primary_key: Some("fish") }, kind: IndexCreation { index_uid: "whalo", primary_key: Some("fish") }}
----------------------------------------------------------------------
### Status:
enqueued []
succeeded [0,1,]
failed [2,]
----------------------------------------------------------------------
### Kind:
"indexCreation" [0,1,2,]
----------------------------------------------------------------------
### Index Tasks:
catto [0,]
doggo [1,]
whalo [2,]
----------------------------------------------------------------------
### Index Mapper:
catto: { number_of_documents: 0, field_distribution: {} }
doggo: { number_of_documents: 0, field_distribution: {} }
----------------------------------------------------------------------
### Canceled By:
----------------------------------------------------------------------
### Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### Started At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### Finished At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### All Batches:
0 {uid: 0, }
1 {uid: 1, }
2 {uid: 2, }
----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
----------------------------------------------------------------------
### Batches Status:
succeeded [0,1,]
failed [2,]
----------------------------------------------------------------------
### Batches Kind:
"indexCreation" [0,1,2,]
----------------------------------------------------------------------
### Batches Index Tasks:
catto [0,]
doggo [1,]
whalo [2,]
----------------------------------------------------------------------
### Batches Canceled By:
----------------------------------------------------------------------
### Batches Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### Batches Started At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### Batches Finished At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### File Store:
----------------------------------------------------------------------

View File

@ -0,0 +1,60 @@
---
source: crates/index-scheduler/src/lib.rs
---
### Autobatching Enabled = true
### Processing batch None:
[]
----------------------------------------------------------------------
### All Tasks:
0 {uid: 0, status: enqueued, details: { primary_key: Some("mouse") }, kind: IndexCreation { index_uid: "catto", primary_key: Some("mouse") }}
1 {uid: 1, status: enqueued, details: { primary_key: Some("sheep") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("sheep") }}
2 {uid: 2, status: enqueued, details: { primary_key: Some("fish") }, kind: IndexCreation { index_uid: "whalo", primary_key: Some("fish") }}
----------------------------------------------------------------------
### Status:
enqueued [0,1,2,]
----------------------------------------------------------------------
### Kind:
"indexCreation" [0,1,2,]
----------------------------------------------------------------------
### Index Tasks:
catto [0,]
doggo [1,]
whalo [2,]
----------------------------------------------------------------------
### Index Mapper:
----------------------------------------------------------------------
### Canceled By:
----------------------------------------------------------------------
### Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
----------------------------------------------------------------------
### Started At:
----------------------------------------------------------------------
### Finished At:
----------------------------------------------------------------------
### All Batches:
----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status:
----------------------------------------------------------------------
### Batches Kind:
----------------------------------------------------------------------
### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
----------------------------------------------------------------------
### Batches Enqueued At:
----------------------------------------------------------------------
### Batches Started At:
----------------------------------------------------------------------
### Batches Finished At:
----------------------------------------------------------------------
### File Store:
----------------------------------------------------------------------

View File

@ -0,0 +1,102 @@
---
source: crates/index-scheduler/src/lib.rs
---
### 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: succeeded, details: { primary_key: Some("sheep") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("sheep") }}
2 {uid: 2, batch_uid: 2, status: failed, error: ResponseError { code: 200, message: "Planned failure for tests.", error_code: "internal", error_type: "internal", error_link: "https://docs.meilisearch.com/errors#internal" }, details: { swaps: [IndexSwap { indexes: ("catto", "doggo") }] }, kind: IndexSwap { swaps: [IndexSwap { indexes: ("catto", "doggo") }] }}
3 {uid: 3, batch_uid: 3, status: failed, error: ResponseError { code: 200, message: "Index `whalo` not found.", error_code: "index_not_found", error_type: "invalid_request", error_link: "https://docs.meilisearch.com/errors#index_not_found" }, details: { swaps: [IndexSwap { indexes: ("catto", "whalo") }] }, kind: IndexSwap { swaps: [IndexSwap { indexes: ("catto", "whalo") }] }}
----------------------------------------------------------------------
### Status:
enqueued []
succeeded [0,1,]
failed [2,3,]
----------------------------------------------------------------------
### Kind:
"indexCreation" [0,1,]
"indexSwap" [2,3,]
----------------------------------------------------------------------
### Index Tasks:
catto [0,2,3,]
doggo [1,2,]
whalo [3,]
----------------------------------------------------------------------
### Index Mapper:
catto: { number_of_documents: 0, field_distribution: {} }
doggo: { number_of_documents: 0, field_distribution: {} }
----------------------------------------------------------------------
### Canceled By:
----------------------------------------------------------------------
### Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
[timestamp] [3,]
----------------------------------------------------------------------
### Started At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
[timestamp] [3,]
----------------------------------------------------------------------
### Finished At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
[timestamp] [3,]
----------------------------------------------------------------------
### All Batches:
0 {uid: 0, }
1 {uid: 1, }
2 {uid: 2, }
3 {uid: 3, }
----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
3 [3,]
----------------------------------------------------------------------
### Batches Status:
succeeded [0,1,]
failed [2,3,]
----------------------------------------------------------------------
### Batches Kind:
"indexCreation" [0,1,]
"indexSwap" [2,3,]
----------------------------------------------------------------------
### Batches Index Tasks:
catto [0,2,3,]
doggo [1,2,]
whalo [3,]
----------------------------------------------------------------------
### Batches Canceled By:
----------------------------------------------------------------------
### Batches Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
[timestamp] [3,]
----------------------------------------------------------------------
### Batches Started At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
[timestamp] [3,]
----------------------------------------------------------------------
### Batches Finished At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
[timestamp] [3,]
----------------------------------------------------------------------
### File Store:
----------------------------------------------------------------------

View File

@ -0,0 +1,63 @@
---
source: crates/index-scheduler/src/lib.rs
---
### Autobatching Enabled = true
### Processing batch None:
[]
----------------------------------------------------------------------
### All Tasks:
0 {uid: 0, status: enqueued, details: { primary_key: Some("mouse") }, kind: IndexCreation { index_uid: "catto", primary_key: Some("mouse") }}
1 {uid: 1, status: enqueued, details: { primary_key: Some("sheep") }, kind: IndexCreation { index_uid: "doggo", primary_key: Some("sheep") }}
2 {uid: 2, status: enqueued, details: { swaps: [IndexSwap { indexes: ("catto", "doggo") }] }, kind: IndexSwap { swaps: [IndexSwap { indexes: ("catto", "doggo") }] }}
3 {uid: 3, status: enqueued, details: { swaps: [IndexSwap { indexes: ("catto", "whalo") }] }, kind: IndexSwap { swaps: [IndexSwap { indexes: ("catto", "whalo") }] }}
----------------------------------------------------------------------
### Status:
enqueued [0,1,2,3,]
----------------------------------------------------------------------
### Kind:
"indexCreation" [0,1,]
"indexSwap" [2,3,]
----------------------------------------------------------------------
### Index Tasks:
catto [0,2,3,]
doggo [1,2,]
whalo [3,]
----------------------------------------------------------------------
### Index Mapper:
----------------------------------------------------------------------
### Canceled By:
----------------------------------------------------------------------
### Enqueued At:
[timestamp] [0,]
[timestamp] [1,]
[timestamp] [2,]
[timestamp] [3,]
----------------------------------------------------------------------
### Started At:
----------------------------------------------------------------------
### Finished At:
----------------------------------------------------------------------
### All Batches:
----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status:
----------------------------------------------------------------------
### Batches Kind:
----------------------------------------------------------------------
### Batches Index Tasks:
----------------------------------------------------------------------
### Batches Canceled By:
----------------------------------------------------------------------
### Batches Enqueued At:
----------------------------------------------------------------------
### Batches Started At:
----------------------------------------------------------------------
### Batches Finished At:
----------------------------------------------------------------------
### File Store:
----------------------------------------------------------------------

View File

@ -51,6 +51,11 @@ whalo: { number_of_documents: 0, field_distribution: {} }
1 {uid: 1, } 1 {uid: 1, }
2 {uid: 2, } 2 {uid: 2, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,] succeeded [0,1,2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -32,6 +32,8 @@ doggo [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -35,6 +35,8 @@ whalo [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -38,6 +38,8 @@ whalo [1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -51,6 +51,11 @@ doggo: { number_of_documents: 0, field_distribution: {} }
1 {uid: 1, } 1 {uid: 1, }
2 {uid: 2, } 2 {uid: 2, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,] succeeded [0,1,]
failed [2,] failed [2,]

View File

@ -38,6 +38,8 @@ whalo [2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -41,6 +41,8 @@ whalo [3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -40,6 +40,8 @@ doggo [3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------
### All Batches: ### All Batches:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batches Kind: ### Batches Kind:

View File

@ -46,6 +46,9 @@ a: { number_of_documents: 0, field_distribution: {} }
### All Batches: ### All Batches:
0 {uid: 0, } 0 {uid: 0, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,] succeeded [0,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -50,6 +50,10 @@ b: { number_of_documents: 0, field_distribution: {} }
0 {uid: 0, } 0 {uid: 0, }
1 {uid: 1, } 1 {uid: 1, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,] succeeded [0,1,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -54,6 +54,11 @@ c: { number_of_documents: 0, field_distribution: {} }
1 {uid: 1, } 1 {uid: 1, }
2 {uid: 2, } 2 {uid: 2, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,] succeeded [0,1,2,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -58,6 +58,12 @@ d: { number_of_documents: 0, field_distribution: {} }
2 {uid: 2, } 2 {uid: 2, }
3 {uid: 3, } 3 {uid: 3, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
3 [3,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,3,] succeeded [0,1,2,3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -66,6 +66,13 @@ d: { number_of_documents: 0, field_distribution: {} }
3 {uid: 3, } 3 {uid: 3, }
4 {uid: 4, } 4 {uid: 4, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
3 [3,]
4 [4,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,3,4,] succeeded [0,1,2,3,4,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -61,6 +61,12 @@ d: { number_of_documents: 0, field_distribution: {} }
2 {uid: 2, } 2 {uid: 2, }
3 {uid: 3, } 3 {uid: 3, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
3 [3,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,3,] succeeded [0,1,2,3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -69,6 +69,14 @@ d: { number_of_documents: 0, field_distribution: {} }
4 {uid: 4, } 4 {uid: 4, }
5 {uid: 5, } 5 {uid: 5, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
3 [3,]
4 [4,]
5 [5,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,3,4,5,] succeeded [0,1,2,3,4,5,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -74,6 +74,15 @@ d: { number_of_documents: 0, field_distribution: {} }
5 {uid: 5, } 5 {uid: 5, }
6 {uid: 6, } 6 {uid: 6, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
3 [3,]
4 [4,]
5 [5,]
6 [6,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,3,4,5,6,] succeeded [0,1,2,3,4,5,6,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

View File

@ -63,6 +63,12 @@ d: { number_of_documents: 0, field_distribution: {} }
2 {uid: 2, } 2 {uid: 2, }
3 {uid: 3, } 3 {uid: 3, }
---------------------------------------------------------------------- ----------------------------------------------------------------------
### Batch to tasks mapping:
0 [0,]
1 [1,]
2 [2,]
3 [3,]
----------------------------------------------------------------------
### Batches Status: ### Batches Status:
succeeded [0,1,2,3,] succeeded [0,1,2,3,]
---------------------------------------------------------------------- ----------------------------------------------------------------------

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