Delex
Delex
Index
Index
A
|
B
|
C
|
D
|
E
|
F
|
G
|
H
|
I
|
J
|
K
|
L
|
M
|
N
|
O
|
P
|
Q
|
R
|
S
|
T
|
U
|
V
|
W
A
add_in_edge() (delex.graph.node.Node method)
add_out_edge() (delex.graph.node.Node method)
AlphaNumericTokenizer (class in delex.tokenizer)
ancestors() (delex.graph.node.Node method)
apply() (delex.execution.dataframe_stream.DataFrameStream method)
arrays_to_encoded_sparse_vector() (delex.storage.vector_store.MemmapVectorStore static method)
attach_current_thread_jvm() (in module delex.utils.funcs)
B
base_tokenize() (delex.tokenizer.ShingleTokenizer method)
BlockingProgram (class in delex.lang.program)
BlockingProgramOptimizer (class in delex.execution.optimizer)
BM25TopkPredicate (class in delex.lang.predicate.topk_predicate)
BM25TopkPredicate.Sim (class in delex.lang.predicate.topk_predicate)
BootlegPredicate (class in delex.lang.predicate.bootleg_predicate)
BootlegSim (class in delex.lang.predicate.bootleg_predicate)
build() (delex.graph.node.Node method)
(delex.graph.node.PredicateNode method)
(delex.graph.node.SetOpNode method)
(delex.index.filtered_set_sim_index.FilteredSetSimIndex method)
(delex.index.hash_index.HashIndex method)
(delex.lang.predicate.bootleg_predicate.BootlegPredicate method)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate method)
(delex.lang.predicate.predicate.Predicate method)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate method)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate method)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate method)
(delex.storage.hash_map.id_int_map.IdOffsetHashMap class method)
(delex.storage.hash_map.string_int_map.StringIntHashMap class method)
(delex.storage.memmap_seqs.MemmapSeqs class method)
(delex.storage.sorted_set.MemmapSortedSets class method)
(delex.storage.string_store.MemmapStrings class method)
(delex.storage.vector_store.MemmapVectorStore class method)
(delex.tokenizer.Tokenizer method)
build_parallelism (delex.execution.graph_executor.GraphExecutor attribute)
build_time (delex.execution.graph_executor.GraphExecutionStats property)
(delex.execution.graph_executor.PartitionExecutionStats attribute)
(delex.execution.graph_executor.SubGraphExecutionStats property)
build_time() (delex.execution.cost_estimation.CostEstimator method)
BuildCache (class in delex.utils.build_cache)
C
CachedBM25IndexKey (class in delex.lang.predicate.topk_predicate)
CachedNameIndexKey (class in delex.lang.predicate.bootleg_predicate)
CachedNamesKey (class in delex.lang.predicate.bootleg_predicate)
CachedObjectKey (class in delex.utils.build_cache)
CacheItem (class in delex.utils.build_cache)
class_type (delex.index.filtered_set_sim_index_slice.CosineSetSimIndexSlice attribute)
(delex.index.filtered_set_sim_index_slice.JaccardSetSimIndexSlice attribute)
(delex.index.set_sim_index.SetSimIndexSlice attribute)
clone_graph() (in module delex.graph.algorithms)
column (delex.execution.partitioner.DataFramePartitioner attribute)
compute_estimates() (delex.execution.cost_estimation.CostEstimator method)
compute_scores() (delex.lang.predicate.bootleg_predicate.BootlegPredicate method)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate method)
(delex.lang.predicate.set_sim_predicate.CosinePredicate method)
(delex.lang.predicate.set_sim_predicate.JaccardPredicate method)
(delex.lang.predicate.set_sim_predicate.OverlapCoeffPredicate method)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate method)
(delex.lang.predicate.threshold_predicate.ThresholdPredicate method)
contains() (delex.lang.predicate.bootleg_predicate.BootlegPredicate method)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate method)
(delex.lang.predicate.predicate.Predicate method)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate method)
(delex.lang.predicate.string_sim_predicate.JaroWinklerPredicate method)
(delex.lang.predicate.string_sim_predicate.SmithWatermanPredicate method)
(delex.lang.predicate.threshold_predicate.ThresholdPredicate method)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate method)
(delex.lang.rule.Rule method)
cosine() (delex.storage.sorted_set.MemmapSortedSets method)
cosine_threshold() (delex.index.set_sim_index.SetSimIndex method)
CosinePredicate (class in delex.lang.predicate.set_sim_predicate)
CosineSetSimIndexSlice (class in delex.index.filtered_set_sim_index_slice)
cost_est (delex.execution.graph_executor.GraphExecutor attribute)
cost_estimation_time (delex.execution.plan_executor.PlanExecutionStats attribute)
CostEstimator (class in delex.execution.cost_estimation)
create_span_map() (in module delex.storage.span_map)
D
DataFramePartitioner (class in delex.execution.partitioner)
DataFrameStream (class in delex.execution.dataframe_stream)
decode_sparse_vector() (delex.storage.vector_store.MemmapVectorStore static method)
default_plan() (delex.execution.optimizer.BlockingProgramOptimizer method)
deinit() (delex.index.filtered_set_sim_index.FilteredSetSimIndex method)
(delex.index.hash_index.HashIndex method)
(delex.lang.predicate.bootleg_predicate.BootlegPredicate method)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate method)
(delex.lang.predicate.predicate.Predicate method)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate method)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate method)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate method)
(delex.storage.hash_map.hash_map_base.DistributableHashMap method)
(delex.storage.memmap_arr.MemmapArray method)
(delex.storage.memmap_seqs.MemmapSeqs method)
(delex.storage.packed_memmap_arrs.PackedMemmapArrays method)
(delex.tokenizer.Tokenizer method)
(delex.utils.traits.SparkDistributable method)
delete() (delex.storage.memmap_arr.MemmapArray method)
(delex.storage.memmap_seqs.MemmapSeqs method)
(delex.storage.packed_memmap_arrs.PackedMemmapArrays method)
delex
module
delex.execution
module
delex.execution.cost_estimation
module
delex.execution.dataframe_stream
module
delex.execution.graph_executor
module
delex.execution.optimizer
module
delex.execution.partitioner
module
delex.execution.plan_executor
module
delex.graph
module
delex.graph.algorithms
module
delex.graph.node
module
delex.graph.utils
module
delex.index
module
delex.index.filtered_set_sim_index
module
delex.index.filtered_set_sim_index_slice
module
delex.index.hash_index
module
delex.index.set_sim_index
module
delex.lang
module
delex.lang.predicate
module
delex.lang.predicate.bootleg_predicate
module
delex.lang.predicate.exact_match_predicate
module
delex.lang.predicate.name_map
module
delex.lang.predicate.predicate
module
delex.lang.predicate.set_sim_predicate
module
delex.lang.predicate.string_sim_predicate
module
delex.lang.predicate.threshold_predicate
module
delex.lang.predicate.topk_predicate
module
delex.lang.program
module
delex.lang.rule
module
delex.storage
module
delex.storage.hash_map
module
delex.storage.hash_map.hash_map_base
module
delex.storage.hash_map.id_int_map
module
delex.storage.hash_map.string_int_map
module
delex.storage.memmap_arr
module
delex.storage.memmap_seqs
module
delex.storage.packed_memmap_arrs
module
delex.storage.sorted_set
module
delex.storage.span_map
module
delex.storage.string_store
module
delex.storage.vector_store
module
delex.tokenizer
module
delex.utils
module
delex.utils.build_cache
module
delex.utils.funcs
module
delex.utils.hash_function
module
delex.utils.numba_functions
module
delex.utils.traits
module
DistributableHashMap (class in delex.storage.hash_map.hash_map_base)
dot() (delex.storage.vector_store.MemmapVectorStore method)
dot_graph (delex.execution.graph_executor.GraphExecutionStats attribute)
drop() (delex.execution.dataframe_stream.DataFrameStream method)
drop_rules (delex.lang.program.BlockingProgram attribute)
DropRule (class in delex.lang.rule)
E
EditDistancePredicate (class in delex.lang.predicate.string_sim_predicate)
equivalent() (delex.graph.node.Node method)
estimate_cost (delex.execution.plan_executor.PlanExecutor attribute)
estimate_plan_cost() (delex.execution.cost_estimation.CostEstimator method)
ExactMatchPredicate (class in delex.lang.predicate.exact_match_predicate)
ExactMatchPredicate.Sim (class in delex.lang.predicate.exact_match_predicate)
exec_time (delex.execution.graph_executor.GraphExecutionStats property)
(delex.execution.graph_executor.PartitionExecutionStats attribute)
(delex.execution.graph_executor.SubGraphExecutionStats property)
execute() (delex.execution.graph_executor.GraphExecutor method)
(delex.execution.plan_executor.PlanExecutor method)
(delex.graph.node.Node method)
(delex.graph.node.PredicateNode method)
(delex.graph.node.SetOpNode method)
F
fetch() (delex.index.hash_index.HashIndex method)
(delex.storage.memmap_seqs.MemmapSeqs method)
(delex.storage.string_store.MemmapStrings method)
(delex.storage.vector_store.MemmapVectorStore method)
fetch_bytes() (delex.storage.string_store.MemmapStrings method)
filter() (delex.lang.predicate.predicate.Predicate method)
filter_array() (delex.execution.partitioner.DataFramePartitioner method)
filter_batch() (delex.lang.predicate.predicate.Predicate method)
(delex.lang.predicate.threshold_predicate.ThresholdPredicate method)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate method)
filter_time() (delex.execution.cost_estimation.CostEstimator method)
FilteredSetSimIndex (class in delex.index.filtered_set_sim_index)
FilteredSetSimIndex.CacheKey (class in delex.index.filtered_set_sim_index)
FilteredSetSimIndexSlice (class in delex.index.filtered_set_sim_index_slice)
find_all_nodes() (in module delex.graph.algorithms)
find_sink() (in module delex.graph.algorithms)
fit() (delex.execution.cost_estimation.ScalingModel class method)
from_arrow_iter() (delex.execution.dataframe_stream.DataFrameStream class method)
from_pandas_iter() (delex.execution.dataframe_stream.DataFrameStream class method)
from_sparse_mat() (delex.index.filtered_set_sim_index.FilteredSetSimIndex class method)
(delex.index.set_sim_index.SetSimIndex class method)
G
gap_cost (delex.lang.predicate.string_sim_predicate.SmithWatermanPredicate.Sim attribute)
generate_plan() (delex.execution.plan_executor.PlanExecutor method)
get() (delex.utils.build_cache.BuildCache method)
get_logger() (in module delex.utils.funcs)
get_partition() (delex.execution.partitioner.DataFramePartitioner method)
graph_exec_stats (delex.execution.plan_executor.PlanExecutionStats attribute)
GraphExecutionStats (class in delex.execution.graph_executor)
GraphExecutor (class in delex.execution.graph_executor)
H
hash() (delex.utils.hash_function.HashFunction method)
hash_map_get_key() (in module delex.storage.hash_map.id_int_map)
hash_map_get_keys() (in module delex.storage.hash_map.id_int_map)
hash_map_insert_key() (in module delex.storage.hash_map.id_int_map)
hash_map_insert_keys() (in module delex.storage.hash_map.id_int_map)
hash_split() (delex.utils.hash_function.HashFunction method)
HashFunction (class in delex.utils.hash_function)
HashIndex (class in delex.index.hash_index)
HashIndex.CacheKey (class in delex.index.hash_index)
human_format_bytes() (in module delex.utils.funcs)
I
id_string (delex.graph.node.Node property)
IdOffsetHashMap (class in delex.storage.hash_map.id_int_map)
in_degree (delex.graph.node.Node property)
index_col (delex.index.filtered_set_sim_index.FilteredSetSimIndex.CacheKey attribute)
(delex.index.hash_index.HashIndex.CacheKey attribute)
(delex.lang.predicate.bootleg_predicate.BootlegPredicate property)
(delex.lang.predicate.bootleg_predicate.BootlegSim attribute)
(delex.lang.predicate.bootleg_predicate.CachedNameIndexKey attribute)
(delex.lang.predicate.bootleg_predicate.CachedNamesKey attribute)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate property)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate.Sim attribute)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate.Sim attribute)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate.Sim attribute)
(delex.lang.predicate.threshold_predicate.ThresholdPredicate property)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate property)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate.Sim attribute)
(delex.lang.predicate.topk_predicate.CachedBM25IndexKey attribute)
(delex.storage.sorted_set.MemmapSortedSets.CacheKey attribute)
(delex.storage.string_store.MemmapStrings.CacheKey attribute)
(delex.storage.vector_store.MemmapVectorStore.CacheKey attribute)
(delex.tokenizer.Tokenizer.CacheKey attribute)
index_component_sizes() (delex.lang.predicate.bootleg_predicate.BootlegPredicate method)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate method)
(delex.lang.predicate.predicate.Predicate method)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate method)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate method)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate method)
index_size_in_bytes() (delex.lang.predicate.bootleg_predicate.BootlegPredicate method)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate method)
(delex.lang.predicate.predicate.Predicate method)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate method)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate method)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate method)
index_table (delex.execution.graph_executor.GraphExecutor attribute)
index_table_count (delex.execution.graph_executor.GraphExecutor property)
index_table_id_col (delex.execution.graph_executor.GraphExecutor attribute)
indexable (delex.lang.predicate.bootleg_predicate.BootlegPredicate property)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate property)
(delex.lang.predicate.predicate.Predicate property)
(delex.lang.predicate.set_sim_predicate.OverlapCoeffPredicate property)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate property)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate property)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate property)
init() (delex.graph.node.PredicateNode method)
(delex.graph.node.SetOpNode method)
(delex.index.filtered_set_sim_index.FilteredSetSimIndex method)
(delex.index.hash_index.HashIndex method)
(delex.index.set_sim_index.SetSimIndex method)
(delex.lang.predicate.bootleg_predicate.BootlegPredicate method)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate method)
(delex.lang.predicate.predicate.Predicate method)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate method)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate method)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate method)
(delex.storage.hash_map.hash_map_base.DistributableHashMap method)
(delex.storage.memmap_arr.MemmapArray method)
(delex.storage.memmap_seqs.MemmapSeqs method)
(delex.storage.packed_memmap_arrs.PackedMemmapArrays method)
(delex.tokenizer.Tokenizer method)
(delex.utils.traits.SparkDistributable method)
init_jvm() (in module delex.utils.funcs)
insert_after() (delex.graph.node.Node method)
insert_before() (delex.graph.node.Node method)
IntersectNode (class in delex.graph.node)
invert (delex.lang.predicate.bootleg_predicate.BootlegSim attribute)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate.Sim attribute)
invert() (delex.lang.predicate.set_sim_predicate.SetSimPredicate method)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate method)
invertable (delex.lang.predicate.threshold_predicate.ThresholdPredicate property)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate property)
is_persisted() (in module delex.utils.funcs)
is_sink (delex.graph.node.Node property)
is_source (delex.graph.node.Node property)
is_topk (delex.lang.predicate.bootleg_predicate.BootlegPredicate property)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate property)
(delex.lang.predicate.predicate.Predicate property)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate property)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate property)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate property)
iter_dependencies() (delex.graph.node.Node method)
(delex.graph.node.PredicateNode method)
iter_in() (delex.graph.node.Node method)
iter_out() (delex.graph.node.Node method)
iter_spark_rows() (in module delex.storage.vector_store)
J
jaccard() (delex.storage.sorted_set.MemmapSortedSets method)
jaccard_threshold() (delex.index.set_sim_index.SetSimIndex method)
JaccardPredicate (class in delex.lang.predicate.set_sim_predicate)
JaccardSetSimIndexSlice (class in delex.index.filtered_set_sim_index_slice)
JaroPredicate (class in delex.lang.predicate.string_sim_predicate)
JaroWinklerPredicate (class in delex.lang.predicate.string_sim_predicate)
JaroWinklerPredicate.Sim (class in delex.lang.predicate.string_sim_predicate)
K
k (delex.lang.predicate.topk_predicate.BM25TopkPredicate property)
keep_rules (delex.lang.program.BlockingProgram attribute)
KeepRule (class in delex.lang.rule)
L
left (delex.graph.node.MinusNode property)
lowercase (delex.index.hash_index.HashIndex.CacheKey attribute)
(delex.lang.predicate.bootleg_predicate.CachedNameIndexKey attribute)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate.Sim attribute)
M
MemmapArray (class in delex.storage.memmap_arr)
MemmapSeqs (class in delex.storage.memmap_seqs)
MemmapSortedSets (class in delex.storage.sorted_set)
MemmapSortedSets.CacheKey (class in delex.storage.sorted_set)
MemmapStrings (class in delex.storage.string_store)
MemmapStrings.CacheKey (class in delex.storage.string_store)
MemmapVectorStore (class in delex.storage.vector_store)
MemmapVectorStore.CacheKey (class in delex.storage.vector_store)
MinusNode (class in delex.graph.node)
model_config (delex.execution.graph_executor.GraphExecutionStats attribute)
(delex.execution.graph_executor.GraphExecutor attribute)
(delex.execution.graph_executor.PartitionExecutionStats attribute)
(delex.execution.graph_executor.SubGraphExecutionStats attribute)
(delex.execution.plan_executor.PlanExecutionStats attribute)
(delex.execution.plan_executor.PlanExecutor attribute)
model_post_init() (delex.execution.graph_executor.GraphExecutor method)
(delex.execution.plan_executor.PlanExecutor method)
module
delex
delex.execution
delex.execution.cost_estimation
delex.execution.dataframe_stream
delex.execution.graph_executor
delex.execution.optimizer
delex.execution.partitioner
delex.execution.plan_executor
delex.graph
delex.graph.algorithms
delex.graph.node
delex.graph.utils
delex.index
delex.index.filtered_set_sim_index
delex.index.filtered_set_sim_index_slice
delex.index.hash_index
delex.index.set_sim_index
delex.lang
delex.lang.predicate
delex.lang.predicate.bootleg_predicate
delex.lang.predicate.exact_match_predicate
delex.lang.predicate.name_map
delex.lang.predicate.predicate
delex.lang.predicate.set_sim_predicate
delex.lang.predicate.string_sim_predicate
delex.lang.predicate.threshold_predicate
delex.lang.predicate.topk_predicate
delex.lang.program
delex.lang.rule
delex.storage
delex.storage.hash_map
delex.storage.hash_map.hash_map_base
delex.storage.hash_map.id_int_map
delex.storage.hash_map.string_int_map
delex.storage.memmap_arr
delex.storage.memmap_seqs
delex.storage.packed_memmap_arrs
delex.storage.sorted_set
delex.storage.span_map
delex.storage.string_store
delex.storage.vector_store
delex.tokenizer
delex.utils
delex.utils.build_cache
delex.utils.funcs
delex.utils.hash_function
delex.utils.numba_functions
delex.utils.traits
N
NAME (delex.tokenizer.AlphaNumericTokenizer attribute)
(delex.tokenizer.NumericTokenizer attribute)
(delex.tokenizer.StrippedWhiteSpaceTokenizer attribute)
(delex.tokenizer.WhiteSpaceTokenizer attribute)
Node (class in delex.graph.node)
nodes (delex.execution.graph_executor.GraphExecutionStats attribute)
(delex.execution.graph_executor.SubGraphExecutionStats attribute)
nodes_to_dot() (in module delex.graph.utils)
nparts (delex.execution.partitioner.DataFramePartitioner attribute)
nthreads (delex.execution.cost_estimation.CostEstimator property)
NumericTokenizer (class in delex.tokenizer)
nunique_tokens (delex.tokenizer.Tokenizer property)
O
obj (delex.utils.build_cache.CacheItem property)
on_spark (delex.storage.hash_map.hash_map_base.DistributableHashMap property)
op (delex.lang.predicate.bootleg_predicate.BootlegPredicate property)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate property)
(delex.lang.predicate.threshold_predicate.ThresholdPredicate property)
optimize (delex.execution.plan_executor.PlanExecutor attribute)
optimize() (delex.execution.optimizer.BlockingProgramOptimizer method)
optimize_time (delex.execution.plan_executor.PlanExecutionStats attribute)
out_degree (delex.graph.node.Node property)
output_col (delex.graph.node.Node property)
overlap_coeff() (delex.storage.sorted_set.MemmapSortedSets method)
overlap_coeff_threshold() (delex.index.set_sim_index.SetSimIndex method)
OverlapCoeffPredicate (class in delex.lang.predicate.set_sim_predicate)
P
PackedMemmapArrays (class in delex.storage.packed_memmap_arrs)
part_num (delex.execution.graph_executor.PartitionExecutionStats attribute)
partition_stats (delex.execution.graph_executor.SubGraphExecutionStats attribute)
partitioner (delex.execution.graph_executor.PartitionExecutionStats attribute)
PartitionExecutionStats (class in delex.execution.graph_executor)
persisted() (in module delex.utils.funcs)
PlanExecutionStats (class in delex.execution.plan_executor)
PlanExecutor (class in delex.execution.plan_executor)
pop() (delex.graph.node.Node method)
Predicate (class in delex.lang.predicate.predicate)
predicate (delex.graph.node.PredicateNode property)
PredicateNode (class in delex.graph.node)
predicates (delex.lang.rule.Rule attribute)
predict() (delex.execution.cost_estimation.ScalingModel method)
prefix_weight (delex.lang.predicate.string_sim_predicate.JaroWinklerPredicate.Sim attribute)
preprocess() (delex.execution.optimizer.BlockingProgramOptimizer method)
pretty_str() (delex.lang.program.BlockingProgram method)
(delex.lang.rule.Rule method)
pyarrow_schema() (delex.execution.dataframe_stream.DataFrameStream method)
Q
QGramTokenizer (class in delex.tokenizer)
R
ram_size_in_bytes (delex.execution.graph_executor.GraphExecutor attribute)
RE (delex.tokenizer.StrippedQGramTokenizer attribute)
(delex.tokenizer.StrippedWhiteSpaceTokenizer attribute)
remove_in_edge() (delex.graph.node.Node method)
remove_in_edges() (delex.graph.node.Node method)
remove_out_edge() (delex.graph.node.Node method)
remove_out_edges() (delex.graph.node.Node method)
right (delex.graph.node.MinusNode property)
Rule (class in delex.lang.rule)
S
ScalingModel (class in delex.execution.cost_estimation)
schema (delex.execution.dataframe_stream.DataFrameStream property)
search() (delex.index.filtered_set_sim_index.FilteredSetSimIndex method)
(delex.index.filtered_set_sim_index_slice.FilteredSetSimIndexSlice method)
(delex.lang.predicate.predicate.Predicate method)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate method)
search_batch() (delex.lang.predicate.predicate.Predicate method)
(delex.lang.predicate.threshold_predicate.ThresholdPredicate method)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate method)
search_col (delex.index.filtered_set_sim_index.FilteredSetSimIndex.CacheKey attribute)
(delex.lang.predicate.bootleg_predicate.BootlegPredicate property)
(delex.lang.predicate.bootleg_predicate.BootlegSim attribute)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate property)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate.Sim attribute)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate.Sim attribute)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate.Sim attribute)
(delex.lang.predicate.threshold_predicate.ThresholdPredicate property)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate property)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate.Sim attribute)
(delex.storage.sorted_set.MemmapSortedSets.CacheKey attribute)
(delex.storage.vector_store.MemmapVectorStore.CacheKey attribute)
(delex.tokenizer.Tokenizer.CacheKey attribute)
search_index() (delex.lang.predicate.bootleg_predicate.BootlegPredicate method)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate method)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate method)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate method)
(delex.lang.predicate.threshold_predicate.ThresholdPredicate method)
search_table (delex.execution.graph_executor.GraphExecutor attribute)
search_time() (delex.execution.cost_estimation.CostEstimator method)
selectivity() (delex.execution.cost_estimation.CostEstimator method)
SetOpNode (class in delex.graph.node)
SetSimIndex (class in delex.index.set_sim_index)
SetSimIndexSlice (class in delex.index.set_sim_index)
SetSimPredicate (class in delex.lang.predicate.set_sim_predicate)
SetSimPredicate.Sim (class in delex.lang.predicate.set_sim_predicate)
shape (delex.storage.memmap_arr.MemmapArray property)
ShingleTokenizer (class in delex.tokenizer)
sim (delex.index.filtered_set_sim_index.FilteredSetSimIndex.CacheKey attribute)
(delex.lang.predicate.bootleg_predicate.BootlegPredicate property)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate property)
(delex.lang.predicate.predicate.Predicate property)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate property)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate property)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate property)
sim_name (delex.lang.predicate.set_sim_predicate.SetSimPredicate.Sim attribute)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate.Sim attribute)
size_in_bytes() (delex.index.filtered_set_sim_index.FilteredSetSimIndex method)
(delex.index.hash_index.HashIndex method)
(delex.storage.hash_map.hash_map_base.DistributableHashMap method)
(delex.storage.memmap_arr.MemmapArray method)
(delex.storage.memmap_seqs.MemmapSeqs method)
(delex.storage.packed_memmap_arrs.PackedMemmapArrays method)
(in module delex.utils.funcs)
SLICE_TYPES (delex.index.filtered_set_sim_index.FilteredSetSimIndex attribute)
SmithWatermanPredicate (class in delex.lang.predicate.string_sim_predicate)
SmithWatermanPredicate.Sim (class in delex.lang.predicate.string_sim_predicate)
sorted_set_overlap() (in module delex.utils.numba_functions)
span_map_get_key() (in module delex.storage.span_map)
span_map_insert_key() (in module delex.storage.span_map)
span_map_insert_keys() (in module delex.storage.span_map)
spark_schema() (delex.execution.dataframe_stream.DataFrameStream method)
SparkDistributable (class in delex.utils.traits)
streamable (delex.graph.node.Node property)
(delex.graph.node.PredicateNode property)
(delex.graph.node.SetOpNode property)
(delex.lang.predicate.bootleg_predicate.BootlegPredicate property)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate property)
(delex.lang.predicate.predicate.Predicate property)
(delex.lang.predicate.set_sim_predicate.SetSimPredicate property)
(delex.lang.predicate.string_sim_predicate.StringSimPredicate property)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate property)
StringIntHashMap (class in delex.storage.hash_map.string_int_map)
StringSimPredicate (class in delex.lang.predicate.string_sim_predicate)
StringSimPredicate.Sim (class in delex.lang.predicate.string_sim_predicate)
StrippedQGramTokenizer (class in delex.tokenizer)
StrippedWhiteSpaceTokenizer (class in delex.tokenizer)
sub_graph_stats (delex.execution.graph_executor.GraphExecutionStats attribute)
SubGraphExecutionStats (class in delex.execution.graph_executor)
T
table_a_count (delex.execution.cost_estimation.CostEstimator property)
table_b_count (delex.execution.cost_estimation.CostEstimator property)
threshold (delex.index.filtered_set_sim_index.FilteredSetSimIndex.CacheKey attribute)
ThresholdPredicate (class in delex.lang.predicate.threshold_predicate)
to_arrow_stream() (delex.execution.dataframe_stream.DataFrameStream method)
to_pandas_stream() (delex.execution.dataframe_stream.DataFrameStream method)
to_spark() (delex.index.filtered_set_sim_index.FilteredSetSimIndex method)
(delex.index.hash_index.HashIndex method)
(delex.index.set_sim_index.SetSimIndex method)
(delex.storage.hash_map.hash_map_base.DistributableHashMap method)
(delex.storage.memmap_arr.MemmapArray method)
(delex.storage.memmap_seqs.MemmapSeqs method)
(delex.storage.packed_memmap_arrs.PackedMemmapArrays method)
(delex.tokenizer.Tokenizer method)
(delex.utils.traits.SparkDistributable method)
tokenize() (delex.tokenizer.Tokenizer method)
tokenize_set() (delex.tokenizer.Tokenizer method)
tokenize_set_spark() (delex.tokenizer.Tokenizer method)
tokenize_spark() (delex.tokenizer.Tokenizer method)
Tokenizer (class in delex.tokenizer)
tokenizer (delex.lang.predicate.topk_predicate.CachedBM25IndexKey attribute)
Tokenizer.CacheKey (class in delex.tokenizer)
tokenizer_name (delex.lang.predicate.set_sim_predicate.SetSimPredicate.Sim attribute)
(delex.lang.predicate.topk_predicate.BM25TopkPredicate.Sim attribute)
tokenizer_type (delex.index.filtered_set_sim_index.FilteredSetSimIndex.CacheKey attribute)
(delex.storage.sorted_set.MemmapSortedSets.CacheKey attribute)
(delex.storage.vector_store.MemmapVectorStore.CacheKey attribute)
(delex.tokenizer.Tokenizer.CacheKey attribute)
topological_sort() (in module delex.graph.algorithms)
total_time (delex.execution.graph_executor.GraphExecutionStats property)
(delex.execution.graph_executor.SubGraphExecutionStats property)
(delex.execution.plan_executor.PlanExecutionStats property)
type_check() (in module delex.utils.funcs)
typed_list_to_array() (in module delex.utils.numba_functions)
U
UnionNode (class in delex.graph.node)
unpack() (delex.storage.packed_memmap_arrs.PackedMemmapArrays method)
use_chunking (delex.execution.graph_executor.GraphExecutor property)
use_cost_estimation (delex.execution.graph_executor.GraphExecutor property)
V
val (delex.lang.predicate.bootleg_predicate.BootlegPredicate property)
(delex.lang.predicate.exact_match_predicate.ExactMatchPredicate property)
(delex.lang.predicate.threshold_predicate.ThresholdPredicate property)
validate() (delex.execution.cost_estimation.CostEstimator method)
(delex.graph.node.IntersectNode method)
(delex.graph.node.MinusNode method)
(delex.graph.node.Node method)
(delex.graph.node.PredicateNode method)
(delex.graph.node.UnionNode method)
(delex.lang.program.BlockingProgram method)
(delex.lang.rule.DropRule method)
(delex.lang.rule.KeepRule method)
values (delex.storage.memmap_arr.MemmapArray property)
vector_dtype (delex.storage.vector_store.MemmapVectorStore attribute)
W
WHITESPACE_NORM (delex.tokenizer.StrippedWhiteSpaceTokenizer attribute)
WhiteSpaceTokenizer (class in delex.tokenizer)
working_set_size (delex.execution.graph_executor.GraphExecutionStats property)
(delex.execution.graph_executor.PartitionExecutionStats attribute)
(delex.execution.graph_executor.SubGraphExecutionStats property)
working_set_size() (delex.execution.cost_estimation.CostEstimator method)
(delex.graph.node.Node method)
(delex.graph.node.PredicateNode method)
(delex.graph.node.SetOpNode method)