use arrow::array::PrimitiveArray;
use polars_core::utils::split;
use polars_core::with_match_physical_float_polars_type;
use polars_utils::hashing::DirtyHash;
use polars_utils::nulls::IsNull;
use polars_utils::total_ord::{ToTotalOrd, TotalEq, TotalHash};
use super::*;
use crate::series::SeriesSealed;
pub trait SeriesJoin: SeriesSealed + Sized {
#[doc(hidden)]
fn hash_join_left(
&self,
other: &Series,
validate: JoinValidation,
join_nulls: bool,
) -> PolarsResult<LeftJoinIds> {
let s_self = self.as_series();
let (lhs, rhs) = (s_self.to_physical_repr(), other.to_physical_repr());
validate.validate_probe(&lhs, &rhs, false)?;
use DataType::*;
match lhs.dtype() {
String | Binary => {
let lhs = lhs.cast(&Binary).unwrap();
let rhs = rhs.cast(&Binary).unwrap();
let lhs = lhs.binary().unwrap();
let rhs = rhs.binary().unwrap();
let (lhs, rhs, _, _) = prepare_binary::<BinaryType>(lhs, rhs, false);
let lhs = lhs.iter().map(|v| v.as_slice()).collect::<Vec<_>>();
let rhs = rhs.iter().map(|v| v.as_slice()).collect::<Vec<_>>();
hash_join_tuples_left(lhs, rhs, None, None, validate, join_nulls)
},
BinaryOffset => {
let lhs = lhs.binary_offset().unwrap();
let rhs = rhs.binary_offset().unwrap();
let (lhs, rhs, _, _) = prepare_binary::<BinaryOffsetType>(lhs, rhs, false);
let lhs = lhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
let rhs = rhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
hash_join_tuples_left(lhs, rhs, None, None, validate, join_nulls)
},
_ => {
if lhs.dtype().is_float() {
with_match_physical_float_polars_type!(lhs.dtype(), |$T| {
let lhs: &ChunkedArray<$T> = lhs.as_ref().as_ref().as_ref();
let rhs: &ChunkedArray<$T> = rhs.as_ref().as_ref().as_ref();
num_group_join_left(lhs, rhs, validate, join_nulls)
})
} else if s_self.bit_repr_is_large() {
let lhs = lhs.bit_repr_large();
let rhs = rhs.bit_repr_large();
num_group_join_left(&lhs, &rhs, validate, join_nulls)
} else {
let lhs = lhs.bit_repr_small();
let rhs = rhs.bit_repr_small();
num_group_join_left(&lhs, &rhs, validate, join_nulls)
}
},
}
}
#[cfg(feature = "semi_anti_join")]
fn hash_join_semi_anti(&self, other: &Series, anti: bool, join_nulls: bool) -> Vec<IdxSize> {
let s_self = self.as_series();
let (lhs, rhs) = (s_self.to_physical_repr(), other.to_physical_repr());
use DataType::*;
match lhs.dtype() {
String | Binary => {
let lhs = lhs.cast(&Binary).unwrap();
let rhs = rhs.cast(&Binary).unwrap();
let lhs = lhs.binary().unwrap();
let rhs = rhs.binary().unwrap();
let (lhs, rhs, _, _) = prepare_binary::<BinaryType>(lhs, rhs, false);
let lhs = lhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
let rhs = rhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
if anti {
hash_join_tuples_left_anti(lhs, rhs, join_nulls)
} else {
hash_join_tuples_left_semi(lhs, rhs, join_nulls)
}
},
BinaryOffset => {
let lhs = lhs.binary_offset().unwrap();
let rhs = rhs.binary_offset().unwrap();
let (lhs, rhs, _, _) = prepare_binary::<BinaryOffsetType>(lhs, rhs, false);
let lhs = lhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
let rhs = rhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
if anti {
hash_join_tuples_left_anti(lhs, rhs, join_nulls)
} else {
hash_join_tuples_left_semi(lhs, rhs, join_nulls)
}
},
_ => {
if lhs.dtype().is_float() {
with_match_physical_float_polars_type!(lhs.dtype(), |$T| {
let lhs: &ChunkedArray<$T> = lhs.as_ref().as_ref().as_ref();
let rhs: &ChunkedArray<$T> = rhs.as_ref().as_ref().as_ref();
num_group_join_anti_semi(lhs, rhs, anti, join_nulls)
})
} else if s_self.bit_repr_is_large() {
let lhs = lhs.bit_repr_large();
let rhs = rhs.bit_repr_large();
num_group_join_anti_semi(&lhs, &rhs, anti, join_nulls)
} else {
let lhs = lhs.bit_repr_small();
let rhs = rhs.bit_repr_small();
num_group_join_anti_semi(&lhs, &rhs, anti, join_nulls)
}
},
}
}
fn hash_join_inner(
&self,
other: &Series,
validate: JoinValidation,
join_nulls: bool,
) -> PolarsResult<(InnerJoinIds, bool)> {
let s_self = self.as_series();
let (lhs, rhs) = (s_self.to_physical_repr(), other.to_physical_repr());
validate.validate_probe(&lhs, &rhs, true)?;
use DataType::*;
match lhs.dtype() {
String | Binary => {
let lhs = lhs.cast(&Binary).unwrap();
let rhs = rhs.cast(&Binary).unwrap();
let lhs = lhs.binary().unwrap();
let rhs = rhs.binary().unwrap();
let (lhs, rhs, swapped, _) = prepare_binary::<BinaryType>(lhs, rhs, true);
let lhs = lhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
let rhs = rhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
Ok((
hash_join_tuples_inner(lhs, rhs, swapped, validate, join_nulls)?,
!swapped,
))
},
BinaryOffset => {
let lhs = lhs.binary_offset().unwrap();
let rhs = rhs.binary_offset()?;
let (lhs, rhs, swapped, _) = prepare_binary::<BinaryOffsetType>(lhs, rhs, true);
let lhs = lhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
let rhs = rhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
Ok((
hash_join_tuples_inner(lhs, rhs, swapped, validate, join_nulls)?,
!swapped,
))
},
_ => {
if lhs.dtype().is_float() {
with_match_physical_float_polars_type!(lhs.dtype(), |$T| {
let lhs: &ChunkedArray<$T> = lhs.as_ref().as_ref().as_ref();
let rhs: &ChunkedArray<$T> = rhs.as_ref().as_ref().as_ref();
group_join_inner::<$T>(lhs, rhs, validate, join_nulls)
})
} else if s_self.bit_repr_is_large() {
let lhs = s_self.bit_repr_large();
let rhs = other.bit_repr_large();
group_join_inner::<UInt64Type>(&lhs, &rhs, validate, join_nulls)
} else {
let lhs = s_self.bit_repr_small();
let rhs = other.bit_repr_small();
group_join_inner::<UInt32Type>(&lhs, &rhs, validate, join_nulls)
}
},
}
}
fn hash_join_outer(
&self,
other: &Series,
validate: JoinValidation,
join_nulls: bool,
) -> PolarsResult<(PrimitiveArray<IdxSize>, PrimitiveArray<IdxSize>)> {
let s_self = self.as_series();
let (lhs, rhs) = (s_self.to_physical_repr(), other.to_physical_repr());
validate.validate_probe(&lhs, &rhs, true)?;
use DataType::*;
match lhs.dtype() {
String | Binary => {
let lhs = lhs.cast(&Binary).unwrap();
let rhs = rhs.cast(&Binary).unwrap();
let lhs = lhs.binary().unwrap();
let rhs = rhs.binary().unwrap();
let (lhs, rhs, swapped, _) = prepare_binary::<BinaryType>(lhs, rhs, true);
let lhs = lhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
let rhs = rhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
hash_join_tuples_outer(lhs, rhs, swapped, validate, join_nulls)
},
BinaryOffset => {
let lhs = lhs.binary_offset().unwrap();
let rhs = rhs.binary_offset()?;
let (lhs, rhs, swapped, _) = prepare_binary::<BinaryOffsetType>(lhs, rhs, true);
let lhs = lhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
let rhs = rhs.iter().map(|k| k.as_slice()).collect::<Vec<_>>();
hash_join_tuples_outer(lhs, rhs, swapped, validate, join_nulls)
},
_ => {
if lhs.dtype().is_float() {
with_match_physical_float_polars_type!(lhs.dtype(), |$T| {
let lhs: &ChunkedArray<$T> = lhs.as_ref().as_ref().as_ref();
let rhs: &ChunkedArray<$T> = rhs.as_ref().as_ref().as_ref();
hash_join_outer(lhs, rhs, validate, join_nulls)
})
} else if s_self.bit_repr_is_large() {
let lhs = s_self.bit_repr_large();
let rhs = other.bit_repr_large();
hash_join_outer(&lhs, &rhs, validate, join_nulls)
} else {
let lhs = s_self.bit_repr_small();
let rhs = other.bit_repr_small();
hash_join_outer(&lhs, &rhs, validate, join_nulls)
}
},
}
}
}
impl SeriesJoin for Series {}
fn chunks_as_slices<T>(splitted: &[ChunkedArray<T>]) -> Vec<&[T::Native]>
where
T: PolarsNumericType,
{
splitted
.iter()
.flat_map(|ca| ca.downcast_iter().map(|arr| arr.values().as_slice()))
.collect()
}
fn get_arrays<T: PolarsDataType>(cas: &[ChunkedArray<T>]) -> Vec<&T::Array> {
cas.iter().flat_map(|arr| arr.downcast_iter()).collect()
}
fn group_join_inner<T>(
left: &ChunkedArray<T>,
right: &ChunkedArray<T>,
validate: JoinValidation,
join_nulls: bool,
) -> PolarsResult<(InnerJoinIds, bool)>
where
T: PolarsDataType,
for<'a> &'a T::Array: IntoIterator<Item = Option<&'a T::Physical<'a>>>,
for<'a> T::Physical<'a>:
Send + Sync + Copy + TotalHash + TotalEq + DirtyHash + IsNull + ToTotalOrd,
for<'a> <T::Physical<'a> as ToTotalOrd>::TotalOrdItem:
Send + Sync + Copy + Hash + Eq + DirtyHash + IsNull,
{
let n_threads = POOL.current_num_threads();
let (a, b, swapped) = det_hash_prone_order!(left, right);
let splitted_a = split(a, n_threads);
let splitted_b = split(b, n_threads);
let splitted_a = get_arrays(&splitted_a);
let splitted_b = get_arrays(&splitted_b);
match (left.null_count(), right.null_count()) {
(0, 0) => {
let first = &splitted_a[0];
if first.as_slice().is_some() {
let splitted_a = splitted_a
.iter()
.map(|arr| arr.as_slice().unwrap())
.collect::<Vec<_>>();
let splitted_b = splitted_b
.iter()
.map(|arr| arr.as_slice().unwrap())
.collect::<Vec<_>>();
Ok((
hash_join_tuples_inner(splitted_a, splitted_b, swapped, validate, join_nulls)?,
!swapped,
))
} else {
Ok((
hash_join_tuples_inner(splitted_a, splitted_b, swapped, validate, join_nulls)?,
!swapped,
))
}
},
_ => Ok((
hash_join_tuples_inner(splitted_a, splitted_b, swapped, validate, join_nulls)?,
!swapped,
)),
}
}
#[cfg(feature = "chunked_ids")]
fn create_mappings(
chunks_left: &[ArrayRef],
chunks_right: &[ArrayRef],
left_len: usize,
right_len: usize,
) -> (Option<Vec<ChunkId>>, Option<Vec<ChunkId>>) {
let mapping_left = || {
if chunks_left.len() > 1 {
Some(create_chunked_index_mapping(chunks_left, left_len))
} else {
None
}
};
let mapping_right = || {
if chunks_right.len() > 1 {
Some(create_chunked_index_mapping(chunks_right, right_len))
} else {
None
}
};
POOL.join(mapping_left, mapping_right)
}
#[cfg(not(feature = "chunked_ids"))]
fn create_mappings(
_chunks_left: &[ArrayRef],
_chunks_right: &[ArrayRef],
_left_len: usize,
_right_len: usize,
) -> (Option<Vec<ChunkId>>, Option<Vec<ChunkId>>) {
(None, None)
}
fn num_group_join_left<T>(
left: &ChunkedArray<T>,
right: &ChunkedArray<T>,
validate: JoinValidation,
join_nulls: bool,
) -> PolarsResult<LeftJoinIds>
where
T: PolarsNumericType,
T::Native: TotalHash + TotalEq + DirtyHash + IsNull + ToTotalOrd,
<T::Native as ToTotalOrd>::TotalOrdItem: Send + Sync + Copy + Hash + Eq + DirtyHash + IsNull,
T::Native: DirtyHash + Copy + ToTotalOrd,
<Option<T::Native> as ToTotalOrd>::TotalOrdItem: Send + Sync + DirtyHash,
{
let n_threads = POOL.current_num_threads();
let splitted_a = split(left, n_threads);
let splitted_b = split(right, n_threads);
match (
left.null_count(),
right.null_count(),
left.chunks().len(),
right.chunks().len(),
) {
(0, 0, 1, 1) => {
let keys_a = chunks_as_slices(&splitted_a);
let keys_b = chunks_as_slices(&splitted_b);
hash_join_tuples_left(keys_a, keys_b, None, None, validate, join_nulls)
},
(0, 0, _, _) => {
let keys_a = chunks_as_slices(&splitted_a);
let keys_b = chunks_as_slices(&splitted_b);
let (mapping_left, mapping_right) =
create_mappings(left.chunks(), right.chunks(), left.len(), right.len());
hash_join_tuples_left(
keys_a,
keys_b,
mapping_left.as_deref(),
mapping_right.as_deref(),
validate,
join_nulls,
)
},
_ => {
let keys_a = get_arrays(&splitted_a);
let keys_b = get_arrays(&splitted_b);
let (mapping_left, mapping_right) =
create_mappings(left.chunks(), right.chunks(), left.len(), right.len());
hash_join_tuples_left(
keys_a,
keys_b,
mapping_left.as_deref(),
mapping_right.as_deref(),
validate,
join_nulls,
)
},
}
}
fn hash_join_outer<T>(
ca_in: &ChunkedArray<T>,
other: &ChunkedArray<T>,
validate: JoinValidation,
join_nulls: bool,
) -> PolarsResult<(PrimitiveArray<IdxSize>, PrimitiveArray<IdxSize>)>
where
T: PolarsNumericType,
T::Native: TotalHash + TotalEq + ToTotalOrd,
<T::Native as ToTotalOrd>::TotalOrdItem: Send + Sync + Copy + Hash + Eq + IsNull,
{
let (a, b, swapped) = det_hash_prone_order!(ca_in, other);
let n_partitions = _set_partition_size();
let splitted_a = split(a, n_partitions);
let splitted_b = split(b, n_partitions);
match (a.null_count(), b.null_count()) {
(0, 0) => {
let iters_a = splitted_a
.iter()
.flat_map(|ca| ca.downcast_iter().map(|arr| arr.values().as_slice()))
.collect::<Vec<_>>();
let iters_b = splitted_b
.iter()
.flat_map(|ca| ca.downcast_iter().map(|arr| arr.values().as_slice()))
.collect::<Vec<_>>();
hash_join_tuples_outer(iters_a, iters_b, swapped, validate, join_nulls)
},
_ => {
let iters_a = splitted_a
.iter()
.flat_map(|ca| ca.downcast_iter().map(|arr| arr.iter()))
.collect::<Vec<_>>();
let iters_b = splitted_b
.iter()
.flat_map(|ca| ca.downcast_iter().map(|arr| arr.iter()))
.collect::<Vec<_>>();
hash_join_tuples_outer(iters_a, iters_b, swapped, validate, join_nulls)
},
}
}
#[cfg(feature = "asof_join")]
pub fn prepare_bytes<'a>(
been_split: &'a [BinaryChunked],
hb: &RandomState,
) -> Vec<Vec<BytesHash<'a>>> {
POOL.install(|| {
been_split
.par_iter()
.map(|ca| {
ca.iter()
.map(|opt_b| {
let hash = hb.hash_one(opt_b);
BytesHash::new(opt_b, hash)
})
.collect::<Vec<_>>()
})
.collect()
})
}
fn prepare_binary<'a, T>(
ca: &'a ChunkedArray<T>,
other: &'a ChunkedArray<T>,
build_shortest_table: bool,
) -> (
Vec<Vec<BytesHash<'a>>>,
Vec<Vec<BytesHash<'a>>>,
bool,
RandomState,
)
where
T: PolarsDataType,
for<'b> <T::Array as StaticArray>::ValueT<'b>: AsRef<[u8]>,
{
let (a, b, swapped) = if build_shortest_table {
det_hash_prone_order!(ca, other)
} else {
(ca, other, false)
};
let hb = RandomState::default();
let bh_a = a.to_bytes_hashes(true, hb.clone());
let bh_b = b.to_bytes_hashes(true, hb.clone());
(bh_a, bh_b, swapped, hb)
}
#[cfg(feature = "semi_anti_join")]
fn num_group_join_anti_semi<T>(
left: &ChunkedArray<T>,
right: &ChunkedArray<T>,
anti: bool,
join_nulls: bool,
) -> Vec<IdxSize>
where
T: PolarsNumericType,
T::Native: TotalHash + TotalEq + DirtyHash + ToTotalOrd,
<T::Native as ToTotalOrd>::TotalOrdItem: Send + Sync + Copy + Hash + Eq + DirtyHash + IsNull,
<Option<T::Native> as ToTotalOrd>::TotalOrdItem: Send + Sync + DirtyHash + IsNull,
{
let n_threads = POOL.current_num_threads();
let splitted_a = split(left, n_threads);
let splitted_b = split(right, n_threads);
match (
left.null_count(),
right.null_count(),
left.chunks().len(),
right.chunks().len(),
) {
(0, 0, 1, 1) => {
let keys_a = chunks_as_slices(&splitted_a);
let keys_b = chunks_as_slices(&splitted_b);
if anti {
hash_join_tuples_left_anti(keys_a, keys_b, join_nulls)
} else {
hash_join_tuples_left_semi(keys_a, keys_b, join_nulls)
}
},
(0, 0, _, _) => {
let keys_a = chunks_as_slices(&splitted_a);
let keys_b = chunks_as_slices(&splitted_b);
if anti {
hash_join_tuples_left_anti(keys_a, keys_b, join_nulls)
} else {
hash_join_tuples_left_semi(keys_a, keys_b, join_nulls)
}
},
_ => {
let keys_a = get_arrays(&splitted_a);
let keys_b = get_arrays(&splitted_b);
if anti {
hash_join_tuples_left_anti(keys_a, keys_b, join_nulls)
} else {
hash_join_tuples_left_semi(keys_a, keys_b, join_nulls)
}
},
}
}