Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abort(Exception, ActionListener<Void>) - Method in class org.elasticsearch.compute.operator.Driver
-
Abort the driver and wait for it to finish
- AbstractArrayState - Class in org.elasticsearch.compute.aggregation
-
Base class for array states that track which group ids have been set.
- AbstractArrayState(BigArrays) - Constructor for class org.elasticsearch.compute.aggregation.AbstractArrayState
- AbstractBlockBuilder - Class in org.elasticsearch.compute.data
- AbstractBlockBuilder(BlockFactory) - Constructor for class org.elasticsearch.compute.data.AbstractBlockBuilder
- AbstractFallibleArrayState - Class in org.elasticsearch.compute.aggregation
-
Base class that extends
AbstractArrayState
to add failure tracking. - AbstractFallibleArrayState(BigArrays) - Constructor for class org.elasticsearch.compute.aggregation.AbstractFallibleArrayState
- AbstractPageMappingOperator - Class in org.elasticsearch.compute.operator
-
Abstract superclass for operators that accept a single page, modify it, and then return it.
- AbstractPageMappingOperator() - Constructor for class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- AbstractPageMappingOperator.Status - Class in org.elasticsearch.compute.operator
- AbstractPageMappingToIteratorOperator - Class in org.elasticsearch.compute.operator
-
Maps a single
Page
into zero or more resulting pages. - AbstractPageMappingToIteratorOperator() - Constructor for class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- AbstractPageMappingToIteratorOperator.Status - Class in org.elasticsearch.compute.operator
- AbstractVectorBuilder - Class in org.elasticsearch.compute.data
- AbstractVectorBuilder(BlockFactory) - Constructor for class org.elasticsearch.compute.data.AbstractVectorBuilder
- accept(Object) - Method in record class org.elasticsearch.compute.data.BlockUtils.BuilderWrapper
- acquire() - Method in class org.elasticsearch.compute.EsqlRefCountingListener
- ACTION_NAME - Static variable in class org.elasticsearch.compute.operator.DriverTaskRunner
- activeOperators() - Method in class org.elasticsearch.compute.operator.DriverStatus
-
Status of each active
Operator
in the driver. - add() - Method in class org.elasticsearch.compute.operator.mvdedupe.IntLongBlockAdd
- add() - Method in class org.elasticsearch.compute.operator.mvdedupe.LongLongBlockAdd
- add(double) - Method in class org.elasticsearch.compute.aggregation.WelfordAlgorithm
- add(double, double, long) - Method in class org.elasticsearch.compute.aggregation.WelfordAlgorithm
- add(int) - Method in class org.elasticsearch.compute.aggregation.WelfordAlgorithm
- add(int, IntBlock) - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorFunction.AddInput
-
Send a batch of group ids to the aggregator.
- add(int, IntVector) - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorFunction.AddInput
-
Send a batch of group ids to the aggregator.
- add(long) - Method in class org.elasticsearch.compute.aggregation.WelfordAlgorithm
- add(Page, GroupingAggregatorFunction.AddInput) - Method in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
-
Add all values for the "group by" columns in the page to the hash and pass the ordinals to the provided
GroupingAggregatorFunction.AddInput
. - add(Page, GroupingAggregatorFunction.AddInput) - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizeBlockHash
- add(Page, GroupingAggregatorFunction.AddInput) - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizePackedValuesBlockHash
- add(Page, GroupingAggregatorFunction.AddInput) - Method in class org.elasticsearch.compute.aggregation.blockhash.TimeSeriesBlockHash
- addAsyncAction() - Method in class org.elasticsearch.compute.operator.DriverContext
- addCompletionListener(ActionListener<Void>) - Method in interface org.elasticsearch.compute.operator.exchange.ExchangeSink
-
Adds a listener that will be notified when this exchange sink is finished.
- addCompletionListener(ActionListener<Void>) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkHandler
-
Add a listener, which will be notified when this exchange sink handler is completed.
- addCompletionListener(ActionListener<Void>) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator
- addEmptySink() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceHandler
-
Links this exchange source with an empty/dummy remote sink.
- addEstimateBytesAndMaybeBreak(long, String) - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- addExchangeSourceHandler(String, ExchangeSourceHandler) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
-
Remember the exchange source handler for the given session ID.
- addingValue() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
Implementations of
BatchEncoder.MVEncoder.readNextBatch()
should call this before adding each value to the current position to mark its start. - addInput(Page) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- addInput(Page) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- addInput(Page) - Method in class org.elasticsearch.compute.operator.AggregationOperator
- addInput(Page) - Method in class org.elasticsearch.compute.operator.AsyncOperator
- addInput(Page) - Method in class org.elasticsearch.compute.operator.HashAggregationOperator
- addInput(Page) - Method in class org.elasticsearch.compute.operator.LimitOperator
- addInput(Page) - Method in class org.elasticsearch.compute.operator.lookup.MergePositionsOperator
- addInput(Page) - Method in class org.elasticsearch.compute.operator.MvExpandOperator
- addInput(Page) - Method in interface org.elasticsearch.compute.operator.Operator
-
adds an input page to the operator.
- addInput(Page) - Method in class org.elasticsearch.compute.operator.OrdinalsGroupingOperator
- addInput(Page) - Method in class org.elasticsearch.compute.operator.SinkOperator
- addInput(Page) - Method in class org.elasticsearch.compute.operator.SourceOperator
-
A source operator does not accept input - unconditionally throws UnsupportedOperationException.
- addInput(Page) - Method in class org.elasticsearch.compute.operator.topn.TopNOperator
- addIntermediateInput(int, IntVector, Page) - Method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- addIntermediateInput(int, IntVector, Page) - Method in class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- addIntermediateInput(int, IntVector, Page) - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorFunction
- addIntermediateInput(int, IntVector, Page) - Method in class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- addIntermediateInput(Page) - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunction
-
Add a pre-aggregated page worth of "intermediate" input.
- addIntermediateInput(Page) - Method in class org.elasticsearch.compute.aggregation.CountAggregatorFunction
- addIntermediateInput(Page) - Method in class org.elasticsearch.compute.aggregation.FromPartialAggregatorFunction
- addIntermediateInput(Page) - Method in class org.elasticsearch.compute.aggregation.ToPartialAggregatorFunction
- addIntermediateRow(int, GroupingAggregator, int) - Method in class org.elasticsearch.compute.aggregation.GroupingAggregator
-
Add the position-th row from the intermediate output of the given aggregator to this aggregator at the groupId position
- addIntermediateRowInput(int, GroupingAggregatorFunction, int) - Method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- addIntermediateRowInput(int, GroupingAggregatorFunction, int) - Method in class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- addIntermediateRowInput(int, GroupingAggregatorFunction, int) - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorFunction
-
Add the position-th row from the intermediate output of the given aggregator function to the groupId
- addIntermediateRowInput(int, GroupingAggregatorFunction, int) - Method in class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- addPage(Page) - Method in interface org.elasticsearch.compute.operator.exchange.ExchangeSink
-
adds a new page to this sink
- AddPage - Class in org.elasticsearch.compute.aggregation.blockhash
- AddPage(BlockFactory, int, GroupingAggregatorFunction.AddInput) - Constructor for class org.elasticsearch.compute.aggregation.blockhash.AddPage
- addRawInput(Page, BooleanVector) - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunction
-
Add a page worth of data to the aggregation.
- addRawInput(Page, BooleanVector) - Method in class org.elasticsearch.compute.aggregation.CountAggregatorFunction
- addRawInput(Page, BooleanVector) - Method in class org.elasticsearch.compute.aggregation.FromPartialAggregatorFunction
- addRawInput(Page, BooleanVector) - Method in class org.elasticsearch.compute.aggregation.ToPartialAggregatorFunction
- addReleasable(Releasable) - Method in class org.elasticsearch.compute.operator.DriverContext
-
Adds a releasable to this context.
- addRemoteSink(RemoteSink, boolean, Runnable, int, ActionListener<Void>) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceHandler
-
Add a remote sink as a new data source of this handler.
- addWithoutBreaking(long) - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- adjustBreaker(long) - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- adjustBreaker(long) - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
- adjustBreaker(long) - Method in class org.elasticsearch.compute.data.BlockFactory
-
Adjust the circuit breaker with the given delta, if the delta is negative, the breaker will be adjusted without tripping.
- AggregateMetricDoubleBlockBuilder - Class in org.elasticsearch.compute.data
- AggregateMetricDoubleBlockBuilder(int, BlockFactory) - Constructor for class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- AggregateMetricDoubleBlockBuilder.AggregateMetricDoubleLiteral - Record Class in org.elasticsearch.compute.data
- AggregateMetricDoubleBlockBuilder.Metric - Enum Class in org.elasticsearch.compute.data
- AggregateMetricDoubleLiteral(Double, Double, Double, Integer) - Constructor for record class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.AggregateMetricDoubleLiteral
-
Creates an instance of a
AggregateMetricDoubleLiteral
record class. - aggregationFinishNanos() - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
-
Nanoseconds this operator has spent running the aggregations final evaluation.
- aggregationNanos() - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
-
Nanoseconds this operator has spent running the aggregations.
- aggregationNanos() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
-
Nanoseconds this operator has spent running the aggregations.
- AggregationOperator - Class in org.elasticsearch.compute.operator
-
Blocking aggregation operator.
- AggregationOperator(List<Aggregator>, DriverContext) - Constructor for class org.elasticsearch.compute.operator.AggregationOperator
- AggregationOperator.AggregationOperatorFactory - Record Class in org.elasticsearch.compute.operator
- AggregationOperator.Status - Class in org.elasticsearch.compute.operator
- AggregationOperatorFactory(List<Aggregator.Factory>, AggregatorMode) - Constructor for record class org.elasticsearch.compute.operator.AggregationOperator.AggregationOperatorFactory
-
Creates an instance of a
AggregationOperatorFactory
record class. - aggregator(DriverContext, List<Integer>) - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunctionSupplier
- aggregator(DriverContext, List<Integer>) - Method in record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
- Aggregator - Class in org.elasticsearch.compute.aggregation
- Aggregator(AggregatorFunction, AggregatorMode) - Constructor for class org.elasticsearch.compute.aggregation.Aggregator
- Aggregator.Factory - Interface in org.elasticsearch.compute.aggregation
- aggregatorFactory(AggregatorMode, List<Integer>) - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunctionSupplier
- AggregatorFunction - Interface in org.elasticsearch.compute.aggregation
-
A non-grouped aggregation.
- AggregatorFunctionSupplier - Interface in org.elasticsearch.compute.aggregation
-
Builds aggregation implementations, closing over any state required to do so.
- aggregatorMode() - Method in record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
-
Returns the value of the
aggregatorMode
record component. - AggregatorMode - Enum Class in org.elasticsearch.compute.aggregation
- aggregators() - Method in record class org.elasticsearch.compute.operator.AggregationOperator.AggregationOperatorFactory
-
Returns the value of the
aggregators
record component. - aggregators() - Method in record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
-
Returns the value of the
aggregators
record component. - aggregators() - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Returns the value of the
aggregators
record component. - AggregatorState - Interface in org.elasticsearch.compute.aggregation
- allFalse() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
-
Are all values
false
? This will scan all values to check and always answer accurately. - allFalse() - Method in interface org.elasticsearch.compute.data.BooleanVector
-
Are all values
false
? This will scan all values to check and always answer accurately. - allFalse() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- allowPassingToDifferentDriver() - Method in interface org.elasticsearch.compute.data.Block
-
Before passing a Block to another Driver, it is necessary to switch the owning block factory to its parent, which is associated with the global circuit breaker.
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.CompositeBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.DocBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.DocVector
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- allowPassingToDifferentDriver() - Method in class org.elasticsearch.compute.data.Page
-
Before passing a Page to another Driver, it is necessary to switch the owning block factories of its Blocks to their parents, which are associated with the global circuit breaker.
- allowPassingToDifferentDriver() - Method in interface org.elasticsearch.compute.data.Vector
-
Before passing a Vector to another Driver, it is necessary to switch the owning block factory to its parent, which is associated with the global circuit breaker.
- allTrue() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
-
Are all values
true
? This will scan all values to check and always answer accurately. - allTrue() - Method in interface org.elasticsearch.compute.data.BooleanVector
-
Are all values
true
? This will scan all values to check and always answer accurately. - allTrue() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- analysisRegistry() - Method in record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
-
Returns the value of the
analysisRegistry
record component. - anyFailure() - Method in class org.elasticsearch.compute.aggregation.AbstractFallibleArrayState
- append() - Method in record class org.elasticsearch.compute.data.BlockUtils.BuilderWrapper
-
Returns the value of the
append
record component. - append(byte) - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Append a byte.
- append(byte[], int, int) - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Append bytes.
- append(BytesRef) - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Append bytes.
- appendBlock(Block) - Method in class org.elasticsearch.compute.data.Page
-
Creates a new page, appending the given block to the existing blocks in this Page.
- appendBlocks(Block[]) - Method in class org.elasticsearch.compute.data.Page
-
Creates a new page, appending the given blocks to the existing blocks in this Page.
- appendBlocks(Page, ReleasableIterator<? extends Block>) - Static method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- appendBoolean(boolean) - Method in interface org.elasticsearch.compute.data.BooleanBlock.Builder
-
Appends a boolean to the current entry.
- appendBoolean(boolean) - Method in interface org.elasticsearch.compute.data.BooleanVector.Builder
-
Appends a boolean to the current entry.
- appendBoolean(boolean) - Method in interface org.elasticsearch.compute.data.BooleanVector.FixedBuilder
-
Appends a boolean to the current entry.
- appendBoolean(boolean) - Method in class org.elasticsearch.compute.data.BooleanVectorFixedBuilder
- appendBoolean(int, boolean) - Method in interface org.elasticsearch.compute.data.BooleanVector.FixedBuilder
- appendBoolean(int, boolean) - Method in class org.elasticsearch.compute.data.BooleanVectorFixedBuilder
- appendBytesRef(BytesRef) - Method in interface org.elasticsearch.compute.data.BytesRefBlock.Builder
-
Appends a BytesRef to the current entry.
- appendBytesRef(BytesRef) - Method in interface org.elasticsearch.compute.data.BytesRefVector.Builder
-
Appends a BytesRef to the current entry.
- appendDoc(int) - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- appendDouble(double) - Method in interface org.elasticsearch.compute.data.DoubleBlock.Builder
-
Appends a double to the current entry.
- appendDouble(double) - Method in interface org.elasticsearch.compute.data.DoubleVector.Builder
-
Appends a double to the current entry.
- appendDouble(double) - Method in interface org.elasticsearch.compute.data.DoubleVector.FixedBuilder
-
Appends a double to the current entry.
- appendDouble(double) - Method in class org.elasticsearch.compute.data.DoubleVectorFixedBuilder
- appendDouble(int, double) - Method in interface org.elasticsearch.compute.data.DoubleVector.FixedBuilder
- appendDouble(int, double) - Method in class org.elasticsearch.compute.data.DoubleVectorFixedBuilder
- appendFloat(float) - Method in interface org.elasticsearch.compute.data.FloatBlock.Builder
-
Appends a float to the current entry.
- appendFloat(float) - Method in interface org.elasticsearch.compute.data.FloatVector.Builder
-
Appends a float to the current entry.
- appendFloat(float) - Method in interface org.elasticsearch.compute.data.FloatVector.FixedBuilder
-
Appends a float to the current entry.
- appendFloat(float) - Method in class org.elasticsearch.compute.data.FloatVectorFixedBuilder
- appendFloat(int, float) - Method in interface org.elasticsearch.compute.data.FloatVector.FixedBuilder
- appendFloat(int, float) - Method in class org.elasticsearch.compute.data.FloatVectorFixedBuilder
- appendInt(int) - Method in interface org.elasticsearch.compute.data.IntBlock.Builder
-
Appends a int to the current entry.
- appendInt(int) - Method in interface org.elasticsearch.compute.data.IntVector.Builder
-
Appends a int to the current entry.
- appendInt(int) - Method in interface org.elasticsearch.compute.data.IntVector.FixedBuilder
-
Appends a int to the current entry.
- appendInt(int) - Method in class org.elasticsearch.compute.data.IntVectorFixedBuilder
- appendInt(int, int) - Method in interface org.elasticsearch.compute.data.IntVector.FixedBuilder
- appendInt(int, int) - Method in class org.elasticsearch.compute.data.IntVectorFixedBuilder
- appendLong(int, long) - Method in interface org.elasticsearch.compute.data.LongVector.FixedBuilder
- appendLong(int, long) - Method in class org.elasticsearch.compute.data.LongVectorFixedBuilder
- appendLong(long) - Method in interface org.elasticsearch.compute.data.LongBlock.Builder
-
Appends a long to the current entry.
- appendLong(long) - Method in interface org.elasticsearch.compute.data.LongVector.Builder
-
Appends a long to the current entry.
- appendLong(long) - Method in interface org.elasticsearch.compute.data.LongVector.FixedBuilder
-
Appends a long to the current entry.
- appendLong(long) - Method in class org.elasticsearch.compute.data.LongVectorFixedBuilder
- appendMatch(BooleanVector.Builder, Scorable) - Method in class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator
- appendMatch(DoubleVector.Builder, Scorable) - Method in class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator
- appendMatch(T, Scorable) - Method in class org.elasticsearch.compute.lucene.LuceneQueryEvaluator
-
Appends a matching result to a builder created by @link createVectorBuilder}
- appendNoMatch(BooleanVector.Builder) - Method in class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator
- appendNoMatch(DoubleVector.Builder) - Method in class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator
- appendNoMatch(T) - Method in class org.elasticsearch.compute.lucene.LuceneQueryEvaluator
-
Appends a non matching result to a builder created by @link createVectorBuilder}
- appendNull() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- appendNull() - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- appendNull() - Method in interface org.elasticsearch.compute.data.Block.Builder
-
Appends a null value to the block.
- appendNull() - Method in interface org.elasticsearch.compute.data.BooleanBlock.Builder
- appendNull() - Method in interface org.elasticsearch.compute.data.BytesRefBlock.Builder
- appendNull() - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- appendNull() - Method in interface org.elasticsearch.compute.data.DoubleBlock.Builder
- appendNull() - Method in interface org.elasticsearch.compute.data.FloatBlock.Builder
- appendNull() - Method in interface org.elasticsearch.compute.data.IntBlock.Builder
- appendNull() - Method in interface org.elasticsearch.compute.data.LongBlock.Builder
- appendNull() - Method in class org.elasticsearch.compute.data.SingletonOrdinalsBuilder
- appendNullSv(int) - Method in class org.elasticsearch.compute.aggregation.blockhash.AddPage
-
Deprecated.nulls should resolve to some value.
- appendOrd(int) - Method in class org.elasticsearch.compute.data.SingletonOrdinalsBuilder
- appendOrdInMv(int, int) - Method in class org.elasticsearch.compute.aggregation.blockhash.AddPage
-
Append a value inside a multivalued ordinal.
- appendOrdSv(int, int) - Method in class org.elasticsearch.compute.aggregation.blockhash.AddPage
-
Append a single valued ordinal.
- appendPage(Page) - Method in class org.elasticsearch.compute.data.Page
-
Creates a new page, appending the blocks of the given block to the existing blocks in this Page.
- appendSegment(int) - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- appendShard(int) - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- appendValue(Block.Builder, Object, ElementType) - Static method in class org.elasticsearch.compute.data.BlockUtils
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.DocBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- areAllValuesNull() - Method in interface org.elasticsearch.compute.data.Block
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.CompositeBlock
- areAllValuesNull() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- asBlock() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- asBlock() - Method in interface org.elasticsearch.compute.data.BooleanVector
- asBlock() - Method in interface org.elasticsearch.compute.data.BytesRefVector
- asBlock() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- asBlock() - Method in class org.elasticsearch.compute.data.DocVector
- asBlock() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- asBlock() - Method in interface org.elasticsearch.compute.data.DoubleVector
- asBlock() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- asBlock() - Method in interface org.elasticsearch.compute.data.FloatVector
- asBlock() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- asBlock() - Method in interface org.elasticsearch.compute.data.IntVector
- asBlock() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- asBlock() - Method in interface org.elasticsearch.compute.data.LongVector
- asBlock() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- asBlock() - Method in interface org.elasticsearch.compute.data.Vector
-
Returns Returns a new Block containing this vector..
- asc() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.SortOrder
-
Returns the value of the
asc
record component. - AscendingSequenceRowInTableLookup - Class in org.elasticsearch.compute.aggregation.table
-
RowInTableLookup
that models an increasing sequence of integers. - AscendingSequenceRowInTableLookup(BlockFactory, int, int) - Constructor for class org.elasticsearch.compute.aggregation.table.AscendingSequenceRowInTableLookup
- asOrdinals() - Method in interface org.elasticsearch.compute.data.BytesRefBlock
-
Returns an ordinal bytesref block if this block is backed by a dictionary and ordinals; otherwise, returns null.
- asOrdinals() - Method in interface org.elasticsearch.compute.data.BytesRefVector
-
Returns an ordinal BytesRef vector if this vector is backed by a dictionary and ordinals; otherwise, returns null.
- asOrdinals() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- asOrdinals() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- asOrdinals() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- asOrdinals() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- asPage() - Method in class org.elasticsearch.compute.data.CompositeBlock
- asVector() - Method in interface org.elasticsearch.compute.data.Block
-
Returns an efficient dense single-value view of this block.
- asVector() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- asVector() - Method in interface org.elasticsearch.compute.data.BooleanBlock
- asVector() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- asVector() - Method in interface org.elasticsearch.compute.data.BytesRefBlock
- asVector() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- asVector() - Method in class org.elasticsearch.compute.data.CompositeBlock
- asVector() - Method in class org.elasticsearch.compute.data.DocBlock
- asVector() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- asVector() - Method in interface org.elasticsearch.compute.data.DoubleBlock
- asVector() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- asVector() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- asVector() - Method in interface org.elasticsearch.compute.data.FloatBlock
- asVector() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- asVector() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- asVector() - Method in interface org.elasticsearch.compute.data.IntBlock
- asVector() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- asVector() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- asVector() - Method in interface org.elasticsearch.compute.data.LongBlock
- asVector() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- asVector() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- ASYNC - Enum constant in enum class org.elasticsearch.compute.operator.DriverStatus.Status
- AsyncOperator<Fetched> - Class in org.elasticsearch.compute.operator
-
AsyncOperator
performs an external computation specified inAsyncOperator.performAsync(Page, ActionListener)
. - AsyncOperator(DriverContext, int) - Constructor for class org.elasticsearch.compute.operator.AsyncOperator
-
Create an operator that performs an external computation
- AsyncOperator.Status - Class in org.elasticsearch.compute.operator
B
- BASE_RAM_USAGE - Static variable in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectEncoder
- batchEncoder(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBoolean
-
Build a
BatchEncoder
which deduplicates values at each position and then encodes the results into ainvalid reference
byte[]
- batchEncoder(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBytesRef
-
Build a
BatchEncoder
which deduplicates values at each position and then encodes the results into ainvalid reference
byte[]
- batchEncoder(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeDouble
-
Build a
BatchEncoder
which deduplicates values at each position and then encodes the results into ainvalid reference
byte[]
- batchEncoder(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeInt
-
Build a
BatchEncoder
which deduplicates values at each position and then encodes the results into ainvalid reference
byte[]
- batchEncoder(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeLong
-
Build a
BatchEncoder
which deduplicates values at each position and then encodes the results into ainvalid reference
byte[]
- batchEncoder(Block, int, boolean) - Static method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe
-
Build a
BatchEncoder
which deduplicates values at each position and then encodes the results into ainvalid reference
byte[]
- BatchEncoder - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder() - Constructor for class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder
- BatchEncoder.Booleans - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.BytesRefs - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.Decoder - Interface in org.elasticsearch.compute.operator.mvdedupe
-
Decodes values encoded by
BatchEncoder
. - BatchEncoder.DirectBooleans - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.DirectBytesRefs - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.DirectDoubles - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.DirectEncoder - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.DirectInts - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.DirectLongs - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.DirectNulls - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.Doubles - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.Ints - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.IsNull - Interface in org.elasticsearch.compute.operator.mvdedupe
-
Checks if an offset is
null
. - BatchEncoder.Longs - Class in org.elasticsearch.compute.operator.mvdedupe
- BatchEncoder.MVEncoder - Class in org.elasticsearch.compute.operator.mvdedupe
- beginPositionEntry() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- beginPositionEntry() - Method in interface org.elasticsearch.compute.data.Block.Builder
-
Begins a multivalued entry.
- beginPositionEntry() - Method in interface org.elasticsearch.compute.data.BooleanBlock.Builder
- beginPositionEntry() - Method in interface org.elasticsearch.compute.data.BytesRefBlock.Builder
- beginPositionEntry() - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- beginPositionEntry() - Method in interface org.elasticsearch.compute.data.DoubleBlock.Builder
- beginPositionEntry() - Method in interface org.elasticsearch.compute.data.FloatBlock.Builder
- beginPositionEntry() - Method in interface org.elasticsearch.compute.data.IntBlock.Builder
- beginPositionEntry() - Method in interface org.elasticsearch.compute.data.LongBlock.Builder
- beginPositionEntry() - Method in class org.elasticsearch.compute.data.SingletonOrdinalsBuilder
- bigArrays - Variable in class org.elasticsearch.compute.aggregation.AbstractArrayState
- bigArrays() - Method in class org.elasticsearch.compute.data.BlockFactory
- bigArrays() - Method in class org.elasticsearch.compute.operator.DriverContext
- block - Variable in class org.elasticsearch.compute.operator.lookup.QueryList
- block - Variable in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectEncoder
- block() - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Values
-
Returns the value of the
block
record component. - block() - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Key
-
Returns the value of the
block
record component. - Block - Interface in org.elasticsearch.compute.data
-
A Block is a columnar representation of homogenous data.
- Block.Builder - Interface in org.elasticsearch.compute.data
-
Builds
Block
s. - Block.MvOrdering - Enum Class in org.elasticsearch.compute.data
-
How are multivalued fields ordered? Some operators can enable its optimization when mv_values are sorted ascending or de-duplicated.
- blockFactory - Variable in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
- blockFactory - Variable in class org.elasticsearch.compute.data.AbstractBlockBuilder
- blockFactory - Variable in class org.elasticsearch.compute.data.AbstractVectorBuilder
- blockFactory - Variable in class org.elasticsearch.compute.lucene.LuceneOperator
- blockFactory() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- blockFactory() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- blockFactory() - Method in class org.elasticsearch.compute.data.DocVector
- blockFactory() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- blockFactory() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- blockFactory() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- blockFactory() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- blockFactory() - Method in interface org.elasticsearch.compute.data.Block
-
The block factory associated with this block.
- blockFactory() - Method in class org.elasticsearch.compute.data.BlockStreamInput
- blockFactory() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.CompositeBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.DocBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- blockFactory() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- blockFactory() - Method in interface org.elasticsearch.compute.data.Vector
-
The block factory associated with this vector.
- blockFactory() - Method in class org.elasticsearch.compute.operator.DriverContext
- BlockFactory - Class in org.elasticsearch.compute.data
- BlockFactory(CircuitBreaker, BigArrays) - Constructor for class org.elasticsearch.compute.data.BlockFactory
- BlockFactory(CircuitBreaker, BigArrays, ByteSizeValue) - Constructor for class org.elasticsearch.compute.data.BlockFactory
- BlockFactory(CircuitBreaker, BigArrays, ByteSizeValue, BlockFactory) - Constructor for class org.elasticsearch.compute.data.BlockFactory
- BlockHash - Class in org.elasticsearch.compute.aggregation.blockhash
-
Specialized hash table implementations that map rows to a set of bucket IDs to which they belong to implement
GROUP BY
expressions. - BlockHash.GroupSpec - Record Class in org.elasticsearch.compute.aggregation.blockhash
- blockLoader() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.FieldInfo
-
Returns the value of the
blockLoader
record component. - blockLoaders() - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Returns the value of the
blockLoaders
record component. - blockMapping() - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Factory
-
Returns the value of the
blockMapping
record component. - BlockRamUsageEstimator - Class in org.elasticsearch.compute.data
- BlockRamUsageEstimator() - Constructor for class org.elasticsearch.compute.data.BlockRamUsageEstimator
- blockSize() - Method in record class org.elasticsearch.compute.operator.MvExpandOperator.Factory
-
Returns the value of the
blockSize
record component. - BlockStreamInput - Class in org.elasticsearch.compute.data
-
Stream for reading
Block
s. - BlockStreamInput(StreamInput, BlockFactory) - Constructor for class org.elasticsearch.compute.data.BlockStreamInput
- BlockUtils - Class in org.elasticsearch.compute.data
- BlockUtils.BuilderWrapper - Record Class in org.elasticsearch.compute.data
- BlockUtils.Doc - Record Class in org.elasticsearch.compute.data
-
Returned by
BlockUtils.toJavaObject(org.elasticsearch.compute.data.Block, int)
for "doc" type blocks. - BlockWritables - Class in org.elasticsearch.compute.data
- BlockWritables() - Constructor for class org.elasticsearch.compute.data.BlockWritables
- BOOLEAN - Enum constant in enum class org.elasticsearch.compute.data.ElementType
- BooleanBigArrayBlock - Class in org.elasticsearch.compute.data
-
Block implementation that stores values in a
BooleanBigArrayVector
. - BooleanBigArrayBlock(BitArray, int, int[], BitSet, Block.MvOrdering, BlockFactory) - Constructor for class org.elasticsearch.compute.data.BooleanBigArrayBlock
- BooleanBigArrayVector - Class in org.elasticsearch.compute.data
-
Vector implementation that defers to an enclosed
BitArray
. - BooleanBigArrayVector(BitArray, int, BlockFactory) - Constructor for class org.elasticsearch.compute.data.BooleanBigArrayVector
- BooleanBlock - Interface in org.elasticsearch.compute.data
-
Block that stores boolean values.
- BooleanBlock.Builder - Interface in org.elasticsearch.compute.data
-
Builder for
BooleanBlock
- BooleanBucketedSort - Class in org.elasticsearch.compute.data.sort
-
Aggregates the top N boolean values per bucket.
- BooleanBucketedSort(BigArrays, SortOrder, int) - Constructor for class org.elasticsearch.compute.data.sort.BooleanBucketedSort
- Booleans(int) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Booleans
- BooleanVector - Interface in org.elasticsearch.compute.data
-
Vector that stores boolean values.
- BooleanVector.Builder - Interface in org.elasticsearch.compute.data
-
A builder that grows as needed.
- BooleanVector.FixedBuilder - Interface in org.elasticsearch.compute.data
-
A builder that never grows.
- BooleanVectorBlock - Class in org.elasticsearch.compute.data
-
Block view of a
BooleanVector
. - BooleanVectorFixedBuilder - Class in org.elasticsearch.compute.data
-
Builder for
BooleanVector
s that never grows. - breaker() - Method in class org.elasticsearch.compute.data.BlockFactory
- breaker() - Method in class org.elasticsearch.compute.operator.DriverContext
-
The
CircuitBreaker
to use to track memory. - BreakingBytesRefBuilder - Class in org.elasticsearch.compute.operator
-
Builder for bytes arrays that checks its size against a
CircuitBreaker
. - BreakingBytesRefBuilder(CircuitBreaker, String) - Constructor for class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Build.
- BreakingBytesRefBuilder(CircuitBreaker, String, int) - Constructor for class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Build.
- bufferSize() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkHandler
-
Returns the number of pages available in the buffer.
- bufferSize() - Method in interface org.elasticsearch.compute.operator.exchange.ExchangeSource
-
Returns the number of pages that are buffered in this exchange source
- build() - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- build() - Method in interface org.elasticsearch.compute.data.Block.Builder
-
Builds the block.
- build() - Method in interface org.elasticsearch.compute.data.BooleanBlock.Builder
- build() - Method in interface org.elasticsearch.compute.data.BooleanVector.Builder
- build() - Method in class org.elasticsearch.compute.data.BooleanVectorFixedBuilder
- build() - Method in interface org.elasticsearch.compute.data.BytesRefBlock.Builder
- build() - Method in interface org.elasticsearch.compute.data.BytesRefVector.Builder
- build() - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- build() - Method in interface org.elasticsearch.compute.data.DoubleBlock.Builder
- build() - Method in interface org.elasticsearch.compute.data.DoubleVector.Builder
- build() - Method in class org.elasticsearch.compute.data.DoubleVectorFixedBuilder
- build() - Method in interface org.elasticsearch.compute.data.FloatBlock.Builder
- build() - Method in interface org.elasticsearch.compute.data.FloatVector.Builder
- build() - Method in class org.elasticsearch.compute.data.FloatVectorFixedBuilder
- build() - Method in interface org.elasticsearch.compute.data.IntBlock.Builder
- build() - Method in interface org.elasticsearch.compute.data.IntVector.Builder
- build() - Method in class org.elasticsearch.compute.data.IntVectorFixedBuilder
- build() - Method in interface org.elasticsearch.compute.data.LongBlock.Builder
- build() - Method in interface org.elasticsearch.compute.data.LongVector.Builder
- build() - Method in class org.elasticsearch.compute.data.LongVectorFixedBuilder
- build() - Method in class org.elasticsearch.compute.data.SingletonOrdinalsBuilder
- build() - Method in interface org.elasticsearch.compute.data.Vector.Builder
-
Builds the block.
- build() - Method in class org.elasticsearch.compute.operator.topn.ResultBuilderForNull
- build(List<BlockHash.GroupSpec>, BlockFactory, int, boolean) - Static method in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
-
Creates a specialized hash table that maps one or more
Block
s to ids. - build(BlockFactory, Block[]) - Static method in class org.elasticsearch.compute.aggregation.table.RowInTableLookup
- buildAll(Block.Builder...) - Static method in interface org.elasticsearch.compute.data.Block.Builder
-
Build many
Block
s at once, releasing any partially built blocks if any fail. - buildCategorizeBlockHash(List<BlockHash.GroupSpec>, AggregatorMode, BlockFactory, AnalysisRegistry, int) - Static method in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
-
Builds a BlockHash for the Categorize grouping function.
- buildEmptyResult(BlockFactory, int) - Method in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
-
Build the corresponding block
- buildEmptyResult(BlockFactory, int) - Method in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
-
Build the corresponding block
- builder() - Method in record class org.elasticsearch.compute.data.BlockUtils.BuilderWrapper
-
Returns the value of the
builder
record component. - BuilderWrapper(Block.Builder, Consumer<Object>) - Constructor for record class org.elasticsearch.compute.data.BlockUtils.BuilderWrapper
-
Creates an instance of a
BuilderWrapper
record class. - buildPackedValuesBlockHash(List<BlockHash.GroupSpec>, BlockFactory, int) - Static method in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
-
Temporary method to build a
PackedValuesBlockHash
. - buildResult(BlockFactory, long, int) - Method in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
-
Build the corresponding block
- buildResult(BlockFactory, long, int) - Method in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
-
Build the corresponding block
- buildSort(List<SortBuilder<?>>) - Method in interface org.elasticsearch.compute.lucene.ShardContext
-
Build a "sort" configuration from an Elasticsearch style builder.
- built() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
-
Called during implementations of
Block.Builder.build()
as a last step to mark the Builder as closed and make sure that further closes don't double free memory. - built() - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
-
Called during implementations of
Block.Builder.build()
as a last step to mark the Builder as closed and make sure that further closes don't double free memory. - bytes - Variable in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
Buffer into which we encode values.
- bytes() - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Return the underlying bytes being built for direct manipulation.
- BYTES_REF - Enum constant in enum class org.elasticsearch.compute.data.ElementType
- BytesRefArrayState - Class in org.elasticsearch.compute.aggregation
-
Aggregator state for an array of BytesRefs.
- BytesRefBlock - Interface in org.elasticsearch.compute.data
-
Block that stores BytesRef values.
- BytesRefBlock.Builder - Interface in org.elasticsearch.compute.data
-
Builder for
BytesRefBlock
- BytesRefBucketedSort - Class in org.elasticsearch.compute.data.sort
-
Aggregates the top N variable length
BytesRef
values per bucket. - BytesRefBucketedSort(CircuitBreaker, String, BigArrays, SortOrder, int) - Constructor for class org.elasticsearch.compute.data.sort.BytesRefBucketedSort
- BytesRefs(int) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.BytesRefs
- BytesRefVector - Interface in org.elasticsearch.compute.data
-
Vector that stores BytesRef values.
- BytesRefVector.Builder - Interface in org.elasticsearch.compute.data
-
A builder that grows as needed.
- BytesRefVectorBlock - Class in org.elasticsearch.compute.data
-
Block view of a
BytesRefVector
. - bytesRefView() - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Returns a view of the data added as a
BytesRef
.
C
- cancel(String) - Method in class org.elasticsearch.compute.operator.Driver
- CARTESIAN - Enum constant in enum class org.elasticsearch.compute.aggregation.spatial.PointType
- CategorizeBlockHash - Class in org.elasticsearch.compute.aggregation.blockhash
-
BlockHash implementation for
Categorize
grouping function. - CategorizePackedValuesBlockHash - Class in org.elasticsearch.compute.aggregation.blockhash
-
BlockHash implementation for
Categorize
grouping function as first grouping expression, followed by one or mode other grouping expressions. - channel() - Method in record class org.elasticsearch.compute.aggregation.blockhash.BlockHash.GroupSpec
-
Returns the value of the
channel
record component. - channel() - Method in record class org.elasticsearch.compute.operator.MvExpandOperator.Factory
-
Returns the value of the
channel
record component. - channel() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.SortOrder
-
Returns the value of the
channel
record component. - channels() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.SupplierWithChannels
-
Returns the value of the
channels
record component. - checkForEarlyTermination() - Method in class org.elasticsearch.compute.operator.DriverContext
-
Checks if the Driver associated with this DriverContext has been cancelled or early terminated.
- checkState(boolean, String) - Static method in class org.elasticsearch.compute.operator.HashAggregationOperator
- circuitBreak(String, long) - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- clear() - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Reset the builder to an empty bytes array.
- close() - Method in class org.elasticsearch.compute.aggregation.AbstractArrayState
- close() - Method in class org.elasticsearch.compute.aggregation.AbstractFallibleArrayState
- close() - Method in class org.elasticsearch.compute.aggregation.Aggregator
- close() - Method in class org.elasticsearch.compute.aggregation.blockhash.AddPage
- close() - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizeBlockHash
- close() - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizePackedValuesBlockHash
- close() - Method in class org.elasticsearch.compute.aggregation.blockhash.TimeSeriesBlockHash
- close() - Method in class org.elasticsearch.compute.aggregation.BytesRefArrayState
- close() - Method in class org.elasticsearch.compute.aggregation.CountAggregatorFunction
- close() - Method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- close() - Method in class org.elasticsearch.compute.aggregation.FromPartialAggregatorFunction
- close() - Method in class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- close() - Method in class org.elasticsearch.compute.aggregation.GroupingAggregator
- close() - Method in class org.elasticsearch.compute.aggregation.IpArrayState
- close() - Method in class org.elasticsearch.compute.aggregation.RateDoubleAggregator.DoubleRateGroupingState
- close() - Method in class org.elasticsearch.compute.aggregation.RateFloatAggregator.FloatRateGroupingState
- close() - Method in class org.elasticsearch.compute.aggregation.RateIntAggregator.IntRateGroupingState
- close() - Method in class org.elasticsearch.compute.aggregation.RateLongAggregator.LongRateGroupingState
- close() - Method in class org.elasticsearch.compute.aggregation.table.AscendingSequenceRowInTableLookup
- close() - Method in class org.elasticsearch.compute.aggregation.table.EmptyRowInTableLookup
- close() - Method in class org.elasticsearch.compute.aggregation.ToPartialAggregatorFunction
- close() - Method in class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- close() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- close() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- close() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- close() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- close() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- close() - Method in class org.elasticsearch.compute.data.CompositeBlock
- close() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- close() - Method in class org.elasticsearch.compute.data.DocBlock
- close() - Method in class org.elasticsearch.compute.data.DocVector
- close() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- close() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- close() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- close() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- close() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- close() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- close() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- close() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- close() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- close() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- close() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- close() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- close() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- close() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- close() - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
- close() - Method in class org.elasticsearch.compute.data.BlockStreamInput
- close() - Method in record class org.elasticsearch.compute.data.BlockUtils.BuilderWrapper
- close() - Method in class org.elasticsearch.compute.data.BooleanVectorFixedBuilder
- close() - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- close() - Method in class org.elasticsearch.compute.data.DoubleVectorFixedBuilder
- close() - Method in class org.elasticsearch.compute.data.FloatVectorFixedBuilder
- close() - Method in class org.elasticsearch.compute.data.IntVectorFixedBuilder
- close() - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- close() - Method in class org.elasticsearch.compute.data.LongVectorFixedBuilder
- close() - Method in class org.elasticsearch.compute.data.SingletonOrdinalsBuilder
- close() - Method in class org.elasticsearch.compute.data.sort.BooleanBucketedSort
- close() - Method in class org.elasticsearch.compute.data.sort.BytesRefBucketedSort
- close() - Method in class org.elasticsearch.compute.data.sort.DoubleBucketedSort
- close() - Method in class org.elasticsearch.compute.data.sort.FloatBucketedSort
- close() - Method in class org.elasticsearch.compute.data.sort.IntBucketedSort
- close() - Method in class org.elasticsearch.compute.data.sort.IpBucketedSort
- close() - Method in class org.elasticsearch.compute.data.sort.LongBucketedSort
- close() - Method in record class org.elasticsearch.compute.data.ToMask
- close() - Method in class org.elasticsearch.compute.EsqlRefCountingListener
- close() - Method in class org.elasticsearch.compute.lucene.LuceneOperator
- close() - Method in class org.elasticsearch.compute.lucene.LuceneQueryEvaluator
- close() - Method in class org.elasticsearch.compute.lucene.LuceneSourceOperator
- close() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- close() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- close() - Method in class org.elasticsearch.compute.operator.AggregationOperator
- close() - Method in class org.elasticsearch.compute.operator.AsyncOperator
- close() - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
- close() - Method in class org.elasticsearch.compute.operator.ColumnExtractOperator
- close() - Method in class org.elasticsearch.compute.operator.Driver
- close() - Method in record class org.elasticsearch.compute.operator.DriverContext.Snapshot
- close() - Method in class org.elasticsearch.compute.operator.EvalOperator
- close() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- close() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator
- close() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator
- close() - Method in class org.elasticsearch.compute.operator.FilterOperator
- close() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator
- close() - Method in class org.elasticsearch.compute.operator.LimitOperator
- close() - Method in class org.elasticsearch.compute.operator.LocalSourceOperator
- close() - Method in class org.elasticsearch.compute.operator.lookup.EnrichQuerySourceOperator
- close() - Method in class org.elasticsearch.compute.operator.lookup.MergePositionsOperator
- close() - Method in class org.elasticsearch.compute.operator.lookup.RightChunkedLeftJoin
- close() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectEncoder
- close() - Method in class org.elasticsearch.compute.operator.MvExpandOperator
- close() - Method in interface org.elasticsearch.compute.operator.Operator
-
notifies the operator that it won't be used anymore (i.e.
- close() - Method in class org.elasticsearch.compute.operator.OrdinalsGroupingOperator
- close() - Method in class org.elasticsearch.compute.operator.OutputOperator
- close() - Method in class org.elasticsearch.compute.operator.PageConsumerOperator
- close() - Method in class org.elasticsearch.compute.operator.RowInTableLookupOperator
- close() - Method in class org.elasticsearch.compute.operator.ScoreOperator
- close() - Method in class org.elasticsearch.compute.operator.StringExtractOperator
- close() - Method in class org.elasticsearch.compute.operator.topn.ResultBuilderForNull
- close() - Method in class org.elasticsearch.compute.operator.topn.TopNOperator
- close(ActionListener<Void>) - Method in interface org.elasticsearch.compute.operator.exchange.RemoteSink
- closeInternal() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- closeInternal() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- closeInternal() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.CompositeBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.DocBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.DocVector
- closeInternal() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- closeInternal() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- closeInternal() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- closeInternal() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- closeInternal() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- closeInternal() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- collect() - Method in class org.elasticsearch.compute.operator.ResponseHeadersCollector
-
Called when a child request is completed to collect the response headers of the responding thread
- collect(boolean, int) - Method in class org.elasticsearch.compute.data.sort.BooleanBucketedSort
-
Collects a
value
into abucket
. - collect(double, int) - Method in class org.elasticsearch.compute.data.sort.DoubleBucketedSort
-
Collects a
value
into abucket
. - collect(float, int) - Method in class org.elasticsearch.compute.data.sort.FloatBucketedSort
-
Collects a
value
into abucket
. - collect(int, int) - Method in class org.elasticsearch.compute.data.sort.IntBucketedSort
-
Collects a
value
into abucket
. - collect(long, int) - Method in class org.elasticsearch.compute.data.sort.LongBucketedSort
-
Collects a
value
into abucket
. - collect(BytesRef, int) - Method in class org.elasticsearch.compute.data.sort.BytesRefBucketedSort
-
Collects a
value
into abucket
. - collect(BytesRef, int) - Method in class org.elasticsearch.compute.data.sort.IpBucketedSort
-
Collects a
value
into abucket
. - COLLECT - Enum constant in enum class org.elasticsearch.compute.operator.DriverContext.WarningsMode
- ColumnExtractOperator - Class in org.elasticsearch.compute.operator
- ColumnExtractOperator(ElementType[], EvalOperator.ExpressionEvaluator, ColumnExtractOperator.Evaluator, DriverContext) - Constructor for class org.elasticsearch.compute.operator.ColumnExtractOperator
- ColumnExtractOperator.Evaluator - Interface in org.elasticsearch.compute.operator
- ColumnExtractOperator.Factory - Record Class in org.elasticsearch.compute.operator
- ColumnLoadOperator - Class in org.elasticsearch.compute.operator
- ColumnLoadOperator(ColumnLoadOperator.Values, int) - Constructor for class org.elasticsearch.compute.operator.ColumnLoadOperator
- ColumnLoadOperator.Factory - Record Class in org.elasticsearch.compute.operator
-
Factory for
ColumnLoadOperator
. - ColumnLoadOperator.Values - Record Class in org.elasticsearch.compute.operator
- columns() - Method in record class org.elasticsearch.compute.operator.OutputOperator.OutputOperatorFactory
-
Returns the value of the
columns
record component. - combine(CountDistinctBooleanAggregator.GroupingState, int, boolean) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBooleanAggregator
- combine(CountDistinctBooleanAggregator.SingleState, boolean) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBooleanAggregator
- combine(HllStates.GroupingState, int, double) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctDoubleAggregator
- combine(HllStates.GroupingState, int, float) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctFloatAggregator
- combine(HllStates.GroupingState, int, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctIntAggregator
- combine(HllStates.GroupingState, int, long) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctLongAggregator
- combine(HllStates.GroupingState, int, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBytesRefAggregator
- combine(HllStates.SingleState, double) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctDoubleAggregator
- combine(HllStates.SingleState, float) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctFloatAggregator
- combine(HllStates.SingleState, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctIntAggregator
- combine(HllStates.SingleState, long) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctLongAggregator
- combine(HllStates.SingleState, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBytesRefAggregator
- combine(RateDoubleAggregator.DoubleRateGroupingState, int, long, double) - Static method in class org.elasticsearch.compute.aggregation.RateDoubleAggregator
- combine(RateFloatAggregator.FloatRateGroupingState, int, long, float) - Static method in class org.elasticsearch.compute.aggregation.RateFloatAggregator
- combine(RateIntAggregator.IntRateGroupingState, int, long, int) - Static method in class org.elasticsearch.compute.aggregation.RateIntAggregator
- combine(RateLongAggregator.LongRateGroupingState, int, long, long) - Static method in class org.elasticsearch.compute.aggregation.RateLongAggregator
- combine(StdDevStates.GroupingState, int, double) - Static method in class org.elasticsearch.compute.aggregation.StdDevDoubleAggregator
- combine(StdDevStates.GroupingState, int, float) - Static method in class org.elasticsearch.compute.aggregation.StdDevFloatAggregator
- combine(StdDevStates.GroupingState, int, int) - Static method in class org.elasticsearch.compute.aggregation.StdDevIntAggregator
- combine(StdDevStates.GroupingState, int, long) - Static method in class org.elasticsearch.compute.aggregation.StdDevLongAggregator
- combine(StdDevStates.SingleState, double) - Static method in class org.elasticsearch.compute.aggregation.StdDevDoubleAggregator
- combine(StdDevStates.SingleState, float) - Static method in class org.elasticsearch.compute.aggregation.StdDevFloatAggregator
- combine(StdDevStates.SingleState, int) - Static method in class org.elasticsearch.compute.aggregation.StdDevIntAggregator
- combine(StdDevStates.SingleState, long) - Static method in class org.elasticsearch.compute.aggregation.StdDevLongAggregator
- combineIntermediate(CountDistinctBooleanAggregator.GroupingState, int, boolean, boolean) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBooleanAggregator
- combineIntermediate(CountDistinctBooleanAggregator.SingleState, boolean, boolean) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBooleanAggregator
- combineIntermediate(HllStates.GroupingState, int, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBytesRefAggregator
- combineIntermediate(HllStates.GroupingState, int, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctDoubleAggregator
- combineIntermediate(HllStates.GroupingState, int, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctFloatAggregator
- combineIntermediate(HllStates.GroupingState, int, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctIntAggregator
- combineIntermediate(HllStates.GroupingState, int, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctLongAggregator
- combineIntermediate(HllStates.SingleState, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBytesRefAggregator
- combineIntermediate(HllStates.SingleState, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctDoubleAggregator
- combineIntermediate(HllStates.SingleState, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctFloatAggregator
- combineIntermediate(HllStates.SingleState, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctIntAggregator
- combineIntermediate(HllStates.SingleState, BytesRef) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctLongAggregator
- combineIntermediate(RateDoubleAggregator.DoubleRateGroupingState, int, LongBlock, DoubleBlock, double, int) - Static method in class org.elasticsearch.compute.aggregation.RateDoubleAggregator
- combineIntermediate(RateFloatAggregator.FloatRateGroupingState, int, LongBlock, FloatBlock, double, int) - Static method in class org.elasticsearch.compute.aggregation.RateFloatAggregator
- combineIntermediate(RateIntAggregator.IntRateGroupingState, int, LongBlock, IntBlock, double, int) - Static method in class org.elasticsearch.compute.aggregation.RateIntAggregator
- combineIntermediate(RateLongAggregator.LongRateGroupingState, int, LongBlock, LongBlock, double, int) - Static method in class org.elasticsearch.compute.aggregation.RateLongAggregator
- combineIntermediate(StdDevStates.GroupingState, int, double, double, long) - Static method in class org.elasticsearch.compute.aggregation.StdDevDoubleAggregator
- combineIntermediate(StdDevStates.GroupingState, int, double, double, long) - Static method in class org.elasticsearch.compute.aggregation.StdDevFloatAggregator
- combineIntermediate(StdDevStates.GroupingState, int, double, double, long) - Static method in class org.elasticsearch.compute.aggregation.StdDevIntAggregator
- combineIntermediate(StdDevStates.GroupingState, int, double, double, long) - Static method in class org.elasticsearch.compute.aggregation.StdDevLongAggregator
- combineIntermediate(StdDevStates.SingleState, double, double, long) - Static method in class org.elasticsearch.compute.aggregation.StdDevDoubleAggregator
- combineIntermediate(StdDevStates.SingleState, double, double, long) - Static method in class org.elasticsearch.compute.aggregation.StdDevFloatAggregator
- combineIntermediate(StdDevStates.SingleState, double, double, long) - Static method in class org.elasticsearch.compute.aggregation.StdDevIntAggregator
- combineIntermediate(StdDevStates.SingleState, double, double, long) - Static method in class org.elasticsearch.compute.aggregation.StdDevLongAggregator
- combineStates(CountDistinctBooleanAggregator.GroupingState, int, CountDistinctBooleanAggregator.GroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBooleanAggregator
- combineStates(HllStates.GroupingState, int, HllStates.GroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBytesRefAggregator
- combineStates(HllStates.GroupingState, int, HllStates.GroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctDoubleAggregator
- combineStates(HllStates.GroupingState, int, HllStates.GroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctFloatAggregator
- combineStates(HllStates.GroupingState, int, HllStates.GroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctIntAggregator
- combineStates(HllStates.GroupingState, int, HllStates.GroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctLongAggregator
- combineStates(RateDoubleAggregator.DoubleRateGroupingState, int, RateDoubleAggregator.DoubleRateGroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.RateDoubleAggregator
- combineStates(RateFloatAggregator.FloatRateGroupingState, int, RateFloatAggregator.FloatRateGroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.RateFloatAggregator
- combineStates(RateIntAggregator.IntRateGroupingState, int, RateIntAggregator.IntRateGroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.RateIntAggregator
- combineStates(RateLongAggregator.LongRateGroupingState, int, RateLongAggregator.LongRateGroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.RateLongAggregator
- combineStates(StdDevStates.GroupingState, int, StdDevStates.GroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.StdDevDoubleAggregator
- combineStates(StdDevStates.GroupingState, int, StdDevStates.GroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.StdDevFloatAggregator
- combineStates(StdDevStates.GroupingState, int, StdDevStates.GroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.StdDevIntAggregator
- combineStates(StdDevStates.GroupingState, int, StdDevStates.GroupingState, int) - Static method in class org.elasticsearch.compute.aggregation.StdDevLongAggregator
- completedOperators() - Method in class org.elasticsearch.compute.operator.DriverStatus
-
Status of each completed
Operator
in the driver. - completedPages() - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- COMPOSITE - Enum constant in enum class org.elasticsearch.compute.data.ElementType
-
Composite blocks which contain array of sub-blocks.
- CompositeBlock - Class in org.elasticsearch.compute.data
- CompositeBlock(Block[]) - Constructor for class org.elasticsearch.compute.data.CompositeBlock
- computeEnvelope(Geometry) - Method in enum class org.elasticsearch.compute.aggregation.spatial.PointType
- computeRow(BytesRefBlock, int, Block.Builder[], BytesRef) - Method in interface org.elasticsearch.compute.operator.ColumnExtractOperator.Evaluator
- CONSTANT_NULL_FACTORY - Static variable in class org.elasticsearch.compute.operator.EvalOperator
- constantBlock(BlockFactory, Object, int) - Static method in class org.elasticsearch.compute.data.BlockUtils
- ConstantNullVector - Class in org.elasticsearch.compute.data
-
This vector is never instantiated.
- copyBytes(BytesRef) - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Set the content of the builder to the given bytes.
- copyFrom(Block, int, int) - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- copyFrom(Block, int, int) - Method in interface org.elasticsearch.compute.data.Block.Builder
-
Copy the values in
block
frombeginInclusive
toendExclusive
into this builder. - copyFrom(Block, int, int) - Method in interface org.elasticsearch.compute.data.BooleanBlock.Builder
- copyFrom(Block, int, int) - Method in interface org.elasticsearch.compute.data.BytesRefBlock.Builder
- copyFrom(Block, int, int) - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- copyFrom(Block, int, int) - Method in interface org.elasticsearch.compute.data.DoubleBlock.Builder
- copyFrom(Block, int, int) - Method in interface org.elasticsearch.compute.data.FloatBlock.Builder
- copyFrom(Block, int, int) - Method in interface org.elasticsearch.compute.data.IntBlock.Builder
- copyFrom(Block, int, int) - Method in interface org.elasticsearch.compute.data.LongBlock.Builder
- copyFrom(Block, int, int) - Method in class org.elasticsearch.compute.data.SingletonOrdinalsBuilder
- copyFrom(BooleanBlock, int) - Method in interface org.elasticsearch.compute.data.BooleanBlock.Builder
-
Copy the values in
block
atposition
. - copyFrom(BooleanBlock, int, int) - Method in interface org.elasticsearch.compute.data.BooleanBlock.Builder
-
Copy the values in
block
frombeginInclusive
toendExclusive
into this builder. - copyFrom(BytesRefBlock, int, int) - Method in interface org.elasticsearch.compute.data.BytesRefBlock.Builder
-
Copy the values in
block
frombeginInclusive
toendExclusive
into this builder. - copyFrom(BytesRefBlock, int, BytesRef) - Method in interface org.elasticsearch.compute.data.BytesRefBlock.Builder
-
Copy the values in
block
atposition
. - copyFrom(DoubleBlock, int) - Method in interface org.elasticsearch.compute.data.DoubleBlock.Builder
-
Copy the values in
block
atposition
. - copyFrom(DoubleBlock, int, int) - Method in interface org.elasticsearch.compute.data.DoubleBlock.Builder
-
Copy the values in
block
frombeginInclusive
toendExclusive
into this builder. - copyFrom(FloatBlock, int) - Method in interface org.elasticsearch.compute.data.FloatBlock.Builder
-
Copy the values in
block
atposition
. - copyFrom(FloatBlock, int, int) - Method in interface org.elasticsearch.compute.data.FloatBlock.Builder
-
Copy the values in
block
frombeginInclusive
toendExclusive
into this builder. - copyFrom(IntBlock, int) - Method in interface org.elasticsearch.compute.data.IntBlock.Builder
-
Copy the values in
block
atposition
. - copyFrom(IntBlock, int, int) - Method in interface org.elasticsearch.compute.data.IntBlock.Builder
-
Copy the values in
block
frombeginInclusive
toendExclusive
into this builder. - copyFrom(LongBlock, int) - Method in interface org.elasticsearch.compute.data.LongBlock.Builder
-
Copy the values in
block
atposition
. - copyFrom(LongBlock, int, int) - Method in interface org.elasticsearch.compute.data.LongBlock.Builder
-
Copy the values in
block
frombeginInclusive
toendExclusive
into this builder. - count() - Method in class org.elasticsearch.compute.aggregation.WelfordAlgorithm
- count() - Method in record class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.AggregateMetricDoubleLiteral
-
Returns the value of the
count
record component. - count() - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- COUNT - Enum constant in enum class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.Metric
- CountAggregatorFunction - Class in org.elasticsearch.compute.aggregation
- CountDistinctBooleanAggregator - Class in org.elasticsearch.compute.aggregation
- CountDistinctBooleanAggregator() - Constructor for class org.elasticsearch.compute.aggregation.CountDistinctBooleanAggregator
- CountDistinctBytesRefAggregator - Class in org.elasticsearch.compute.aggregation
- CountDistinctBytesRefAggregator() - Constructor for class org.elasticsearch.compute.aggregation.CountDistinctBytesRefAggregator
- CountDistinctDoubleAggregator - Class in org.elasticsearch.compute.aggregation
- CountDistinctDoubleAggregator() - Constructor for class org.elasticsearch.compute.aggregation.CountDistinctDoubleAggregator
- CountDistinctFloatAggregator - Class in org.elasticsearch.compute.aggregation
- CountDistinctFloatAggregator() - Constructor for class org.elasticsearch.compute.aggregation.CountDistinctFloatAggregator
- CountDistinctIntAggregator - Class in org.elasticsearch.compute.aggregation
- CountDistinctIntAggregator() - Constructor for class org.elasticsearch.compute.aggregation.CountDistinctIntAggregator
- CountDistinctLongAggregator - Class in org.elasticsearch.compute.aggregation
- CountDistinctLongAggregator() - Constructor for class org.elasticsearch.compute.aggregation.CountDistinctLongAggregator
- CountGroupingAggregatorFunction - Class in org.elasticsearch.compute.aggregation
- counts() - Method in record class org.elasticsearch.compute.operator.DriverSleeps
-
Returns the value of the
counts
record component. - cpuNanos() - Method in class org.elasticsearch.compute.operator.DriverProfile
-
Nanos this
Driver
has been running on the cpu. - cpuNanos() - Method in class org.elasticsearch.compute.operator.DriverStatus
-
Nanos this
Driver
has been running on the cpu. - create(int, int, int, List<? extends ShardContext>, Function<ShardContext, Query>) - Static method in class org.elasticsearch.compute.lucene.TimeSeriesSortedSourceOperatorFactory
- create(List<? extends ShardContext>, Function<ShardContext, Weight>, DataPartitioning, int) - Static method in class org.elasticsearch.compute.lucene.LuceneSliceQueue
- create(List<Integer>) - Static method in class org.elasticsearch.compute.aggregation.CountAggregatorFunction
- create(DriverContext, List<Integer>) - Static method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- createExchangeSink(Runnable) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkHandler
-
Create a new exchange sink for exchanging data
- createExchangeSource() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceHandler
-
Create a new
ExchangeSource
for exchanging data - createNoMatchVector(BlockFactory, int) - Method in class org.elasticsearch.compute.lucene.LuceneQueryEvaluator
-
Creates a vector where all positions correspond to elements that don't match the query
- createNoMatchVector(BlockFactory, int) - Method in class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator
- createNoMatchVector(BlockFactory, int) - Method in class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator
- createSinkHandler(String, int) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
-
Creates an
ExchangeSinkHandler
for the specified exchange id. - createTask(long, String, String, TaskId, Map<String, String>) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeRequest
- createVectorBuilder(BlockFactory, int) - Method in class org.elasticsearch.compute.lucene.LuceneQueryEvaluator
-
Creates the corresponding vector builder to store the results of evaluating the query
- createVectorBuilder(BlockFactory, int) - Method in class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator
- createVectorBuilder(BlockFactory, int) - Method in class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator
- createWarnings(DriverContext.WarningsMode, int, int, String) - Static method in class org.elasticsearch.compute.operator.Warnings
-
Create a new warnings object based on the given mode
- createWarningsTreatedAsFalse(DriverContext.WarningsMode, int, int, String) - Static method in class org.elasticsearch.compute.operator.Warnings
-
Create a new warnings object based on the given mode which warns that it treats the result as
false
. - createWeight(IndexSearcher, ScoreMode, float) - Method in class org.elasticsearch.compute.querydsl.query.SingleValueMatchQuery
- current() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
D
- dataPartitioning - Variable in class org.elasticsearch.compute.lucene.LuceneOperator.Factory
- DataPartitioning - Enum Class in org.elasticsearch.compute.lucene
- dataType() - Method in record class org.elasticsearch.compute.aggregation.IntermediateStateDesc
-
Returns the value of the
dataType
record component. - dateTermQueryList(MappedFieldType, SearchExecutionContext, LongBlock) - Static method in class org.elasticsearch.compute.operator.lookup.QueryList
-
Returns a list of term queries for the given field and the input block of
date
field values. - decode(BytesRef) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- decode(Block.Builder, BatchEncoder.IsNull, BytesRef[], int) - Method in interface org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Decoder
- decodeBoolean(BytesRef) - Method in class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- decodeBoolean(BytesRef) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- decodeBytesRef(BytesRef, BytesRef) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- decodeDouble(BytesRef) - Method in class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- decodeDouble(BytesRef) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- decodeFloat(BytesRef) - Method in class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- decodeFloat(BytesRef) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- decodeInt(BytesRef) - Method in class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- decodeInt(BytesRef) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- decodeKey(BytesRef) - Method in class org.elasticsearch.compute.operator.topn.ResultBuilderForNull
- decodeLatitude(long) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- decodeLong(BytesRef) - Method in class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- decodeLong(BytesRef) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- decodeLongitude(long) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- decodePoint(BytesRef) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- decoder(ElementType) - Static method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder
-
Get a
BatchEncoder.Decoder
for the providedElementType
. - decodeValue(BytesRef) - Method in class org.elasticsearch.compute.operator.topn.ResultBuilderForNull
- decodeX(long) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- decodeY(long) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- decRef() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- decRef() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- decRef() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- decRef() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- decRef() - Method in class org.elasticsearch.compute.data.CompositeBlock
- decRef() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- decRef() - Method in class org.elasticsearch.compute.data.DocBlock
- decRef() - Method in class org.elasticsearch.compute.data.DocVector
- decRef() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- decRef() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- decRef() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- decRef() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- decRef() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- decRef() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- decRef() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- decRef() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- decRef() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- decRef() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- decRef() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- decRef() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- decRef() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- decRef() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- decRef() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- dedupeToBlock(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBoolean
-
Dedupe values using an adaptive algorithm based on the size of the input list.
- dedupeToBlockAdaptive(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBytesRef
-
Remove duplicate values from each position and write the results to a
Block
using an adaptive algorithm based on the size of the input list. - dedupeToBlockAdaptive(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeDouble
-
Remove duplicate values from each position and write the results to a
Block
using an adaptive algorithm based on the size of the input list. - dedupeToBlockAdaptive(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeInt
-
Remove duplicate values from each position and write the results to a
Block
using an adaptive algorithm based on the size of the input list. - dedupeToBlockAdaptive(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeLong
-
Remove duplicate values from each position and write the results to a
Block
using an adaptive algorithm based on the size of the input list. - dedupeToBlockAdaptive(Block, BlockFactory) - Static method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe
-
Remove duplicate values from each position and write the results to a
Block
using an adaptive algorithm based on the size of the input list. - dedupeToBlockUsingCopyAndSort(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBytesRef
-
Remove duplicate values from each position and write the results to a
Block
using an algorithm with very low overhead butn^2
case complexity for larger. - dedupeToBlockUsingCopyAndSort(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeDouble
-
Remove duplicate values from each position and write the results to a
Block
using an algorithm with very low overhead butn^2
case complexity for larger. - dedupeToBlockUsingCopyAndSort(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeInt
-
Remove duplicate values from each position and write the results to a
Block
using an algorithm with very low overhead butn^2
case complexity for larger. - dedupeToBlockUsingCopyAndSort(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeLong
-
Remove duplicate values from each position and write the results to a
Block
using an algorithm with very low overhead butn^2
case complexity for larger. - dedupeToBlockUsingCopyAndSort(Block, BlockFactory) - Static method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe
-
Remove duplicate values from each position and write the results to a
Block
using an algorithm that sorts all values. - dedupeToBlockUsingCopyMissing(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBytesRef
-
Remove duplicate values from each position and write the results to a
Block
using an algorithm that sorts all values. - dedupeToBlockUsingCopyMissing(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeDouble
-
Remove duplicate values from each position and write the results to a
Block
using an algorithm that sorts all values. - dedupeToBlockUsingCopyMissing(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeInt
-
Remove duplicate values from each position and write the results to a
Block
using an algorithm that sorts all values. - dedupeToBlockUsingCopyMissing(BlockFactory) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeLong
-
Remove duplicate values from each position and write the results to a
Block
using an algorithm that sorts all values. - dedupeToBlockUsingCopyMissing(Block, BlockFactory) - Static method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe
-
Remove duplicate values from each position and write the results to a
Block
using an algorithm with very low overhead butn^2
case complexity for larger. - DEDUPLICATED_AND_SORTED_ASCENDING - Enum constant in enum class org.elasticsearch.compute.data.Block.MvOrdering
- DEDUPLICATED_UNORDERD - Enum constant in enum class org.elasticsearch.compute.data.Block.MvOrdering
- deepCopyOf(Block, BlockFactory) - Static method in class org.elasticsearch.compute.data.BlockUtils
-
Returns a deep copy of the given block, using the blockFactory for creating the copy block.
- DEFAULT_MAX_BLOCK_PRIMITIVE_ARRAY_SIZE - Static variable in class org.elasticsearch.compute.data.BlockFactory
- DEFAULT_MAX_ITERATIONS - Static variable in class org.elasticsearch.compute.operator.Driver
- DEFAULT_MAX_PAGE_SIZE - Static variable in class org.elasticsearch.compute.operator.lookup.EnrichQuerySourceOperator
- DEFAULT_SORTABLE - Static variable in interface org.elasticsearch.compute.operator.topn.TopNEncoder
-
An encoder that encodes values such that sorting the bytes sorts the values.
- DEFAULT_STATUS_INTERVAL - Static variable in class org.elasticsearch.compute.operator.Driver
-
Minimum time between updating status.
- DEFAULT_TIME_BEFORE_YIELDING - Static variable in class org.elasticsearch.compute.operator.Driver
- DEFAULT_UNSORTABLE - Static variable in interface org.elasticsearch.compute.operator.topn.TopNEncoder
-
An encoder that encodes values as compactly as possible without making the encoded bytes sortable.
- Describable - Interface in org.elasticsearch.compute
-
A component capable of describing itself.
- describe() - Method in record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
- describe() - Method in interface org.elasticsearch.compute.Describable
-
Returns a description of the component.
- describe() - Method in class org.elasticsearch.compute.lucene.LuceneCountOperator.Factory
- describe() - Method in class org.elasticsearch.compute.lucene.LuceneMaxFactory
- describe() - Method in class org.elasticsearch.compute.lucene.LuceneMinFactory
- describe() - Method in class org.elasticsearch.compute.lucene.LuceneSourceOperator.Factory
- describe() - Method in class org.elasticsearch.compute.lucene.LuceneTopNSourceOperator.Factory
- describe() - Method in class org.elasticsearch.compute.lucene.TimeSeriesSortedSourceOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Factory
- describe() - Method in record class org.elasticsearch.compute.operator.AggregationOperator.AggregationOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.ColumnExtractOperator.Factory
- describe() - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Factory
- describe() - Method in class org.elasticsearch.compute.operator.Driver
- describe() - Method in record class org.elasticsearch.compute.operator.EvalOperator.EvalOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.ExchangeSinkOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.ExchangeSourceOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.FilterOperator.FilterOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
- describe() - Method in class org.elasticsearch.compute.operator.LimitOperator.Factory
- describe() - Method in record class org.elasticsearch.compute.operator.LocalSourceOperator.LocalSourceFactory
- describe() - Method in record class org.elasticsearch.compute.operator.MvExpandOperator.Factory
- describe() - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.OutputOperator.OutputOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.ProjectOperator.ProjectOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Factory
- describe() - Method in record class org.elasticsearch.compute.operator.ScoreOperator.ScoreOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.ShowOperator.ShowOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.StringExtractOperator.StringExtractOperatorFactory
- describe() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Final
- describe() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
- describe() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
- describe() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
- describe(StringBuilder) - Method in class org.elasticsearch.compute.lucene.LuceneCountOperator
- describe(StringBuilder) - Method in class org.elasticsearch.compute.lucene.LuceneOperator
- describe(StringBuilder) - Method in class org.elasticsearch.compute.lucene.LuceneSourceOperator
- describe(StringBuilder) - Method in class org.elasticsearch.compute.lucene.LuceneTopNSourceOperator
- description() - Method in class org.elasticsearch.compute.operator.DriverProfile
-
Description of the task this driver is running.
- description() - Method in class org.elasticsearch.compute.operator.DriverStatus
-
Description of the task this driver is running.
- doAddInput(Page) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator
- doAddInput(Page) - Method in class org.elasticsearch.compute.operator.OutputOperator
- doAddInput(Page) - Method in class org.elasticsearch.compute.operator.PageConsumerOperator
- doAddInput(Page) - Method in class org.elasticsearch.compute.operator.SinkOperator
- doc() - Method in record class org.elasticsearch.compute.data.BlockUtils.Doc
-
Returns the value of the
doc
record component. - Doc(int, int, int) - Constructor for record class org.elasticsearch.compute.data.BlockUtils.Doc
-
Creates an instance of a
Doc
record class. - DOC - Enum constant in enum class org.elasticsearch.compute.data.ElementType
-
Blocks that reference individual lucene documents.
- DOC - Enum constant in enum class org.elasticsearch.compute.lucene.DataPartitioning
- DocBlock - Class in org.elasticsearch.compute.data
- DocBlock.Builder - Class in org.elasticsearch.compute.data
- docChannel() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Factory
-
Returns the value of the
docChannel
record component. - docChannel() - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Returns the value of the
docChannel
record component. - doClose() - Method in class org.elasticsearch.compute.operator.AsyncOperator
- doClose() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
- docs() - Method in class org.elasticsearch.compute.data.DocVector
- DocVector - Class in org.elasticsearch.compute.data
-
Vector
where each entry references a lucene document. - DocVector(IntVector, IntVector, IntVector, Boolean) - Constructor for class org.elasticsearch.compute.data.DocVector
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.DocBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- doesHaveMultivaluedFields() - Method in interface org.elasticsearch.compute.data.Block
-
Does this block have multivalued fields? Unlike
Block.mayHaveMultivaluedFields()
this will never return a false positive. - doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.CompositeBlock
- doesHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- DONE - Enum constant in enum class org.elasticsearch.compute.operator.DriverStatus.Status
- doStart() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
- doStop() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
- DOUBLE - Enum constant in enum class org.elasticsearch.compute.data.ElementType
- DOUBLE - Enum constant in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
- DOUBLE - Enum constant in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
- DoubleBigArrayBlock - Class in org.elasticsearch.compute.data
-
Block implementation that stores values in a
DoubleBigArrayVector
. - DoubleBigArrayBlock(DoubleArray, int, int[], BitSet, Block.MvOrdering, BlockFactory) - Constructor for class org.elasticsearch.compute.data.DoubleBigArrayBlock
- DoubleBigArrayVector - Class in org.elasticsearch.compute.data
-
Vector implementation that defers to an enclosed
DoubleArray
. - DoubleBigArrayVector(DoubleArray, int, BlockFactory) - Constructor for class org.elasticsearch.compute.data.DoubleBigArrayVector
- DoubleBlock - Interface in org.elasticsearch.compute.data
-
Block that stores double values.
- DoubleBlock.Builder - Interface in org.elasticsearch.compute.data
-
Builder for
DoubleBlock
- DoubleBucketedSort - Class in org.elasticsearch.compute.data.sort
-
Aggregates the top N double values per bucket.
- DoubleBucketedSort(BigArrays, SortOrder, int) - Constructor for class org.elasticsearch.compute.data.sort.DoubleBucketedSort
- Doubles(int) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Doubles
- DoubleVector - Interface in org.elasticsearch.compute.data
-
Vector that stores double values.
- DoubleVector.Builder - Interface in org.elasticsearch.compute.data
-
A builder that grows as needed.
- DoubleVector.FixedBuilder - Interface in org.elasticsearch.compute.data
-
A builder that never grows.
- DoubleVectorBlock - Class in org.elasticsearch.compute.data
-
Block view of a
DoubleVector
. - DoubleVectorFixedBuilder - Class in org.elasticsearch.compute.data
-
Builder for
DoubleVector
s that never grows. - Driver - Class in org.elasticsearch.compute.operator
- Driver(String, String, long, long, DriverContext, Supplier<String>, SourceOperator, List<Operator>, SinkOperator, TimeValue, Releasable) - Constructor for class org.elasticsearch.compute.operator.Driver
-
Creates a new driver with a chain of operators.
- driverContext() - Method in class org.elasticsearch.compute.operator.Driver
- DriverContext - Class in org.elasticsearch.compute.operator
-
A driver-local context that is shared across operators.
- DriverContext(BigArrays, BlockFactory) - Constructor for class org.elasticsearch.compute.operator.DriverContext
- DriverContext.Snapshot - Record Class in org.elasticsearch.compute.operator
-
A snapshot of the driver context.
- DriverContext.WarningsMode - Enum Class in org.elasticsearch.compute.operator
-
Indicates the behavior Evaluators of this context should use for reporting warnings
- DriverEarlyTerminationException - Exception Class in org.elasticsearch.compute.operator
-
An exception indicates that a compute should be terminated early as the downstream pipeline has enough or no long requires more data.
- DriverEarlyTerminationException(String) - Constructor for exception class org.elasticsearch.compute.operator.DriverEarlyTerminationException
- DriverProfile - Class in org.elasticsearch.compute.operator
-
Profile results from a single
Driver
. - DriverProfile(String, long, long, long, long, long, List<DriverStatus.OperatorStatus>, DriverSleeps) - Constructor for class org.elasticsearch.compute.operator.DriverProfile
- DriverProfile(StreamInput) - Constructor for class org.elasticsearch.compute.operator.DriverProfile
- DriverRunner - Class in org.elasticsearch.compute.operator
-
Run a set of drivers to completion.
- DriverRunner(ThreadContext) - Constructor for class org.elasticsearch.compute.operator.DriverRunner
- DriverSleeps - Record Class in org.elasticsearch.compute.operator
-
Records of the times the driver has slept.
- DriverSleeps(Map<String, Long>, List<DriverSleeps.Sleep>, List<DriverSleeps.Sleep>) - Constructor for record class org.elasticsearch.compute.operator.DriverSleeps
-
Creates an instance of a
DriverSleeps
record class. - DriverSleeps.Sleep - Record Class in org.elasticsearch.compute.operator
-
A record of a time the driver slept.
- DriverStatus - Class in org.elasticsearch.compute.operator
-
Task.Status
reported from aDriver
to be reported by the tasks api. - DriverStatus(StreamInput) - Constructor for class org.elasticsearch.compute.operator.DriverStatus
- DriverStatus.OperatorStatus - Class in org.elasticsearch.compute.operator
-
Status of an
Operator
. - DriverStatus.Status - Enum Class in org.elasticsearch.compute.operator
- DriverTaskRunner - Class in org.elasticsearch.compute.operator
-
A
DriverRunner
that executesDriver
with a child task so that we can retrieve the progress with the Task API. - DriverTaskRunner(TransportService, Executor) - Constructor for class org.elasticsearch.compute.operator.DriverTaskRunner
E
- eagerEvalSafeInLazy() - Method in interface org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator.Factory
-
true
if it is safe and fast to evaluate this expression eagerly inEvalOperator.ExpressionEvaluator
s that need to be lazy, likeCASE
. - elementSize() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
-
The number of bytes used to represent each value element.
- elementSize() - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
-
The number of bytes used to represent each value element.
- elementSize() - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- elementType() - Method in record class org.elasticsearch.compute.aggregation.blockhash.BlockHash.GroupSpec
-
Returns the value of the
elementType
record component. - elementType() - Method in interface org.elasticsearch.compute.data.Block
-
Returns the element type of this block.
- elementType() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- elementType() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- elementType() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- elementType() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- elementType() - Method in class org.elasticsearch.compute.data.CompositeBlock
- elementType() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- elementType() - Method in class org.elasticsearch.compute.data.DocBlock
- elementType() - Method in class org.elasticsearch.compute.data.DocVector
- elementType() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- elementType() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- elementType() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- elementType() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- elementType() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- elementType() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- elementType() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- elementType() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- elementType() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- elementType() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- elementType() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- elementType() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- elementType() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- elementType() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- elementType() - Method in interface org.elasticsearch.compute.data.Vector
-
Returns the element type of this vector.
- ElementType - Enum Class in org.elasticsearch.compute.data
- elementTypes() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
-
Returns the value of the
elementTypes
record component. - empty() - Static method in record class org.elasticsearch.compute.operator.DriverSleeps
- Empty() - Constructor for record class org.elasticsearch.compute.aggregation.SeenGroupIds.Empty
-
Creates an instance of a
Empty
record class. - EmptyRowInTableLookup - Class in org.elasticsearch.compute.aggregation.table
-
RowInTableLookup
for an empty table. - EmptyRowInTableLookup(BlockFactory) - Constructor for class org.elasticsearch.compute.aggregation.table.EmptyRowInTableLookup
- enableGroupIdTracking(SeenGroupIds) - Method in class org.elasticsearch.compute.aggregation.AbstractArrayState
-
Switches this array state into tracking which group ids are set.
- enableGroupIdTracking(SeenGroupIds) - Method in class org.elasticsearch.compute.aggregation.BytesRefArrayState
-
Switches this array state into tracking which group ids are set.
- enableGroupIdTracking(SeenGroupIds) - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorState
- enableGroupIdTracking(SeenGroupIds) - Method in class org.elasticsearch.compute.aggregation.RateDoubleAggregator.DoubleRateGroupingState
- enableGroupIdTracking(SeenGroupIds) - Method in class org.elasticsearch.compute.aggregation.RateFloatAggregator.FloatRateGroupingState
- enableGroupIdTracking(SeenGroupIds) - Method in class org.elasticsearch.compute.aggregation.RateIntAggregator.IntRateGroupingState
- enableGroupIdTracking(SeenGroupIds) - Method in class org.elasticsearch.compute.aggregation.RateLongAggregator.LongRateGroupingState
- encode(boolean) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Booleans
-
Encode a
boolean
and advance to the next position. - encode(double) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Doubles
-
Encode a
double
and advance to the next position. - encode(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Ints
-
Encode an
int
into the current position and advance to the next position. - encode(long) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Longs
-
Encode a
long
and advance to the next position. - encode(BytesRef) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.BytesRefs
-
Encode a
BytesRef
and advance to the next position. - encodeBoolean(boolean, BreakingBytesRefBuilder) - Method in class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- encodeBoolean(boolean, BreakingBytesRefBuilder) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- encodeBytesRef(BytesRef, BreakingBytesRefBuilder) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- encodeDouble(double, BreakingBytesRefBuilder) - Method in class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- encodeDouble(double, BreakingBytesRefBuilder) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- encodeFloat(float, BreakingBytesRefBuilder) - Method in class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- encodeFloat(float, BreakingBytesRefBuilder) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- encodeInt(int, BreakingBytesRefBuilder) - Method in class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- encodeInt(int, BreakingBytesRefBuilder) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- encodeLong(long, BreakingBytesRefBuilder) - Method in class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- encodeLong(long, BreakingBytesRefBuilder) - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
- encodeLongitude(double) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- encodeNextBatch() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectEncoder
- encodeNextBatch() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder
-
Encodes the next batch of entries.
- encodeNextBatch() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
Encodes the next batch of entries.
- encodeNull() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
Implementations of
BatchEncoder.MVEncoder.readNextBatch()
should call this to encode an entirely null position. - encoder() - Method in enum class org.elasticsearch.compute.aggregation.spatial.PointType
- encoders() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
-
Returns the value of the
encoders
record component. - endPosition() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
Implementations of
BatchEncoder.MVEncoder.readNextBatch()
should call this to end the current position. - endPositionEntry() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- endPositionEntry() - Method in interface org.elasticsearch.compute.data.Block.Builder
-
Ends the current multi-value entry.
- endPositionEntry() - Method in interface org.elasticsearch.compute.data.BooleanBlock.Builder
- endPositionEntry() - Method in interface org.elasticsearch.compute.data.BytesRefBlock.Builder
- endPositionEntry() - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- endPositionEntry() - Method in interface org.elasticsearch.compute.data.DoubleBlock.Builder
- endPositionEntry() - Method in interface org.elasticsearch.compute.data.FloatBlock.Builder
- endPositionEntry() - Method in interface org.elasticsearch.compute.data.IntBlock.Builder
- endPositionEntry() - Method in interface org.elasticsearch.compute.data.LongBlock.Builder
- endPositionEntry() - Method in class org.elasticsearch.compute.data.SingletonOrdinalsBuilder
- EnrichQuerySourceOperator - Class in org.elasticsearch.compute.operator.lookup
-
Lookup document IDs for the input queries.
- EnrichQuerySourceOperator(BlockFactory, int, QueryList, IndexReader, Warnings) - Constructor for class org.elasticsearch.compute.operator.lookup.EnrichQuerySourceOperator
- ensureCapacity() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- ensureCapacity() - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
- ensureCapacity(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Doubles
-
Make sure there is capacity for this many
double
s, growing the buffer if needed. - ensureCapacity(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Ints
-
Make sure there is capacity for this many
int
s, growing the buffer if needed. - ensureCapacity(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Longs
-
Make sure there is capacity for this many
long
s, growing the buffer if needed. - ensureCapacity(int, int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.BytesRefs
-
Make sure there is capacity for
totalBytes
and spread across#count
BytesRef
s? You could call this with something likeensureCapacity(Arrays.stream(bytes).mapToInt(b -> b.length).sum(), bytes.length)
. - ENTRY - Static variable in interface org.elasticsearch.compute.data.BooleanBlock
- ENTRY - Static variable in interface org.elasticsearch.compute.data.BytesRefBlock
- ENTRY - Static variable in interface org.elasticsearch.compute.data.DoubleBlock
- ENTRY - Static variable in interface org.elasticsearch.compute.data.FloatBlock
- ENTRY - Static variable in interface org.elasticsearch.compute.data.IntBlock
- ENTRY - Static variable in interface org.elasticsearch.compute.data.LongBlock
- ENTRY - Static variable in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.operator.AggregationOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.operator.AsyncOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.operator.DriverStatus
- ENTRY - Static variable in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.operator.LimitOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- ENTRY - Static variable in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- equals(Object) - Method in record class org.elasticsearch.compute.aggregation.blockhash.BlockHash.GroupSpec
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.aggregation.IntermediateStateDesc
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.aggregation.SeenGroupIds.Empty
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.aggregation.SeenGroupIds.Range
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.AggregateMetricDoubleLiteral
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.data.BlockUtils.BuilderWrapper
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.data.BlockUtils.Doc
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- equals(Object) - Method in interface org.elasticsearch.compute.data.BooleanBlock
-
Compares the given object with this block for equality.
- equals(Object) - Method in interface org.elasticsearch.compute.data.BooleanVector
-
Compares the given object with this vector for equality.
- equals(Object) - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- equals(Object) - Method in interface org.elasticsearch.compute.data.BytesRefBlock
-
Compares the given object with this block for equality.
- equals(Object) - Method in interface org.elasticsearch.compute.data.BytesRefVector
-
Compares the given object with this vector for equality.
- equals(Object) - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.CompositeBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.DocBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.DocVector
- equals(Object) - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- equals(Object) - Method in interface org.elasticsearch.compute.data.DoubleBlock
-
Compares the given object with this block for equality.
- equals(Object) - Method in interface org.elasticsearch.compute.data.DoubleVector
-
Compares the given object with this vector for equality.
- equals(Object) - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- equals(Object) - Method in interface org.elasticsearch.compute.data.FloatBlock
-
Compares the given object with this block for equality.
- equals(Object) - Method in interface org.elasticsearch.compute.data.FloatVector
-
Compares the given object with this vector for equality.
- equals(Object) - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- equals(Object) - Method in interface org.elasticsearch.compute.data.IntBlock
-
Compares the given object with this block for equality.
- equals(Object) - Method in interface org.elasticsearch.compute.data.IntVector
-
Compares the given object with this vector for equality.
- equals(Object) - Method in class org.elasticsearch.compute.data.IntVectorBlock
- equals(Object) - Method in record class org.elasticsearch.compute.data.LocalCircuitBreaker.SizeSettings
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- equals(Object) - Method in interface org.elasticsearch.compute.data.LongBlock
-
Compares the given object with this block for equality.
- equals(Object) - Method in interface org.elasticsearch.compute.data.LongVector
-
Compares the given object with this vector for equality.
- equals(Object) - Method in class org.elasticsearch.compute.data.LongVectorBlock
- equals(Object) - Method in class org.elasticsearch.compute.data.Page
- equals(Object) - Method in record class org.elasticsearch.compute.data.ToMask
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- equals(Object) - Method in record class org.elasticsearch.compute.lucene.LuceneQueryEvaluator.ShardConfig
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator.Factory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator.Factory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.lucene.LuceneSlice
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.lucene.PartialLeafReaderContext
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Factory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.FieldInfo
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.ShardContext
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Status
- equals(Object) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- equals(Object) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- equals(Object) - Method in record class org.elasticsearch.compute.operator.AggregationOperator.AggregationOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
- equals(Object) - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- equals(Object) - Method in record class org.elasticsearch.compute.operator.ColumnExtractOperator.Factory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Factory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Values
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.DriverContext.Snapshot
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.operator.DriverProfile
- equals(Object) - Method in record class org.elasticsearch.compute.operator.DriverSleeps
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.DriverSleeps.Sleep
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.operator.DriverStatus
- equals(Object) - Method in class org.elasticsearch.compute.operator.DriverStatus.OperatorStatus
- equals(Object) - Method in record class org.elasticsearch.compute.operator.EvalOperator.EvalOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeRequest
- equals(Object) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- equals(Object) - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.ExchangeSinkOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.Status
- equals(Object) - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.ExchangeSourceOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- equals(Object) - Method in record class org.elasticsearch.compute.operator.FilterOperator.FilterOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
- equals(Object) - Method in record class org.elasticsearch.compute.operator.IsBlockedResult
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
- equals(Object) - Method in record class org.elasticsearch.compute.operator.LocalSourceOperator.LocalSourceFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe.HashResult
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.MvExpandOperator.Factory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- equals(Object) - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.OutputOperator.OutputOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.ProjectOperator.ProjectOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Factory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Key
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.ScoreOperator.ScoreOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.ShowOperator.ShowOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.StringExtractOperator.StringExtractOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Final
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.SupplierWithChannels
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.SortOrder
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- equals(Object) - Method in class org.elasticsearch.compute.querydsl.query.SingleValueMatchQuery
- equals(BooleanBlock, BooleanBlock) - Static method in interface org.elasticsearch.compute.data.BooleanBlock
-
Returns
true
if the given blocks are equal to each other, otherwisefalse
. - equals(BooleanVector, BooleanVector) - Static method in interface org.elasticsearch.compute.data.BooleanVector
-
Returns
true
if the given vectors are equal to each other, otherwisefalse
. - equals(BytesRefBlock, BytesRefBlock) - Static method in interface org.elasticsearch.compute.data.BytesRefBlock
-
Returns
true
if the given blocks are equal to each other, otherwisefalse
. - equals(BytesRefVector, BytesRefVector) - Static method in interface org.elasticsearch.compute.data.BytesRefVector
-
Returns
true
if the given vectors are equal to each other, otherwisefalse
. - equals(DoubleBlock, DoubleBlock) - Static method in interface org.elasticsearch.compute.data.DoubleBlock
-
Returns
true
if the given blocks are equal to each other, otherwisefalse
. - equals(DoubleVector, DoubleVector) - Static method in interface org.elasticsearch.compute.data.DoubleVector
-
Returns
true
if the given vectors are equal to each other, otherwisefalse
. - equals(FloatBlock, FloatBlock) - Static method in interface org.elasticsearch.compute.data.FloatBlock
-
Returns
true
if the given blocks are equal to each other, otherwisefalse
. - equals(FloatVector, FloatVector) - Static method in interface org.elasticsearch.compute.data.FloatVector
-
Returns
true
if the given vectors are equal to each other, otherwisefalse
. - equals(IntBlock, IntBlock) - Static method in interface org.elasticsearch.compute.data.IntBlock
-
Returns
true
if the given blocks are equal to each other, otherwisefalse
. - equals(IntVector, IntVector) - Static method in interface org.elasticsearch.compute.data.IntVector
-
Returns
true
if the given vectors are equal to each other, otherwisefalse
. - equals(LongBlock, LongBlock) - Static method in interface org.elasticsearch.compute.data.LongBlock
-
Returns
true
if the given blocks are equal to each other, otherwisefalse
. - equals(LongVector, LongVector) - Static method in interface org.elasticsearch.compute.data.LongVector
-
Returns
true
if the given vectors are equal to each other, otherwisefalse
. - EsqlRefCountingListener - Class in org.elasticsearch.compute
-
Similar to
RefCountingListener
, but prefers non-task-cancelled exceptions over task-cancelled ones as they are more useful for diagnosing issues. - EsqlRefCountingListener(ActionListener<Void>) - Constructor for class org.elasticsearch.compute.EsqlRefCountingListener
- estimatedBytes - Variable in class org.elasticsearch.compute.data.AbstractBlockBuilder
-
The number of bytes currently estimated with the breaker.
- estimatedBytes - Variable in class org.elasticsearch.compute.data.AbstractVectorBuilder
-
The number of bytes currently estimated with the breaker.
- estimatedBytes() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- estimatedBytes() - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
- estimatedBytes() - Method in interface org.elasticsearch.compute.data.Block.Builder
-
An estimate of the number of bytes the
Block
created byBlock.Builder.build()
will use. - estimatedBytes() - Method in class org.elasticsearch.compute.data.BooleanVectorFixedBuilder
- estimatedBytes() - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- estimatedBytes() - Method in class org.elasticsearch.compute.data.DoubleVectorFixedBuilder
- estimatedBytes() - Method in class org.elasticsearch.compute.data.FloatVectorFixedBuilder
- estimatedBytes() - Method in class org.elasticsearch.compute.data.IntVectorFixedBuilder
- estimatedBytes() - Method in class org.elasticsearch.compute.data.LongVectorFixedBuilder
- estimatedBytes() - Method in class org.elasticsearch.compute.data.SingletonOrdinalsBuilder
- estimatedBytes() - Method in interface org.elasticsearch.compute.data.Vector.Builder
-
An estimate of the number of bytes the
Vector
created byVector.Builder.build()
will use. - eval(Page) - Method in class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator
- eval(Page) - Method in interface org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator
-
Evaluate the expression.
- EvalOperator - Class in org.elasticsearch.compute.operator
-
Evaluates a tree of functions for every position in the block, resulting in a new block which is appended to the page.
- EvalOperator(BlockFactory, EvalOperator.ExpressionEvaluator) - Constructor for class org.elasticsearch.compute.operator.EvalOperator
- EvalOperator.EvalOperatorFactory - Record Class in org.elasticsearch.compute.operator
- EvalOperator.ExpressionEvaluator - Interface in org.elasticsearch.compute.operator
- EvalOperator.ExpressionEvaluator.Factory - Interface in org.elasticsearch.compute.operator
-
A Factory for creating ExpressionEvaluators.
- EvalOperatorFactory(EvalOperator.ExpressionEvaluator.Factory) - Constructor for record class org.elasticsearch.compute.operator.EvalOperator.EvalOperatorFactory
-
Creates an instance of a
EvalOperatorFactory
record class. - evaluate() - Method in class org.elasticsearch.compute.aggregation.WelfordAlgorithm
- evaluate(long, long) - Method in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
- evaluate(long, long) - Method in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
- evaluate(Block[], int, IntVector, DriverContext) - Method in class org.elasticsearch.compute.aggregation.GroupingAggregator
-
Build the results for this aggregation.
- evaluate(Block[], int, DriverContext) - Method in class org.elasticsearch.compute.aggregation.Aggregator
- evaluateBlockCount() - Method in class org.elasticsearch.compute.aggregation.Aggregator
-
The number of Blocks required for evaluation.
- evaluateBlockCount() - Method in class org.elasticsearch.compute.aggregation.GroupingAggregator
-
The number of Blocks required for evaluation.
- evaluateFinal(CountDistinctBooleanAggregator.GroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBooleanAggregator
- evaluateFinal(CountDistinctBooleanAggregator.SingleState, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBooleanAggregator
- evaluateFinal(HllStates.GroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBytesRefAggregator
- evaluateFinal(HllStates.GroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctDoubleAggregator
- evaluateFinal(HllStates.GroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctFloatAggregator
- evaluateFinal(HllStates.GroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctIntAggregator
- evaluateFinal(HllStates.GroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctLongAggregator
- evaluateFinal(HllStates.SingleState, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBytesRefAggregator
- evaluateFinal(HllStates.SingleState, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctDoubleAggregator
- evaluateFinal(HllStates.SingleState, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctFloatAggregator
- evaluateFinal(HllStates.SingleState, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctIntAggregator
- evaluateFinal(HllStates.SingleState, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctLongAggregator
- evaluateFinal(RateDoubleAggregator.DoubleRateGroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.RateDoubleAggregator
- evaluateFinal(RateFloatAggregator.FloatRateGroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.RateFloatAggregator
- evaluateFinal(RateIntAggregator.IntRateGroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.RateIntAggregator
- evaluateFinal(RateLongAggregator.LongRateGroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.RateLongAggregator
- evaluateFinal(StdDevStates.GroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.StdDevDoubleAggregator
- evaluateFinal(StdDevStates.GroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.StdDevFloatAggregator
- evaluateFinal(StdDevStates.GroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.StdDevIntAggregator
- evaluateFinal(StdDevStates.GroupingState, IntVector, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.StdDevLongAggregator
- evaluateFinal(StdDevStates.SingleState, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.StdDevDoubleAggregator
- evaluateFinal(StdDevStates.SingleState, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.StdDevFloatAggregator
- evaluateFinal(StdDevStates.SingleState, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.StdDevIntAggregator
- evaluateFinal(StdDevStates.SingleState, DriverContext) - Static method in class org.elasticsearch.compute.aggregation.StdDevLongAggregator
- evaluateFinal(Block[], int, IntVector, DriverContext) - Method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- evaluateFinal(Block[], int, IntVector, DriverContext) - Method in class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- evaluateFinal(Block[], int, IntVector, DriverContext) - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorFunction
-
Build the final results for this aggregation.
- evaluateFinal(Block[], int, IntVector, DriverContext) - Method in class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- evaluateFinal(Block[], int, DriverContext) - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunction
-
Build the final results from running this agg.
- evaluateFinal(Block[], int, DriverContext) - Method in class org.elasticsearch.compute.aggregation.CountAggregatorFunction
- evaluateFinal(Block[], int, DriverContext) - Method in class org.elasticsearch.compute.aggregation.FromPartialAggregatorFunction
- evaluateFinal(Block[], int, DriverContext) - Method in class org.elasticsearch.compute.aggregation.ToPartialAggregatorFunction
- evaluateIntermediate(Block[], int, IntVector) - Method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- evaluateIntermediate(Block[], int, IntVector) - Method in class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- evaluateIntermediate(Block[], int, IntVector) - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorFunction
-
Build the intermediate results for this aggregation.
- evaluateIntermediate(Block[], int, IntVector) - Method in class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- evaluateIntermediate(Block[], int, DriverContext) - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunction
-
Build pre-aggregated "intermediate" data to pass to the
AggregatorFunction.addIntermediateInput(org.elasticsearch.compute.data.Page)
. - evaluateIntermediate(Block[], int, DriverContext) - Method in class org.elasticsearch.compute.aggregation.CountAggregatorFunction
- evaluateIntermediate(Block[], int, DriverContext) - Method in class org.elasticsearch.compute.aggregation.FromPartialAggregatorFunction
- evaluateIntermediate(Block[], int, DriverContext) - Method in class org.elasticsearch.compute.aggregation.ToPartialAggregatorFunction
- evaluator() - Method in record class org.elasticsearch.compute.operator.EvalOperator.EvalOperatorFactory
-
Returns the value of the
evaluator
record component. - evaluator(ElementType, EvalOperator.ExpressionEvaluator.Factory) - Static method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe
-
Build and
EvalOperator.ExpressionEvaluator
that deduplicates values using an adaptive algorithm based on the size of the input list. - evaluatorSupplier() - Method in record class org.elasticsearch.compute.operator.ColumnExtractOperator.Factory
-
Returns the value of the
evaluatorSupplier
record component. - evaluatorSupplier() - Method in record class org.elasticsearch.compute.operator.FilterOperator.FilterOperatorFactory
-
Returns the value of the
evaluatorSupplier
record component. - EXCHANGE_ACTION_NAME - Static variable in class org.elasticsearch.compute.operator.exchange.ExchangeService
- EXCHANGE_ACTION_NAME_FOR_CCS - Static variable in class org.elasticsearch.compute.operator.exchange.ExchangeService
- exchangeId() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeRequest
-
Returns the exchange ID.
- ExchangeRequest - Class in org.elasticsearch.compute.operator.exchange
- ExchangeRequest(String, boolean) - Constructor for class org.elasticsearch.compute.operator.exchange.ExchangeRequest
- ExchangeRequest(StreamInput) - Constructor for class org.elasticsearch.compute.operator.exchange.ExchangeRequest
- ExchangeResponse - Class in org.elasticsearch.compute.operator.exchange
- ExchangeResponse(BlockFactory, Page, boolean) - Constructor for class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- ExchangeResponse(BlockStreamInput) - Constructor for class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- ExchangeService - Class in org.elasticsearch.compute.operator.exchange
-
ExchangeService
is responsible for exchanging pages between exchange sinks and sources on the same or different nodes. - ExchangeService(Settings, ThreadPool, String, BlockFactory) - Constructor for class org.elasticsearch.compute.operator.exchange.ExchangeService
- ExchangeSink - Interface in org.elasticsearch.compute.operator.exchange
-
Sink for exchanging data
- ExchangeSinkHandler - Class in org.elasticsearch.compute.operator.exchange
-
An
ExchangeSinkHandler
receives pages and status from itsExchangeSink
s, which are created usingExchangeSinkHandler.createExchangeSink(Runnable)
} method. - ExchangeSinkHandler(BlockFactory, int, LongSupplier) - Constructor for class org.elasticsearch.compute.operator.exchange.ExchangeSinkHandler
- ExchangeSinkOperator - Class in org.elasticsearch.compute.operator.exchange
-
Sink operator implementation that pushes data to an
ExchangeSink
- ExchangeSinkOperator(ExchangeSink, Function<Page, Page>) - Constructor for class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator
- ExchangeSinkOperator.ExchangeSinkOperatorFactory - Record Class in org.elasticsearch.compute.operator.exchange
- ExchangeSinkOperator.Status - Class in org.elasticsearch.compute.operator.exchange
- ExchangeSinkOperatorFactory(Supplier<ExchangeSink>, Function<Page, Page>) - Constructor for record class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.ExchangeSinkOperatorFactory
-
Creates an instance of a
ExchangeSinkOperatorFactory
record class. - exchangeSinks() - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.ExchangeSinkOperatorFactory
-
Returns the value of the
exchangeSinks
record component. - ExchangeSource - Interface in org.elasticsearch.compute.operator.exchange
-
Source for exchanging data
- ExchangeSourceHandler - Class in org.elasticsearch.compute.operator.exchange
-
An
ExchangeSourceHandler
asynchronously fetches pages and status from multipleRemoteSink
s and feeds them to itsExchangeSource
, which are created using theExchangeSourceHandler.createExchangeSource()
) method. - ExchangeSourceHandler(int, Executor) - Constructor for class org.elasticsearch.compute.operator.exchange.ExchangeSourceHandler
-
Creates a new ExchangeSourceHandler.
- ExchangeSourceOperator - Class in org.elasticsearch.compute.operator.exchange
-
Source operator implementation that retrieves data from an
ExchangeSource
- ExchangeSourceOperator(ExchangeSource) - Constructor for class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator
- ExchangeSourceOperator.ExchangeSourceOperatorFactory - Record Class in org.elasticsearch.compute.operator.exchange
- ExchangeSourceOperator.Status - Class in org.elasticsearch.compute.operator.exchange
- ExchangeSourceOperatorFactory(Supplier<ExchangeSource>) - Constructor for record class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.ExchangeSourceOperatorFactory
-
Creates an instance of a
ExchangeSourceOperatorFactory
record class. - exchangeSources() - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.ExchangeSourceOperatorFactory
-
Returns the value of the
exchangeSources
record component. - executeDrivers(Task, List<Driver>, Executor, ActionListener<Void>) - Method in class org.elasticsearch.compute.operator.DriverTaskRunner
- executeQuery(Page) - Method in class org.elasticsearch.compute.lucene.LuceneQueryEvaluator
- expand() - Method in interface org.elasticsearch.compute.data.Block
-
Expand multivalued fields into one row per value.
- expand() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- expand() - Method in interface org.elasticsearch.compute.data.BooleanBlock
- expand() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- expand() - Method in interface org.elasticsearch.compute.data.BytesRefBlock
- expand() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- expand() - Method in class org.elasticsearch.compute.data.CompositeBlock
- expand() - Method in class org.elasticsearch.compute.data.DocBlock
- expand() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- expand() - Method in interface org.elasticsearch.compute.data.DoubleBlock
- expand() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- expand() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- expand() - Method in interface org.elasticsearch.compute.data.FloatBlock
- expand() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- expand() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- expand() - Method in interface org.elasticsearch.compute.data.IntBlock
- expand() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- expand() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- expand() - Method in interface org.elasticsearch.compute.data.LongBlock
- expand() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- expand() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- expressionEvaluator() - Method in record class org.elasticsearch.compute.operator.StringExtractOperator.StringExtractOperatorFactory
-
Returns the value of the
expressionEvaluator
record component. - extraClose() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
-
Called when first
closed
. - extraClose() - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
-
Called when first
closed
. - extraClose() - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- extractFirst(long) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- extractSecond(long) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- extractX(long) - Method in enum class org.elasticsearch.compute.aggregation.spatial.PointType
- extractY(long) - Method in enum class org.elasticsearch.compute.aggregation.spatial.PointType
F
- factory() - Method in record class org.elasticsearch.compute.operator.LocalSourceOperator.LocalSourceFactory
-
Returns the value of the
factory
record component. - Factory(int) - Constructor for class org.elasticsearch.compute.operator.LimitOperator.Factory
- Factory(int, int) - Constructor for record class org.elasticsearch.compute.operator.MvExpandOperator.Factory
-
Creates an instance of a
Factory
record class. - Factory(List<? extends ShardContext>, Function<ShardContext, Query>, DataPartitioning, int, int) - Constructor for class org.elasticsearch.compute.lucene.LuceneCountOperator.Factory
- Factory(List<? extends ShardContext>, Function<ShardContext, Query>, DataPartitioning, int, int, int, boolean) - Constructor for class org.elasticsearch.compute.lucene.LuceneSourceOperator.Factory
- Factory(List<? extends ShardContext>, Function<ShardContext, Query>, DataPartitioning, int, int, int, List<SortBuilder<?>>, boolean) - Constructor for class org.elasticsearch.compute.lucene.LuceneTopNSourceOperator.Factory
- Factory(List<? extends ShardContext>, Function<ShardContext, Query>, DataPartitioning, int, int, ScoreMode) - Constructor for class org.elasticsearch.compute.lucene.LuceneOperator.Factory
-
Build the factory.
- Factory(List<ValuesSourceReaderOperator.FieldInfo>, List<ValuesSourceReaderOperator.ShardContext>, int) - Constructor for record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Factory
-
Creates an instance of a
Factory
record class. - Factory(ElementType[], EvalOperator.ExpressionEvaluator.Factory, Supplier<ColumnExtractOperator.Evaluator>) - Constructor for record class org.elasticsearch.compute.operator.ColumnExtractOperator.Factory
-
Creates an instance of a
Factory
record class. - Factory(LuceneQueryEvaluator.ShardConfig[]) - Constructor for record class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator.Factory
-
Creates an instance of a
Factory
record class. - Factory(LuceneQueryEvaluator.ShardConfig[]) - Constructor for record class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator.Factory
-
Creates an instance of a
Factory
record class. - Factory(ColumnLoadOperator.Values, int) - Constructor for record class org.elasticsearch.compute.operator.ColumnLoadOperator.Factory
-
Creates an instance of a
Factory
record class. - Factory(RowInTableLookupOperator.Key[], int[]) - Constructor for record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Factory
-
Creates an instance of a
Factory
record class. - FailureCollector - Class in org.elasticsearch.compute.operator
-
FailureCollector
is responsible for collecting exceptions that occur in the compute engine. - FailureCollector() - Constructor for class org.elasticsearch.compute.operator.FailureCollector
- FailureCollector(int) - Constructor for class org.elasticsearch.compute.operator.FailureCollector
- FALSE_ORD - Static variable in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBoolean
-
Ordinal assigned to
false
. - fetchFromBuffer() - Method in class org.elasticsearch.compute.operator.AsyncOperator
-
Get a
AsyncOperator
from the buffer. - fetchPageAsync(boolean, ActionListener<ExchangeResponse>) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkHandler
-
Fetches pages and the sink status asynchronously.
- fetchPageAsync(boolean, ActionListener<ExchangeResponse>) - Method in interface org.elasticsearch.compute.operator.exchange.RemoteSink
- field - Variable in class org.elasticsearch.compute.operator.lookup.QueryList
- FieldInfo(String, ElementType, IntFunction<BlockLoader>) - Constructor for record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.FieldInfo
-
Creates an instance of a
FieldInfo
record class. - fieldNames() - Method in record class org.elasticsearch.compute.operator.StringExtractOperator.StringExtractOperatorFactory
-
Returns the value of the
fieldNames
record component. - fields() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Factory
-
Returns the value of the
fields
record component. - filter() - Method in record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
-
Returns the value of the
filter
record component. - filter(int...) - Method in interface org.elasticsearch.compute.data.Block
-
Creates a new block that only exposes the positions provided.
- filter(int...) - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- filter(int...) - Method in interface org.elasticsearch.compute.data.BooleanBlock
- filter(int...) - Method in interface org.elasticsearch.compute.data.BooleanVector
- filter(int...) - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- filter(int...) - Method in interface org.elasticsearch.compute.data.BytesRefBlock
- filter(int...) - Method in interface org.elasticsearch.compute.data.BytesRefVector
- filter(int...) - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.CompositeBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.ConstantNullVector
- filter(int...) - Method in class org.elasticsearch.compute.data.DocBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.DocVector
- filter(int...) - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- filter(int...) - Method in interface org.elasticsearch.compute.data.DoubleBlock
- filter(int...) - Method in interface org.elasticsearch.compute.data.DoubleVector
- filter(int...) - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- filter(int...) - Method in interface org.elasticsearch.compute.data.FloatBlock
- filter(int...) - Method in interface org.elasticsearch.compute.data.FloatVector
- filter(int...) - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- filter(int...) - Method in interface org.elasticsearch.compute.data.IntBlock
- filter(int...) - Method in interface org.elasticsearch.compute.data.IntVector
- filter(int...) - Method in class org.elasticsearch.compute.data.IntVectorBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- filter(int...) - Method in interface org.elasticsearch.compute.data.LongBlock
- filter(int...) - Method in interface org.elasticsearch.compute.data.LongVector
- filter(int...) - Method in class org.elasticsearch.compute.data.LongVectorBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- filter(int...) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- filter(int...) - Method in interface org.elasticsearch.compute.data.Vector
-
Creates a new vector that only exposes the positions provided.
- FilteredAggregatorFunctionSupplier - Record Class in org.elasticsearch.compute.aggregation
-
A
AggregatorFunctionSupplier
that wraps another, filtering which positions are supplied to the aggregator. - FilteredAggregatorFunctionSupplier(AggregatorFunctionSupplier, EvalOperator.ExpressionEvaluator.Factory) - Constructor for record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
-
Creates an instance of a
FilteredAggregatorFunctionSupplier
record class. - FilterOperator - Class in org.elasticsearch.compute.operator
- FilterOperator(EvalOperator.ExpressionEvaluator) - Constructor for class org.elasticsearch.compute.operator.FilterOperator
- FilterOperator.FilterOperatorFactory - Record Class in org.elasticsearch.compute.operator
- FilterOperatorFactory(EvalOperator.ExpressionEvaluator.Factory) - Constructor for record class org.elasticsearch.compute.operator.FilterOperator.FilterOperatorFactory
-
Creates an instance of a
FilterOperatorFactory
record class. - Final(List<BlockHash.GroupSpec>, List<TimeSeriesAggregationOperatorFactories.SupplierWithChannels>, List<TimeSeriesAggregationOperatorFactories.SupplierWithChannels>, int) - Constructor for record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Final
-
Creates an instance of a
Final
record class. - FINAL - Enum constant in enum class org.elasticsearch.compute.aggregation.AggregatorMode
-
Maps intermediate inputs to final outputs.
- finish() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
-
Called during implementations of
Block.Builder.build()
as a first step to check if the block is still open and to finish the last position. - finish() - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
-
Called during implementations of
Block.Builder.build()
as a first step to check if the block is still open and to finish the last position. - finish() - Method in class org.elasticsearch.compute.lucene.LuceneCountOperator
- finish() - Method in class org.elasticsearch.compute.lucene.LuceneSourceOperator
- finish() - Method in class org.elasticsearch.compute.lucene.LuceneTopNSourceOperator
- finish() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- finish() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- finish() - Method in class org.elasticsearch.compute.operator.AggregationOperator
- finish() - Method in class org.elasticsearch.compute.operator.AsyncOperator
- finish() - Method in class org.elasticsearch.compute.operator.DriverContext
-
Finishes this context.
- finish() - Method in interface org.elasticsearch.compute.operator.exchange.ExchangeSink
-
called once all pages have been added (see
ExchangeSink.addPage(Page)
). - finish() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator
- finish() - Method in interface org.elasticsearch.compute.operator.exchange.ExchangeSource
-
Called when the source has enough input pages
- finish() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator
- finish() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator
- finish() - Method in class org.elasticsearch.compute.operator.LimitOperator
- finish() - Method in class org.elasticsearch.compute.operator.LocalSourceOperator
- finish() - Method in class org.elasticsearch.compute.operator.lookup.EnrichQuerySourceOperator
- finish() - Method in class org.elasticsearch.compute.operator.lookup.MergePositionsOperator
- finish() - Method in class org.elasticsearch.compute.operator.MvExpandOperator
- finish() - Method in interface org.elasticsearch.compute.operator.Operator
-
notifies the operator that it won't receive any more input pages
- finish() - Method in class org.elasticsearch.compute.operator.OrdinalsGroupingOperator
- finish() - Method in class org.elasticsearch.compute.operator.OutputOperator
- finish() - Method in class org.elasticsearch.compute.operator.PageConsumerOperator
- finish() - Method in class org.elasticsearch.compute.operator.ResponseHeadersCollector
-
Called when all child requests are completed.
- finish() - Method in class org.elasticsearch.compute.operator.topn.TopNOperator
- finishEarly(boolean, ActionListener<Void>) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceHandler
-
Gracefully terminates the exchange source early by instructing all remote exchange sinks to stop their computations.
- finished() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
-
Returns true if the
RemoteSink
is already completed. - finishMv() - Method in class org.elasticsearch.compute.aggregation.blockhash.AddPage
- finishSessionEarly(String, ActionListener<Void>) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
-
Finishes the session early, i.e., before all sources are finished.
- finishSinkHandler(String, Exception) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
-
Removes the exchange sink handler associated with the given exchange id.
- first() - Method in record class org.elasticsearch.compute.operator.DriverSleeps
-
Returns the value of the
first
record component. - firstPosition() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
The first position in the current batch.
- firstValueIndexes - Variable in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- firstValueIndexes - Variable in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- firstValueIndexes - Variable in class org.elasticsearch.compute.data.FloatBigArrayBlock
- firstValueIndexes - Variable in class org.elasticsearch.compute.data.IntBigArrayBlock
- firstValueIndexes - Variable in class org.elasticsearch.compute.data.LongBigArrayBlock
- firstValueIndexes - Variable in class org.elasticsearch.compute.data.AbstractBlockBuilder
- FLOAT - Enum constant in enum class org.elasticsearch.compute.data.ElementType
- FLOAT - Enum constant in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
- FLOAT - Enum constant in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
- FloatBigArrayBlock - Class in org.elasticsearch.compute.data
-
Block implementation that stores values in a
FloatBigArrayVector
. - FloatBigArrayBlock(FloatArray, int, int[], BitSet, Block.MvOrdering, BlockFactory) - Constructor for class org.elasticsearch.compute.data.FloatBigArrayBlock
- FloatBigArrayVector - Class in org.elasticsearch.compute.data
-
Vector implementation that defers to an enclosed
FloatArray
. - FloatBigArrayVector(FloatArray, int, BlockFactory) - Constructor for class org.elasticsearch.compute.data.FloatBigArrayVector
- FloatBlock - Interface in org.elasticsearch.compute.data
-
Block that stores float values.
- FloatBlock.Builder - Interface in org.elasticsearch.compute.data
-
Builder for
FloatBlock
- FloatBucketedSort - Class in org.elasticsearch.compute.data.sort
-
Aggregates the top N float values per bucket.
- FloatBucketedSort(BigArrays, SortOrder, int) - Constructor for class org.elasticsearch.compute.data.sort.FloatBucketedSort
- FloatVector - Interface in org.elasticsearch.compute.data
-
Vector that stores float values.
- FloatVector.Builder - Interface in org.elasticsearch.compute.data
-
A builder that grows as needed.
- FloatVector.FixedBuilder - Interface in org.elasticsearch.compute.data
-
A builder that never grows.
- FloatVectorBlock - Class in org.elasticsearch.compute.data
-
Block view of a
FloatVector
. - FloatVectorFixedBuilder - Class in org.elasticsearch.compute.data
-
Builder for
FloatVector
s that never grows. - flushRemaining() - Method in class org.elasticsearch.compute.aggregation.blockhash.AddPage
-
Call when finished to emit all remaining ordinals to the aggs.
- from() - Method in record class org.elasticsearch.compute.aggregation.SeenGroupIds.Range
-
Returns the value of the
from
record component. - fromArrayRow(BlockFactory, Object...) - Static method in class org.elasticsearch.compute.data.BlockUtils
- fromJava(Class<?>) - Static method in enum class org.elasticsearch.compute.data.ElementType
- fromList(BlockFactory, List<List<Object>>) - Static method in class org.elasticsearch.compute.data.BlockUtils
- fromListRow(BlockFactory, List<Object>) - Static method in class org.elasticsearch.compute.data.BlockUtils
- fromListRow(BlockFactory, List<Object>, int) - Static method in class org.elasticsearch.compute.data.BlockUtils
- FromPartialAggregatorFunction - Class in org.elasticsearch.compute.aggregation
- FromPartialAggregatorFunction(DriverContext, GroupingAggregatorFunction, int) - Constructor for class org.elasticsearch.compute.aggregation.FromPartialAggregatorFunction
- FromPartialGroupingAggregatorFunction - Class in org.elasticsearch.compute.aggregation
- FromPartialGroupingAggregatorFunction(GroupingAggregatorFunction, int) - Constructor for class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- fromPointValues(PointValues) - Method in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
- fromPointValues(PointValues) - Method in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
G
- GEO - Enum constant in enum class org.elasticsearch.compute.aggregation.spatial.PointType
- geoShapeQueryList(MappedFieldType, SearchExecutionContext, Block) - Static method in class org.elasticsearch.compute.operator.lookup.QueryList
-
Returns a list of geo_shape queries for the given field and the input block.
- get(DriverContext) - Method in class org.elasticsearch.compute.lucene.LuceneCountOperator.Factory
- get(DriverContext) - Method in class org.elasticsearch.compute.lucene.LuceneMaxFactory
- get(DriverContext) - Method in class org.elasticsearch.compute.lucene.LuceneMinFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator.Factory
- get(DriverContext) - Method in record class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator.Factory
- get(DriverContext) - Method in class org.elasticsearch.compute.lucene.LuceneSourceOperator.Factory
- get(DriverContext) - Method in class org.elasticsearch.compute.lucene.LuceneTopNSourceOperator.Factory
- get(DriverContext) - Method in class org.elasticsearch.compute.lucene.TimeSeriesSortedSourceOperatorFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Factory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.AggregationOperator.AggregationOperatorFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.ColumnExtractOperator.Factory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Factory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.EvalOperator.EvalOperatorFactory
- get(DriverContext) - Method in interface org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator.Factory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.ExchangeSinkOperatorFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.ExchangeSourceOperatorFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.FilterOperator.FilterOperatorFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
- get(DriverContext) - Method in class org.elasticsearch.compute.operator.LimitOperator.Factory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.LocalSourceOperator.LocalSourceFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.MvExpandOperator.Factory
- get(DriverContext) - Method in interface org.elasticsearch.compute.operator.Operator.OperatorFactory
-
Creates a new intermediate operator.
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.OutputOperator.OutputOperatorFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.ProjectOperator.ProjectOperatorFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Factory
- get(DriverContext) - Method in interface org.elasticsearch.compute.operator.ScoreOperator.ExpressionScorer.Factory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.ScoreOperator.ScoreOperatorFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.ShowOperator.ShowOperatorFactory
- get(DriverContext) - Method in interface org.elasticsearch.compute.operator.SinkOperator.SinkOperatorFactory
-
Creates a new sink operator.
- get(DriverContext) - Method in interface org.elasticsearch.compute.operator.SourceOperator.SourceOperatorFactory
-
Creates a new source operator.
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.StringExtractOperator.StringExtractOperatorFactory
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Final
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
- get(DriverContext) - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
- getBlock(int) - Method in class org.elasticsearch.compute.data.CompositeBlock
-
Returns the block at the given block index.
- getBlock(int) - Method in class org.elasticsearch.compute.data.Page
-
Returns the block at the given block index.
- getBlockCount() - Method in class org.elasticsearch.compute.data.CompositeBlock
-
Returns the number of blocks in this composite block.
- getBlockCount() - Method in class org.elasticsearch.compute.data.Page
-
Returns the number of blocks in this page.
- getBoolean(int) - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- getBoolean(int) - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- getBoolean(int) - Method in interface org.elasticsearch.compute.data.BooleanBlock
-
Retrieves the boolean value stored at the given value index.
- getBoolean(int) - Method in interface org.elasticsearch.compute.data.BooleanVector
- getBoolean(int) - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- getBoolean(int) - Method in class org.elasticsearch.compute.data.ConstantNullVector
- getBucketSize() - Method in class org.elasticsearch.compute.data.sort.BooleanBucketedSort
-
The number of values to store per bucket.
- getBucketSize() - Method in class org.elasticsearch.compute.data.sort.DoubleBucketedSort
-
The number of values to store per bucket.
- getBucketSize() - Method in class org.elasticsearch.compute.data.sort.FloatBucketedSort
-
The number of values to store per bucket.
- getBucketSize() - Method in class org.elasticsearch.compute.data.sort.IntBucketedSort
-
The number of values to store per bucket.
- getBucketSize() - Method in class org.elasticsearch.compute.data.sort.LongBucketedSort
-
The number of values to store per bucket.
- getBytesRef(int, BytesRef) - Method in interface org.elasticsearch.compute.data.BytesRefBlock
-
Retrieves the BytesRef value stored at the given value index.
- getBytesRef(int, BytesRef) - Method in interface org.elasticsearch.compute.data.BytesRefVector
- getBytesRef(int, BytesRef) - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- getBytesRef(int, BytesRef) - Method in class org.elasticsearch.compute.data.ConstantNullVector
- getBytesRef(int, BytesRef) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- getBytesRef(int, BytesRef) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- getCheckedOutput() - Method in class org.elasticsearch.compute.lucene.LuceneCountOperator
- getCheckedOutput() - Method in class org.elasticsearch.compute.lucene.LuceneOperator
- getCheckedOutput() - Method in class org.elasticsearch.compute.lucene.LuceneSourceOperator
- getCheckedOutput() - Method in class org.elasticsearch.compute.lucene.LuceneTopNSourceOperator
- getDictionaryVector() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- getDictionaryVector() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- getDouble(int) - Method in class org.elasticsearch.compute.data.ConstantNullVector
- getDouble(int) - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- getDouble(int) - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- getDouble(int) - Method in interface org.elasticsearch.compute.data.DoubleBlock
-
Retrieves the double value stored at the given value index.
- getDouble(int) - Method in interface org.elasticsearch.compute.data.DoubleVector
- getDouble(int) - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- getDurability() - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- getEmpty() - Method in class org.elasticsearch.compute.lucene.UnsupportedValueSourceType
- getFailure() - Method in class org.elasticsearch.compute.operator.FailureCollector
-
Returns the accumulated failure, preferring non-task-cancelled exceptions over task-cancelled ones.
- getField(FieldContext, AggregationScript.LeafFactory) - Method in class org.elasticsearch.compute.lucene.UnsupportedValueSourceType
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
-
Gets the index of the first value for the given position.
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
-
Gets the index of the first value for the given position.
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
-
Gets the index of the first value for the given position.
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
-
Gets the index of the first value for the given position.
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
-
Gets the index of the first value for the given position.
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.DocBlock
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.IntVectorBlock
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.LongVectorBlock
- getFirstValueIndex(int) - Method in interface org.elasticsearch.compute.data.Block
-
Gets the index of the first value for the given position.
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.CompositeBlock
- getFirstValueIndex(int) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- getFloat(int) - Method in class org.elasticsearch.compute.data.ConstantNullVector
- getFloat(int) - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- getFloat(int) - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- getFloat(int) - Method in interface org.elasticsearch.compute.data.FloatBlock
-
Retrieves the float value stored at the given value index.
- getFloat(int) - Method in interface org.elasticsearch.compute.data.FloatVector
- getFloat(int) - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- getIndex() - Method in enum class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.Metric
- getInstance(CircuitBreaker, BigArrays) - Static method in class org.elasticsearch.compute.data.BlockFactory
- getInt(int) - Method in class org.elasticsearch.compute.data.ConstantNullVector
- getInt(int) - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- getInt(int) - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- getInt(int) - Method in interface org.elasticsearch.compute.data.IntBlock
-
Retrieves the int value stored at the given value index.
- getInt(int) - Method in interface org.elasticsearch.compute.data.IntVector
- getInt(int) - Method in class org.elasticsearch.compute.data.IntVectorBlock
- getKeys() - Method in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
-
Returns a
Block
that contains all the keys that are inserted byBlockHash.add(org.elasticsearch.compute.data.Page, org.elasticsearch.compute.aggregation.GroupingAggregatorFunction.AddInput)
. - getKeys() - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizeBlockHash
- getKeys() - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizePackedValuesBlockHash
- getKeys() - Method in class org.elasticsearch.compute.aggregation.blockhash.TimeSeriesBlockHash
- getLimit() - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- getLocalDriver() - Static method in class org.elasticsearch.compute.operator.DriverContext
- getLong(int) - Method in class org.elasticsearch.compute.data.ConstantNullVector
- getLong(int) - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- getLong(int) - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- getLong(int) - Method in interface org.elasticsearch.compute.data.LongBlock
-
Retrieves the long value stored at the given value index.
- getLong(int) - Method in interface org.elasticsearch.compute.data.LongVector
- getLong(int) - Method in class org.elasticsearch.compute.data.LongVectorBlock
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.Status
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- getMinimalSupportedVersion() - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- getName() - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- getNamedWriteables() - Static method in class org.elasticsearch.compute.data.BlockWritables
- getOrder() - Method in class org.elasticsearch.compute.data.sort.BooleanBucketedSort
-
The order of the sort.
- getOrder() - Method in class org.elasticsearch.compute.data.sort.DoubleBucketedSort
-
The order of the sort.
- getOrder() - Method in class org.elasticsearch.compute.data.sort.FloatBucketedSort
-
The order of the sort.
- getOrder() - Method in class org.elasticsearch.compute.data.sort.IntBucketedSort
-
The order of the sort.
- getOrder() - Method in class org.elasticsearch.compute.data.sort.LongBucketedSort
-
The order of the sort.
- getOrdinalsBlock() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- getOrdinalsVector() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- getOutput() - Method in class org.elasticsearch.compute.lucene.LuceneOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.AggregationOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.LimitOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.LocalSourceOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.lookup.EnrichQuerySourceOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.lookup.MergePositionsOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.MvExpandOperator
- getOutput() - Method in interface org.elasticsearch.compute.operator.Operator
-
returns non-null if output page available.
- getOutput() - Method in class org.elasticsearch.compute.operator.OrdinalsGroupingOperator
- getOutput() - Method in class org.elasticsearch.compute.operator.SinkOperator
-
A sink operator produces no output - unconditionally throws UnsupportedOperationException
- getOutput() - Method in class org.elasticsearch.compute.operator.topn.TopNOperator
- getOverhead() - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- getParentTask() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeRequest
- getPositionCount() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- getPositionCount() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- getPositionCount() - Method in class org.elasticsearch.compute.data.DocVector
- getPositionCount() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- getPositionCount() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- getPositionCount() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- getPositionCount() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- getPositionCount() - Method in interface org.elasticsearch.compute.data.Block
-
Returns The number of positions in this block..
- getPositionCount() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.CompositeBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.DocBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- getPositionCount() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- getPositionCount() - Method in class org.elasticsearch.compute.data.Page
-
Returns the number of positions (rows) in this page.
- getPositionCount() - Method in interface org.elasticsearch.compute.data.Vector
-
The number of positions in this vector.
- getScript(AggregationScript.LeafFactory, ValueType) - Method in class org.elasticsearch.compute.lucene.UnsupportedValueSourceType
- getSinkHandler(String) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
-
Returns an exchange sink handler for the given id.
- getSlices() - Method in class org.elasticsearch.compute.lucene.LuceneSliceQueue
- getSnapshot() - Method in class org.elasticsearch.compute.operator.DriverContext
-
Retrieves the snapshot of the driver context after it has been finished.
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.DocBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- getTotalValueCount() - Method in interface org.elasticsearch.compute.data.Block
-
Returns The total number of values in this block not counting nulls..
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.CompositeBlock
- getTotalValueCount() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- getTrippedCount() - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- getUsed() - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- getValueCount(int) - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
-
Gets the number of values for the given position, possibly 0.
- getValueCount(int) - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
-
Gets the number of values for the given position, possibly 0.
- getValueCount(int) - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
-
Gets the number of values for the given position, possibly 0.
- getValueCount(int) - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
-
Gets the number of values for the given position, possibly 0.
- getValueCount(int) - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
-
Gets the number of values for the given position, possibly 0.
- getValueCount(int) - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- getValueCount(int) - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- getValueCount(int) - Method in class org.elasticsearch.compute.data.DocBlock
- getValueCount(int) - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- getValueCount(int) - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- getValueCount(int) - Method in class org.elasticsearch.compute.data.IntVectorBlock
- getValueCount(int) - Method in class org.elasticsearch.compute.data.LongVectorBlock
- getValueCount(int) - Method in interface org.elasticsearch.compute.data.Block
-
Gets the number of values for the given position, possibly 0.
- getValueCount(int) - Method in class org.elasticsearch.compute.data.CompositeBlock
- getValueCount(int) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- getWriteableName() - Method in interface org.elasticsearch.compute.data.BooleanBlock
- getWriteableName() - Method in interface org.elasticsearch.compute.data.BytesRefBlock
- getWriteableName() - Method in class org.elasticsearch.compute.data.CompositeBlock
- getWriteableName() - Method in class org.elasticsearch.compute.data.DocBlock
- getWriteableName() - Method in interface org.elasticsearch.compute.data.DoubleBlock
- getWriteableName() - Method in interface org.elasticsearch.compute.data.FloatBlock
- getWriteableName() - Method in interface org.elasticsearch.compute.data.IntBlock
- getWriteableName() - Method in interface org.elasticsearch.compute.data.LongBlock
- getWriteableName() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.operator.DriverStatus
- getWriteableName() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- getWriteableName() - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- groupingAggregator(DriverContext, List<Integer>) - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunctionSupplier
- groupingAggregator(DriverContext, List<Integer>) - Method in record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
- GroupingAggregator - Class in org.elasticsearch.compute.aggregation
- GroupingAggregator(GroupingAggregatorFunction, AggregatorMode) - Constructor for class org.elasticsearch.compute.aggregation.GroupingAggregator
- GroupingAggregator.Factory - Interface in org.elasticsearch.compute.aggregation
- groupingAggregatorFactory(AggregatorMode, List<Integer>) - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunctionSupplier
- GroupingAggregatorFunction - Interface in org.elasticsearch.compute.aggregation
-
Applies some grouping function like
min
oravg
to many values, grouped into buckets. - GroupingAggregatorFunction.AddInput - Interface in org.elasticsearch.compute.aggregation
-
Consume group ids to cause the
GroupingAggregatorFunction
to group values at a particular position into a particular group. - GroupingAggregatorState - Interface in org.elasticsearch.compute.aggregation
- groupingElementType() - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Returns the value of the
groupingElementType
record component. - groupingField() - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Returns the value of the
groupingField
record component. - groupingIntermediateStateDesc() - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunctionSupplier
- groupingIntermediateStateDesc() - Method in record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
- groupings() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Final
-
Returns the value of the
groupings
record component. - groupings() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
-
Returns the value of the
groupings
record component. - groupings() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
-
Returns the value of the
groupings
record component. - groups() - Method in record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
-
Returns the value of the
groups
record component. - GroupSpec(int, ElementType) - Constructor for record class org.elasticsearch.compute.aggregation.blockhash.BlockHash.GroupSpec
- GroupSpec(int, ElementType, boolean) - Constructor for record class org.elasticsearch.compute.aggregation.blockhash.BlockHash.GroupSpec
-
Creates an instance of a
GroupSpec
record class. - grow(int) - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Make sure that the underlying bytes has a capacity of at least
capacity
. - growValuesArray(int) - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- growValuesArray(int) - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
- growValuesArray(int) - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
H
- hadMultivaluedFields() - Method in record class org.elasticsearch.compute.data.ToMask
-
Returns the value of the
hadMultivaluedFields
record component. - hasCapacity(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Booleans
-
Is there capacity for this many
booleans
s? - hasCapacity(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Doubles
-
Is there capacity for this many
double
s? - hasCapacity(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Ints
-
Is there capacity for this many
int
s? - hasCapacity(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Longs
-
Is there capacity for this many
long
s? - hasCapacity(int, int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.BytesRefs
-
Is there capacity for
totalBytes
and spread across#count
BytesRef
s? You could call this with something likehasCapacity(Arrays.stream(bytes).mapToInt(b -> b.length).sum(), bytes.length)
. - hasFailure() - Method in class org.elasticsearch.compute.operator.FailureCollector
- hash(BlockFactory, boolean[]) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBoolean
-
Dedupe values and build a
LongBlock
suitable for passing as the grouping block to aGroupingAggregatorFunction
. - hash(BooleanBlock) - Static method in interface org.elasticsearch.compute.data.BooleanBlock
-
Generates the hash code for the given block.
- hash(BooleanVector) - Static method in interface org.elasticsearch.compute.data.BooleanVector
-
Generates the hash code for the given vector.
- hash(BytesRefBlock) - Static method in interface org.elasticsearch.compute.data.BytesRefBlock
-
Generates the hash code for the given block.
- hash(BytesRefVector) - Static method in interface org.elasticsearch.compute.data.BytesRefVector
-
Generates the hash code for the given vector.
- hash(DoubleBlock) - Static method in interface org.elasticsearch.compute.data.DoubleBlock
-
Generates the hash code for the given block.
- hash(DoubleVector) - Static method in interface org.elasticsearch.compute.data.DoubleVector
-
Generates the hash code for the given vector.
- hash(FloatBlock) - Static method in interface org.elasticsearch.compute.data.FloatBlock
-
Generates the hash code for the given block.
- hash(FloatVector) - Static method in interface org.elasticsearch.compute.data.FloatVector
-
Generates the hash code for the given vector.
- hash(IntBlock) - Static method in interface org.elasticsearch.compute.data.IntBlock
-
Generates the hash code for the given block.
- hash(IntVector) - Static method in interface org.elasticsearch.compute.data.IntVector
-
Generates the hash code for the given vector.
- hash(LongBlock) - Static method in interface org.elasticsearch.compute.data.LongBlock
-
Generates the hash code for the given block.
- hash(LongVector) - Static method in interface org.elasticsearch.compute.data.LongVector
-
Generates the hash code for the given vector.
- hashAdd(BlockFactory, BytesRefHash) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBytesRef
-
Dedupe values, add them to the hash, and build an
IntBlock
of their hashes. - hashAdd(BlockFactory, LongHash) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeDouble
-
Dedupe values, add them to the hash, and build an
IntBlock
of their hashes. - hashAdd(BlockFactory, LongHash) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeInt
-
Dedupe values, add them to the hash, and build an
IntBlock
of their hashes. - hashAdd(BlockFactory, LongHash) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeLong
-
Dedupe values, add them to the hash, and build an
IntBlock
of their hashes. - HashAggregationOperator - Class in org.elasticsearch.compute.operator
- HashAggregationOperator(List<GroupingAggregator.Factory>, Supplier<BlockHash>, DriverContext) - Constructor for class org.elasticsearch.compute.operator.HashAggregationOperator
- HashAggregationOperator.HashAggregationOperatorFactory - Record Class in org.elasticsearch.compute.operator
- HashAggregationOperator.Status - Class in org.elasticsearch.compute.operator
- HashAggregationOperatorFactory(List<BlockHash.GroupSpec>, AggregatorMode, List<GroupingAggregator.Factory>, int, AnalysisRegistry) - Constructor for record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
-
Creates an instance of a
HashAggregationOperatorFactory
record class. - hashCode() - Method in record class org.elasticsearch.compute.aggregation.blockhash.BlockHash.GroupSpec
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.aggregation.IntermediateStateDesc
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.aggregation.SeenGroupIds.Empty
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.aggregation.SeenGroupIds.Range
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.AggregateMetricDoubleLiteral
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.data.BlockUtils.BuilderWrapper
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.data.BlockUtils.Doc
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- hashCode() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- hashCode() - Method in interface org.elasticsearch.compute.data.BooleanBlock
-
Returns the hash code of this block, as defined by
BooleanBlock.hash(BooleanBlock)
. - hashCode() - Method in interface org.elasticsearch.compute.data.BooleanVector
-
Returns the hash code of this vector, as defined by
BooleanVector.hash(BooleanVector)
. - hashCode() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- hashCode() - Method in interface org.elasticsearch.compute.data.BytesRefBlock
-
Returns the hash code of this block, as defined by
BytesRefBlock.hash(BytesRefBlock)
. - hashCode() - Method in interface org.elasticsearch.compute.data.BytesRefVector
-
Returns the hash code of this vector, as defined by
BytesRefVector.hash(BytesRefVector)
. - hashCode() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- hashCode() - Method in class org.elasticsearch.compute.data.CompositeBlock
- hashCode() - Method in class org.elasticsearch.compute.data.DocBlock
- hashCode() - Method in class org.elasticsearch.compute.data.DocVector
- hashCode() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- hashCode() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- hashCode() - Method in interface org.elasticsearch.compute.data.DoubleBlock
-
Returns the hash code of this block, as defined by
DoubleBlock.hash(DoubleBlock)
. - hashCode() - Method in interface org.elasticsearch.compute.data.DoubleVector
-
Returns the hash code of this vector, as defined by
DoubleVector.hash(DoubleVector)
. - hashCode() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- hashCode() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- hashCode() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- hashCode() - Method in interface org.elasticsearch.compute.data.FloatBlock
-
Returns the hash code of this block, as defined by
FloatBlock.hash(FloatBlock)
. - hashCode() - Method in interface org.elasticsearch.compute.data.FloatVector
-
Returns the hash code of this vector, as defined by
FloatVector.hash(FloatVector)
. - hashCode() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- hashCode() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- hashCode() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- hashCode() - Method in interface org.elasticsearch.compute.data.IntBlock
-
Returns the hash code of this block, as defined by
IntBlock.hash(IntBlock)
. - hashCode() - Method in interface org.elasticsearch.compute.data.IntVector
-
Returns the hash code of this vector, as defined by
IntVector.hash(IntVector)
. - hashCode() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- hashCode() - Method in record class org.elasticsearch.compute.data.LocalCircuitBreaker.SizeSettings
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- hashCode() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- hashCode() - Method in interface org.elasticsearch.compute.data.LongBlock
-
Returns the hash code of this block, as defined by
LongBlock.hash(LongBlock)
. - hashCode() - Method in interface org.elasticsearch.compute.data.LongVector
-
Returns the hash code of this vector, as defined by
LongVector.hash(LongVector)
. - hashCode() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- hashCode() - Method in class org.elasticsearch.compute.data.Page
- hashCode() - Method in record class org.elasticsearch.compute.data.ToMask
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- hashCode() - Method in record class org.elasticsearch.compute.lucene.LuceneQueryEvaluator.ShardConfig
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator.Factory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator.Factory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.lucene.LuceneSlice
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.lucene.PartialLeafReaderContext
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Factory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.FieldInfo
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.ShardContext
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Status
- hashCode() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- hashCode() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- hashCode() - Method in record class org.elasticsearch.compute.operator.AggregationOperator.AggregationOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
- hashCode() - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- hashCode() - Method in record class org.elasticsearch.compute.operator.ColumnExtractOperator.Factory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Factory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Values
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.DriverContext.Snapshot
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.operator.DriverProfile
- hashCode() - Method in record class org.elasticsearch.compute.operator.DriverSleeps
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.DriverSleeps.Sleep
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.operator.DriverStatus
- hashCode() - Method in class org.elasticsearch.compute.operator.DriverStatus.OperatorStatus
- hashCode() - Method in record class org.elasticsearch.compute.operator.EvalOperator.EvalOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeRequest
- hashCode() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- hashCode() - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.ExchangeSinkOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.Status
- hashCode() - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.ExchangeSourceOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- hashCode() - Method in record class org.elasticsearch.compute.operator.FilterOperator.FilterOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
- hashCode() - Method in record class org.elasticsearch.compute.operator.IsBlockedResult
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
- hashCode() - Method in record class org.elasticsearch.compute.operator.LocalSourceOperator.LocalSourceFactory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe.HashResult
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.MvExpandOperator.Factory
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- hashCode() - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.OutputOperator.OutputOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.ProjectOperator.ProjectOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Factory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Key
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.ScoreOperator.ScoreOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.ShowOperator.ShowOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.StringExtractOperator.StringExtractOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Final
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.SupplierWithChannels
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.SortOrder
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
-
Returns a hash code value for this object.
- hashCode() - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- hashCode() - Method in class org.elasticsearch.compute.querydsl.query.SingleValueMatchQuery
- hashLookup(BlockFactory, BytesRefHash) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBytesRef
-
Dedupe values and build an
IntBlock
of their hashes. - hashLookup(BlockFactory, LongHash) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeDouble
-
Dedupe values and build an
IntBlock
of their hashes. - hashLookup(BlockFactory, LongHash) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeInt
-
Dedupe values and build an
IntBlock
of their hashes. - hashLookup(BlockFactory, LongHash) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeLong
-
Dedupe values and build an
IntBlock
of their hashes. - hashNanos() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
-
Nanoseconds this operator has spent hashing grouping keys.
- hashOrd(boolean[], boolean) - Static method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBoolean
-
Convert the boolean to an ordinal and track if it's been seen in
everSeen
. - hashOrdToGroup(long) - Static method in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
-
Convert the result of calling
LongHash
orLongLongHash
orBytesRefHash
or similar to a group ordinal. - hashOrdToGroupNullReserved(long) - Static method in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
-
Convert the result of calling
LongHash
orLongLongHash
orBytesRefHash
or similar to a group ordinal, reserving0
for null. - HashResult(IntBlock, boolean) - Constructor for record class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe.HashResult
-
Creates an instance of a
HashResult
record class. - hasMultiValues - Variable in class org.elasticsearch.compute.data.AbstractBlockBuilder
- hasNonNullValue - Variable in class org.elasticsearch.compute.data.AbstractBlockBuilder
- hasReferences() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- hasReferences() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.CompositeBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- hasReferences() - Method in class org.elasticsearch.compute.data.DocBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.DocVector
- hasReferences() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- hasReferences() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- hasReferences() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- hasReferences() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- hasReferences() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- hasReferences() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- hasReferences() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- hasValue(int) - Method in class org.elasticsearch.compute.aggregation.AbstractArrayState
I
- IGNORE - Enum constant in enum class org.elasticsearch.compute.operator.DriverContext.WarningsMode
- INACTIVE_SINKS_INTERVAL_DEFAULT - Static variable in class org.elasticsearch.compute.operator.exchange.ExchangeService
- INACTIVE_SINKS_INTERVAL_SETTING - Static variable in class org.elasticsearch.compute.operator.exchange.ExchangeService
-
The time interval for an exchange sink handler to be considered inactive and subsequently removed from the exchange service if no sinks are attached (i.e., no computation uses that sink handler).
- incRef() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- incRef() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- incRef() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- incRef() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- incRef() - Method in class org.elasticsearch.compute.data.CompositeBlock
- incRef() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- incRef() - Method in class org.elasticsearch.compute.data.DocBlock
- incRef() - Method in class org.elasticsearch.compute.data.DocVector
- incRef() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- incRef() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- incRef() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- incRef() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- incRef() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- incRef() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- incRef() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- incRef() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- incRef() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- incRef() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- incRef() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- incRef() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- incRef() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- incRef() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- incRef() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- index() - Method in interface org.elasticsearch.compute.lucene.ShardContext
-
The index of this shard in the list of shards being processed.
- initGrouping(BigArrays) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBooleanAggregator
- initGrouping(BigArrays) - Static method in class org.elasticsearch.compute.aggregation.StdDevDoubleAggregator
- initGrouping(BigArrays) - Static method in class org.elasticsearch.compute.aggregation.StdDevFloatAggregator
- initGrouping(BigArrays) - Static method in class org.elasticsearch.compute.aggregation.StdDevIntAggregator
- initGrouping(BigArrays) - Static method in class org.elasticsearch.compute.aggregation.StdDevLongAggregator
- initGrouping(BigArrays, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBytesRefAggregator
- initGrouping(BigArrays, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctDoubleAggregator
- initGrouping(BigArrays, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctFloatAggregator
- initGrouping(BigArrays, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctIntAggregator
- initGrouping(BigArrays, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctLongAggregator
- initGrouping(DriverContext, long) - Static method in class org.elasticsearch.compute.aggregation.RateDoubleAggregator
- initGrouping(DriverContext, long) - Static method in class org.elasticsearch.compute.aggregation.RateFloatAggregator
- initGrouping(DriverContext, long) - Static method in class org.elasticsearch.compute.aggregation.RateIntAggregator
- initGrouping(DriverContext, long) - Static method in class org.elasticsearch.compute.aggregation.RateLongAggregator
- Initial(int, int, List<BlockHash.GroupSpec>, List<TimeSeriesAggregationOperatorFactories.SupplierWithChannels>, List<TimeSeriesAggregationOperatorFactories.SupplierWithChannels>, int) - Constructor for record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
-
Creates an instance of a
Initial
record class. - INITIAL - Enum constant in enum class org.elasticsearch.compute.aggregation.AggregatorMode
-
Maps raw inputs to intermediate outputs.
- initializeEarlyTerminationChecker(Runnable) - Method in class org.elasticsearch.compute.operator.DriverContext
-
Initializes the early termination or cancellation checker for this DriverContext.
- initSingle() - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBooleanAggregator
- initSingle() - Static method in class org.elasticsearch.compute.aggregation.StdDevDoubleAggregator
- initSingle() - Static method in class org.elasticsearch.compute.aggregation.StdDevFloatAggregator
- initSingle() - Static method in class org.elasticsearch.compute.aggregation.StdDevIntAggregator
- initSingle() - Static method in class org.elasticsearch.compute.aggregation.StdDevLongAggregator
- initSingle(BigArrays, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctBytesRefAggregator
- initSingle(BigArrays, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctDoubleAggregator
- initSingle(BigArrays, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctFloatAggregator
- initSingle(BigArrays, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctIntAggregator
- initSingle(BigArrays, int) - Static method in class org.elasticsearch.compute.aggregation.CountDistinctLongAggregator
- innerToXContent(XContentBuilder) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
-
Render the body of the object for this status.
- innerToXContent(XContentBuilder) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
-
Render the body of the object for this status.
- innerToXContent(XContentBuilder) - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- inputEvalSupplier() - Method in record class org.elasticsearch.compute.operator.ColumnExtractOperator.Factory
-
Returns the value of the
inputEvalSupplier
record component. - insertNulls(IntVector) - Method in interface org.elasticsearch.compute.data.Block
- INT - Enum constant in enum class org.elasticsearch.compute.data.ElementType
- IntBigArrayBlock - Class in org.elasticsearch.compute.data
-
Block implementation that stores values in a
IntBigArrayVector
. - IntBigArrayBlock(IntArray, int, int[], BitSet, Block.MvOrdering, BlockFactory) - Constructor for class org.elasticsearch.compute.data.IntBigArrayBlock
- IntBigArrayVector - Class in org.elasticsearch.compute.data
-
Vector implementation that defers to an enclosed
IntArray
. - IntBigArrayVector(IntArray, int, BlockFactory) - Constructor for class org.elasticsearch.compute.data.IntBigArrayVector
- IntBlock - Interface in org.elasticsearch.compute.data
-
Block that stores int values.
- IntBlock.Builder - Interface in org.elasticsearch.compute.data
-
Builder for
IntBlock
- IntBucketedSort - Class in org.elasticsearch.compute.data.sort
-
Aggregates the top N int values per bucket.
- IntBucketedSort(BigArrays, SortOrder, int) - Constructor for class org.elasticsearch.compute.data.sort.IntBucketedSort
- INTEGER - Enum constant in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
- INTEGER - Enum constant in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
- Intermediate(int, int, List<BlockHash.GroupSpec>, List<TimeSeriesAggregationOperatorFactories.SupplierWithChannels>, List<TimeSeriesAggregationOperatorFactories.SupplierWithChannels>, int) - Constructor for record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
-
Creates an instance of a
Intermediate
record class. - INTERMEDIATE - Enum constant in enum class org.elasticsearch.compute.aggregation.AggregatorMode
-
Maps intermediate inputs to intermediate outputs.
- intermediateBlockCount() - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunction
-
The number of blocks used by intermediate state.
- intermediateBlockCount() - Method in class org.elasticsearch.compute.aggregation.CountAggregatorFunction
- intermediateBlockCount() - Method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- intermediateBlockCount() - Method in class org.elasticsearch.compute.aggregation.FromPartialAggregatorFunction
- intermediateBlockCount() - Method in class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- intermediateBlockCount() - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorFunction
-
The number of blocks used by intermediate state.
- intermediateBlockCount() - Method in class org.elasticsearch.compute.aggregation.ToPartialAggregatorFunction
- intermediateBlockCount() - Method in class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- intermediateStateDesc() - Static method in class org.elasticsearch.compute.aggregation.CountAggregatorFunction
- intermediateStateDesc() - Static method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- intermediateStateDesc() - Static method in class org.elasticsearch.compute.aggregation.FromPartialAggregatorFunction
- intermediateStateDesc() - Static method in class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- intermediateStateDesc() - Static method in class org.elasticsearch.compute.aggregation.ToPartialAggregatorFunction
- intermediateStateDesc() - Static method in class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- IntermediateStateDesc - Record Class in org.elasticsearch.compute.aggregation
-
Intermediate aggregation state descriptor.
- IntermediateStateDesc(String, ElementType) - Constructor for record class org.elasticsearch.compute.aggregation.IntermediateStateDesc
- IntermediateStateDesc(String, ElementType, String) - Constructor for record class org.elasticsearch.compute.aggregation.IntermediateStateDesc
-
Creates an instance of a
IntermediateStateDesc
record class. - IntLongBlockAdd - Class in org.elasticsearch.compute.operator.mvdedupe
- IntLongBlockAdd(BlockFactory, int, GroupingAggregatorFunction.AddInput, LongLongHash, IntBlock, LongBlock) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.IntLongBlockAdd
- Ints(int) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Ints
- IntVector - Interface in org.elasticsearch.compute.data
-
Vector that stores int values.
- IntVector.Builder - Interface in org.elasticsearch.compute.data
-
A builder that grows as needed.
- IntVector.FixedBuilder - Interface in org.elasticsearch.compute.data
-
A builder that never grows.
- IntVectorBlock - Class in org.elasticsearch.compute.data
-
Block view of a
IntVector
. - IntVectorFixedBuilder - Class in org.elasticsearch.compute.data
-
Builder for
IntVector
s that never grows. - IP - Static variable in interface org.elasticsearch.compute.operator.topn.TopNEncoder
-
An encoder for IP addresses.
- IpArrayState - Class in org.elasticsearch.compute.aggregation
-
Aggregator state for an array of IPs.
- IpBucketedSort - Class in org.elasticsearch.compute.data.sort
-
Aggregates the top N IP values per bucket.
- IpBucketedSort(BigArrays, SortOrder, int) - Constructor for class org.elasticsearch.compute.data.sort.IpBucketedSort
- ipTermQueryList(MappedFieldType, SearchExecutionContext, BytesRefBlock) - Static method in class org.elasticsearch.compute.operator.lookup.QueryList
-
Returns a list of term queries for the given field and the input block of
ip
field values. - isBlocked() - Method in class org.elasticsearch.compute.operator.AsyncOperator
- isBlocked() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator
- isBlocked() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator
- isBlocked() - Method in interface org.elasticsearch.compute.operator.Operator
-
An operator can be blocked on some action (e.g.
- IsBlockedResult - Record Class in org.elasticsearch.compute.operator
-
Is this
Operator
blocked? - IsBlockedResult(SubscribableListener<Void>, String) - Constructor for record class org.elasticsearch.compute.operator.IsBlockedResult
-
Creates an instance of a
IsBlockedResult
record class. - isCategorize() - Method in record class org.elasticsearch.compute.aggregation.blockhash.BlockHash.GroupSpec
-
Returns the value of the
isCategorize
record component. - isConstant() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- isConstant() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- isConstant() - Method in class org.elasticsearch.compute.data.DocVector
- isConstant() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- isConstant() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- isConstant() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- isConstant() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- isConstant() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- isConstant() - Method in interface org.elasticsearch.compute.data.Vector
-
Returns true iff this vector is a constant vector - returns the same constant value for every position.
- isDense() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- isDense() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
-
Returns true if this ordinal block is dense enough to enable optimizations using its ordinals
- isDense() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
-
Returns true if this ordinal vector is dense enough to enable optimizations using its ordinals
- isEmpty() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
- isFinished() - Method in class org.elasticsearch.compute.lucene.LuceneCountOperator
- isFinished() - Method in class org.elasticsearch.compute.lucene.LuceneSourceOperator
- isFinished() - Method in class org.elasticsearch.compute.lucene.LuceneTopNSourceOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.AggregationOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.AsyncOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.DriverContext
-
Tells whether this context is finished.
- isFinished() - Method in interface org.elasticsearch.compute.operator.exchange.ExchangeSink
-
Whether the sink has received all pages
- isFinished() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkHandler
-
Returns true if an exchange is finished
- isFinished() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator
- isFinished() - Method in interface org.elasticsearch.compute.operator.exchange.ExchangeSource
-
Whether the associated sinks are finished and pages are processed.
- isFinished() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.LimitOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.LocalSourceOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.lookup.EnrichQuerySourceOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.lookup.MergePositionsOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.MvExpandOperator
- isFinished() - Method in interface org.elasticsearch.compute.operator.Operator
-
whether the operator has finished processing all input pages and made the corresponding output pages available
- isFinished() - Method in class org.elasticsearch.compute.operator.OrdinalsGroupingOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.OutputOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.PageConsumerOperator
- isFinished() - Method in class org.elasticsearch.compute.operator.topn.TopNOperator
- isInputPartial() - Method in enum class org.elasticsearch.compute.aggregation.AggregatorMode
- isNull(int) - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.DocBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.IntVectorBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.LongVectorBlock
- isNull(int) - Method in interface org.elasticsearch.compute.data.Block
- isNull(int) - Method in class org.elasticsearch.compute.data.CompositeBlock
- isNull(int) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- isNull(int) - Method in interface org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.IsNull
- isOutputPartial() - Method in enum class org.elasticsearch.compute.aggregation.AggregatorMode
- isReleased() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- isReleased() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- isReleased() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- isReleased() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- isReleased() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- isReleased() - Method in class org.elasticsearch.compute.data.CompositeBlock
- isReleased() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- isReleased() - Method in class org.elasticsearch.compute.data.DocBlock
- isReleased() - Method in class org.elasticsearch.compute.data.DocVector
- isReleased() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- isReleased() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- isReleased() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- isReleased() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- isReleased() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- isReleased() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- isReleased() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- isReleased() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- isReleased() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- isReleased() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- isReleased() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- isReleased() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- isReleased() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- isReleased() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- isReleased() - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
- isReleased() - Method in interface org.elasticsearch.compute.data.Block
-
Tells if this block has been released.
- isReleased() - Method in class org.elasticsearch.compute.data.BooleanVectorFixedBuilder
- isReleased() - Method in class org.elasticsearch.compute.data.DoubleVectorFixedBuilder
- isReleased() - Method in class org.elasticsearch.compute.data.FloatVectorFixedBuilder
- isReleased() - Method in class org.elasticsearch.compute.data.IntVectorFixedBuilder
- isReleased() - Method in class org.elasticsearch.compute.data.LongVectorFixedBuilder
- isReleased() - Method in interface org.elasticsearch.compute.data.Vector
-
Whether this vector was released
- isStillSleeping() - Method in record class org.elasticsearch.compute.operator.DriverSleeps.Sleep
- iterations() - Method in class org.elasticsearch.compute.operator.DriverProfile
-
The number of times the driver has moved a single page up the chain of operators as far as it'll go.
- iterations() - Method in class org.elasticsearch.compute.operator.DriverStatus
-
The number of times the driver has moved a single page up the chain of operators as far as it'll go.
J
- join(Page) - Method in class org.elasticsearch.compute.operator.lookup.RightChunkedLeftJoin
K
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.Block
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.BooleanBlock
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.BooleanVector
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.BytesRefBlock
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.BytesRefVector
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.CompositeBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.ConstantNullVector
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.DocBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.DocVector
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.DoubleBlock
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.DoubleVector
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.FloatBlock
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.FloatVector
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.IntBlock
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.IntVector
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.IntVectorBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.LongBlock
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.LongVector
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.LongVectorBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- keepMask(BooleanVector) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- keepMask(BooleanVector) - Method in interface org.elasticsearch.compute.data.Vector
- Key(String, Block) - Constructor for record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Key
-
Creates an instance of a
Key
record class. - keys() - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Factory
-
Returns the value of the
keys
record component.
L
- last() - Method in record class org.elasticsearch.compute.operator.DriverSleeps
-
Returns the value of the
last
record component. - lastUpdated() - Method in class org.elasticsearch.compute.operator.DriverStatus
-
When this status was generated.
- leafReaderContext() - Method in record class org.elasticsearch.compute.lucene.PartialLeafReaderContext
-
Returns the value of the
leafReaderContext
record component. - leaves() - Method in record class org.elasticsearch.compute.lucene.LuceneSlice
-
Returns the value of the
leaves
record component. - length() - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
The number of bytes in this buffer.
- limit - Variable in class org.elasticsearch.compute.lucene.LuceneOperator.Factory
- limit() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Factory
- limit() - Method in class org.elasticsearch.compute.operator.Limiter
-
Returns the limit of this limiter.
- limit() - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
-
Total number of position that are emitted by this operator.
- Limiter - Class in org.elasticsearch.compute.operator
-
A shared limiter used by multiple drivers to collect hits in parallel without exceeding the output limit.
- Limiter(int) - Constructor for class org.elasticsearch.compute.operator.Limiter
- LimitOperator - Class in org.elasticsearch.compute.operator
- LimitOperator(Limiter) - Constructor for class org.elasticsearch.compute.operator.LimitOperator
- LimitOperator.Factory - Class in org.elasticsearch.compute.operator
- LimitOperator.Status - Class in org.elasticsearch.compute.operator
- limitRemaining() - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
-
Count of pages that have been processed by this operator.
- listener() - Method in record class org.elasticsearch.compute.operator.IsBlockedResult
-
Returns the value of the
listener
record component. - LOCAL_BREAKER_OVER_RESERVED_DEFAULT_MAX_SIZE - Static variable in class org.elasticsearch.compute.data.BlockFactory
- LOCAL_BREAKER_OVER_RESERVED_DEFAULT_SIZE - Static variable in class org.elasticsearch.compute.data.BlockFactory
- LOCAL_BREAKER_OVER_RESERVED_MAX_SIZE_SETTING - Static variable in class org.elasticsearch.compute.data.BlockFactory
- LOCAL_BREAKER_OVER_RESERVED_SIZE_SETTING - Static variable in class org.elasticsearch.compute.data.BlockFactory
- LocalCircuitBreaker - Class in org.elasticsearch.compute.data
-
Requesting and returning memory from a
CircuitBreaker
can be costly due to the involvement of read/write on one or several atomic longs. - LocalCircuitBreaker(CircuitBreaker, long, long) - Constructor for class org.elasticsearch.compute.data.LocalCircuitBreaker
- LocalCircuitBreaker.SizeSettings - Record Class in org.elasticsearch.compute.data
- LocalSourceFactory(Supplier<LocalSourceOperator>) - Constructor for record class org.elasticsearch.compute.operator.LocalSourceOperator.LocalSourceFactory
-
Creates an instance of a
LocalSourceFactory
record class. - LocalSourceOperator - Class in org.elasticsearch.compute.operator
- LocalSourceOperator(BlockFactory, LocalSourceOperator.ListSupplier) - Constructor for class org.elasticsearch.compute.operator.LocalSourceOperator
- LocalSourceOperator(BlockFactory, LocalSourceOperator.ObjectSupplier) - Constructor for class org.elasticsearch.compute.operator.LocalSourceOperator
- LocalSourceOperator(LocalSourceOperator.BlockSupplier) - Constructor for class org.elasticsearch.compute.operator.LocalSourceOperator
- LocalSourceOperator(LocalSourceOperator.PageSupplier) - Constructor for class org.elasticsearch.compute.operator.LocalSourceOperator
- LocalSourceOperator.BlockSupplier - Interface in org.elasticsearch.compute.operator
- LocalSourceOperator.ListSupplier - Interface in org.elasticsearch.compute.operator
- LocalSourceOperator.LocalSourceFactory - Record Class in org.elasticsearch.compute.operator
- LocalSourceOperator.ObjectSupplier - Interface in org.elasticsearch.compute.operator
- LocalSourceOperator.PageSupplier - Interface in org.elasticsearch.compute.operator
- LONG - Enum constant in enum class org.elasticsearch.compute.data.ElementType
- LONG - Enum constant in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
- LONG - Enum constant in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
- LongBigArrayBlock - Class in org.elasticsearch.compute.data
-
Block implementation that stores values in a
LongBigArrayVector
. - LongBigArrayBlock(LongArray, int, int[], BitSet, Block.MvOrdering, BlockFactory) - Constructor for class org.elasticsearch.compute.data.LongBigArrayBlock
- LongBigArrayVector - Class in org.elasticsearch.compute.data
-
Vector implementation that defers to an enclosed
LongArray
. - LongBigArrayVector(LongArray, int, BlockFactory) - Constructor for class org.elasticsearch.compute.data.LongBigArrayVector
- LongBlock - Interface in org.elasticsearch.compute.data
-
Block that stores long values.
- LongBlock.Builder - Interface in org.elasticsearch.compute.data
-
Builder for
LongBlock
- LongBucketedSort - Class in org.elasticsearch.compute.data.sort
-
Aggregates the top N long values per bucket.
- LongBucketedSort(BigArrays, SortOrder, int) - Constructor for class org.elasticsearch.compute.data.sort.LongBucketedSort
- LongLongBlockAdd - Class in org.elasticsearch.compute.operator.mvdedupe
- LongLongBlockAdd(BlockFactory, int, GroupingAggregatorFunction.AddInput, LongLongHash, LongBlock, LongBlock) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.LongLongBlockAdd
- Longs(int) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.Longs
- LongVector - Interface in org.elasticsearch.compute.data
-
Vector that stores long values.
- LongVector.Builder - Interface in org.elasticsearch.compute.data
-
A builder that grows as needed.
- LongVector.FixedBuilder - Interface in org.elasticsearch.compute.data
-
A builder that never grows.
- LongVectorBlock - Class in org.elasticsearch.compute.data
-
Block view of a
LongVector
. - LongVectorFixedBuilder - Class in org.elasticsearch.compute.data
-
Builder for
LongVector
s that never grows. - lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.Block
-
Builds an Iterator of new
Block
s with the sameBlock.elementType()
as this Block whose values are copied from positions in this Block. - lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.BooleanBlock
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.BooleanVector
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.BytesRefBlock
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.BytesRefVector
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.CompositeBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.ConstantNullVector
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.DocBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.DocVector
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.DoubleBlock
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.DoubleVector
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.FloatBlock
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.FloatVector
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.IntBlock
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.IntVector
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.IntVectorBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.LongBlock
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.LongVector
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.LongVectorBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- lookup(IntBlock, ByteSizeValue) - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- lookup(IntBlock, ByteSizeValue) - Method in interface org.elasticsearch.compute.data.Vector
-
Builds an Iterator of new
Block
s with the sameVector.elementType()
as thisVector
whose values are copied from positions in this Vector. - lookup(Page, ByteSizeValue) - Method in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
-
Lookup all values for the "group by" columns in the page to the hash and return an
Iterator
of the values. - lookup(Page, ByteSizeValue) - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizeBlockHash
- lookup(Page, ByteSizeValue) - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizePackedValuesBlockHash
- lookup(Page, ByteSizeValue) - Method in class org.elasticsearch.compute.aggregation.blockhash.TimeSeriesBlockHash
- lookup(Page, ByteSizeValue) - Method in class org.elasticsearch.compute.aggregation.table.AscendingSequenceRowInTableLookup
- lookup(Page, ByteSizeValue) - Method in class org.elasticsearch.compute.aggregation.table.EmptyRowInTableLookup
- lookup(Page, ByteSizeValue) - Method in class org.elasticsearch.compute.aggregation.table.RowInTableLookup
-
Lookup the values in the
Page
and, for each row, return the offset in the table that was provided when building the lookup. - LuceneCountOperator - Class in org.elasticsearch.compute.lucene
-
Source operator that incrementally counts the results in Lucene searches Returns always one entry that mimics the Count aggregation internal state: 1.
- LuceneCountOperator(BlockFactory, LuceneSliceQueue, int) - Constructor for class org.elasticsearch.compute.lucene.LuceneCountOperator
- LuceneCountOperator.Factory - Class in org.elasticsearch.compute.lucene
- LuceneMaxFactory - Class in org.elasticsearch.compute.lucene
-
Factory that generates an operator that finds the max value of a field using the
LuceneMinMaxOperator
. - LuceneMaxFactory(List<? extends ShardContext>, Function<ShardContext, Query>, DataPartitioning, int, String, LuceneMaxFactory.NumberType, int) - Constructor for class org.elasticsearch.compute.lucene.LuceneMaxFactory
- LuceneMaxFactory.NumberType - Enum Class in org.elasticsearch.compute.lucene
- LuceneMinFactory - Class in org.elasticsearch.compute.lucene
-
Factory that generates an operator that finds the min value of a field using the
LuceneMinMaxOperator
. - LuceneMinFactory(List<? extends ShardContext>, Function<ShardContext, Query>, DataPartitioning, int, String, LuceneMinFactory.NumberType, int) - Constructor for class org.elasticsearch.compute.lucene.LuceneMinFactory
- LuceneMinFactory.NumberType - Enum Class in org.elasticsearch.compute.lucene
- LuceneOperator - Class in org.elasticsearch.compute.lucene
- LuceneOperator(BlockFactory, int, LuceneSliceQueue) - Constructor for class org.elasticsearch.compute.lucene.LuceneOperator
- LuceneOperator.Factory - Class in org.elasticsearch.compute.lucene
- LuceneOperator.Status - Class in org.elasticsearch.compute.lucene
- LuceneQueryEvaluator<T> - Class in org.elasticsearch.compute.lucene
-
Base class for evaluating a Lucene query at the compute engine and providing a Block as a result.
- LuceneQueryEvaluator(BlockFactory, LuceneQueryEvaluator.ShardConfig[]) - Constructor for class org.elasticsearch.compute.lucene.LuceneQueryEvaluator
- LuceneQueryEvaluator.ShardConfig - Record Class in org.elasticsearch.compute.lucene
- LuceneQueryExpressionEvaluator - Class in org.elasticsearch.compute.lucene
-
EvalOperator.ExpressionEvaluator
to run a LuceneQuery
during the compute engine's normal execution, yielding matches/does not match into aBooleanVector
. - LuceneQueryExpressionEvaluator.Factory - Record Class in org.elasticsearch.compute.lucene
- LuceneQueryScoreEvaluator - Class in org.elasticsearch.compute.lucene
-
ScoreOperator.ExpressionScorer
to run a LuceneQuery
during the compute engine's normal execution, yielding the corresponding scores into aDoubleVector
. - LuceneQueryScoreEvaluator.Factory - Record Class in org.elasticsearch.compute.lucene
- LuceneSlice - Record Class in org.elasticsearch.compute.lucene
-
Holds a list of multiple partial Lucene segments
- LuceneSlice(ShardContext, List<PartialLeafReaderContext>, Weight) - Constructor for record class org.elasticsearch.compute.lucene.LuceneSlice
-
Creates an instance of a
LuceneSlice
record class. - LuceneSliceQueue - Class in org.elasticsearch.compute.lucene
-
Shared Lucene slices between Lucene operators.
- LuceneSourceOperator - Class in org.elasticsearch.compute.lucene
-
Source operator that incrementally runs Lucene searches
- LuceneSourceOperator(BlockFactory, int, LuceneSliceQueue, int, Limiter, ScoreMode) - Constructor for class org.elasticsearch.compute.lucene.LuceneSourceOperator
- LuceneSourceOperator.Factory - Class in org.elasticsearch.compute.lucene
- LuceneTopNSourceOperator - Class in org.elasticsearch.compute.lucene
-
Source operator that builds Pages out of the output of a TopFieldCollector (aka TopN)
- LuceneTopNSourceOperator(BlockFactory, int, List<SortBuilder<?>>, int, LuceneSliceQueue, ScoreMode) - Constructor for class org.elasticsearch.compute.lucene.LuceneTopNSourceOperator
- LuceneTopNSourceOperator.Factory - Class in org.elasticsearch.compute.lucene
M
- m2() - Method in class org.elasticsearch.compute.aggregation.WelfordAlgorithm
- mapper() - Method in record class org.elasticsearch.compute.operator.OutputOperator.OutputOperatorFactory
-
Returns the value of the
mapper
record component. - mask() - Method in record class org.elasticsearch.compute.data.ToMask
-
Returns the value of the
mask
record component. - max() - Method in record class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.AggregateMetricDoubleLiteral
-
Returns the value of the
max
record component. - max() - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- max() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- max() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
-
The maximum value in the block.
- max() - Method in interface org.elasticsearch.compute.data.IntVector
-
The maximum value in the Vector.
- MAX - Enum constant in enum class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.Metric
- MAX_BLOCK_PRIMITIVE_ARRAY_SIZE_SETTING - Static variable in class org.elasticsearch.compute.data.BlockFactory
- MAX_LOOKUP - Static variable in interface org.elasticsearch.compute.data.Block
-
The maximum number of values that can be added to one position via lookup.
- maxDoc() - Method in record class org.elasticsearch.compute.lucene.PartialLeafReaderContext
-
Returns the value of the
maxDoc
record component. - maxNeg(int, int) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- maxOverReservedBytes() - Method in record class org.elasticsearch.compute.data.LocalCircuitBreaker.SizeSettings
-
Returns the value of the
maxOverReservedBytes
record component. - maxPageSize() - Method in class org.elasticsearch.compute.lucene.LuceneSourceOperator.Factory
- maxPageSize() - Method in class org.elasticsearch.compute.lucene.LuceneTopNSourceOperator.Factory
- maxPageSize() - Method in record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
-
Returns the value of the
maxPageSize
record component. - maxPageSize() - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Returns the value of the
maxPageSize
record component. - maxPageSize() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Final
-
Returns the value of the
maxPageSize
record component. - maxPageSize() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
-
Returns the value of the
maxPageSize
record component. - maxPageSize() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
-
Returns the value of the
maxPageSize
record component. - maxPageSize() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
-
Returns the value of the
maxPageSize
record component. - maxPrimitiveArrayBytes() - Method in class org.elasticsearch.compute.data.BlockFactory
-
Returns the maximum number of bytes that a Block should be backed by a primitive array before switching to using BigArrays.
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.DocBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- mayHaveMultivaluedFields() - Method in interface org.elasticsearch.compute.data.Block
-
Can this block have multivalued fields? Blocks that return
false
will never return more than one fromBlock.getValueCount(int)
. - mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.CompositeBlock
- mayHaveMultivaluedFields() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.DocBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- mayHaveNulls() - Method in interface org.elasticsearch.compute.data.Block
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.CompositeBlock
- mayHaveNulls() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- mean() - Method in class org.elasticsearch.compute.aggregation.WelfordAlgorithm
- MEDIAN - Static variable in class org.elasticsearch.compute.aggregation.QuantileStates
- merge(int, BooleanBucketedSort, int) - Method in class org.elasticsearch.compute.data.sort.BooleanBucketedSort
-
Merge the values from
other
'sotherGroupId
intogroupId
. - merge(int, BytesRefBucketedSort, int) - Method in class org.elasticsearch.compute.data.sort.BytesRefBucketedSort
-
Merge the values from
other
'sotherGroupId
intogroupId
. - merge(int, DoubleBucketedSort, int) - Method in class org.elasticsearch.compute.data.sort.DoubleBucketedSort
-
Merge the values from
other
'sotherGroupId
intogroupId
. - merge(int, FloatBucketedSort, int) - Method in class org.elasticsearch.compute.data.sort.FloatBucketedSort
-
Merge the values from
other
'sotherGroupId
intogroupId
. - merge(int, IntBucketedSort, int) - Method in class org.elasticsearch.compute.data.sort.IntBucketedSort
-
Merge the values from
other
'sotherGroupId
intogroupId
. - merge(int, IpBucketedSort, int) - Method in class org.elasticsearch.compute.data.sort.IpBucketedSort
-
Merge the values from
other
'sotherGroupId
intogroupId
. - merge(int, LongBucketedSort, int) - Method in class org.elasticsearch.compute.data.sort.LongBucketedSort
-
Merge the values from
other
'sotherGroupId
intogroupId
. - MergePositionsOperator - Class in org.elasticsearch.compute.operator.lookup
-
Combines values at the given blocks with the same positions into a single position for the blocks at the given channels.
- MergePositionsOperator(int, int[], ElementType[], IntBlock, BlockFactory) - Constructor for class org.elasticsearch.compute.operator.lookup.MergePositionsOperator
- min() - Method in record class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.AggregateMetricDoubleLiteral
-
Returns the value of the
min
record component. - min() - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- min() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- min() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
-
The minimum value in the block.
- min() - Method in interface org.elasticsearch.compute.data.IntVector
-
The minimum value in the Vector.
- MIN - Enum constant in enum class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.Metric
- MIN_TARGET_PAGE_SIZE - Static variable in interface org.elasticsearch.compute.operator.Operator
-
The minimum number of positions for a
SourceOperator
to target generating. - minDoc() - Method in record class org.elasticsearch.compute.lucene.PartialLeafReaderContext
-
Returns the value of the
minDoc
record component. - minPos(int, int) - Static method in class org.elasticsearch.compute.aggregation.spatial.SpatialAggregationUtils
- mode() - Method in record class org.elasticsearch.compute.operator.AggregationOperator.AggregationOperatorFactory
-
Returns the value of the
mode
record component. - MultivalueDedupe - Class in org.elasticsearch.compute.operator.mvdedupe
-
Utilities to remove duplicates from multivalued fields.
- MultivalueDedupe.HashResult - Record Class in org.elasticsearch.compute.operator.mvdedupe
-
Result of calling "hash" on a multivalue dedupe.
- MultivalueDedupeBoolean - Class in org.elasticsearch.compute.operator.mvdedupe
-
Removes duplicate values from multivalued positions.
- MultivalueDedupeBoolean(BooleanBlock) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBoolean
- MultivalueDedupeBytesRef - Class in org.elasticsearch.compute.operator.mvdedupe
-
Removes duplicate values from multivalued positions.
- MultivalueDedupeBytesRef(BytesRefBlock) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBytesRef
- MultivalueDedupeDouble - Class in org.elasticsearch.compute.operator.mvdedupe
-
Removes duplicate values from multivalued positions.
- MultivalueDedupeDouble(DoubleBlock) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeDouble
- MultivalueDedupeInt - Class in org.elasticsearch.compute.operator.mvdedupe
-
Removes duplicate values from multivalued positions.
- MultivalueDedupeInt(IntBlock) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeInt
- MultivalueDedupeLong - Class in org.elasticsearch.compute.operator.mvdedupe
-
Removes duplicate values from multivalued positions.
- MultivalueDedupeLong(LongBlock) - Constructor for class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeLong
- multiValueMode(SortedNumericDocValues) - Method in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
- multiValueMode(SortedNumericDocValues) - Method in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
- mvDeduplicated() - Method in interface org.elasticsearch.compute.data.Block
-
Are multivalued fields de-duplicated in each position
- mvDeduplicated() - Method in class org.elasticsearch.compute.data.CompositeBlock
- MvExpandOperator - Class in org.elasticsearch.compute.operator
-
"Expands" multivalued blocks by duplicating all the other columns for each value.
- MvExpandOperator(int, int) - Constructor for class org.elasticsearch.compute.operator.MvExpandOperator
- MvExpandOperator.Factory - Record Class in org.elasticsearch.compute.operator
- MvExpandOperator.Status - Class in org.elasticsearch.compute.operator
- mvOrdering - Variable in class org.elasticsearch.compute.data.AbstractBlockBuilder
- mvOrdering() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.DocBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- mvOrdering() - Method in interface org.elasticsearch.compute.data.Block
-
How are multivalued fields ordered?
- mvOrdering() - Method in class org.elasticsearch.compute.data.CompositeBlock
- mvOrdering() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- mvOrdering(Block.MvOrdering) - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- mvOrdering(Block.MvOrdering) - Method in interface org.elasticsearch.compute.data.Block.Builder
-
How are multivalued fields ordered? This defaults to
Block.MvOrdering.UNORDERED
but when you set it toBlock.MvOrdering.DEDUPLICATED_AND_SORTED_ASCENDING
some operators can optimize themselves. - mvOrdering(Block.MvOrdering) - Method in interface org.elasticsearch.compute.data.BooleanBlock.Builder
- mvOrdering(Block.MvOrdering) - Method in interface org.elasticsearch.compute.data.BytesRefBlock.Builder
- mvOrdering(Block.MvOrdering) - Method in class org.elasticsearch.compute.data.DocBlock.Builder
- mvOrdering(Block.MvOrdering) - Method in interface org.elasticsearch.compute.data.DoubleBlock.Builder
- mvOrdering(Block.MvOrdering) - Method in interface org.elasticsearch.compute.data.FloatBlock.Builder
- mvOrdering(Block.MvOrdering) - Method in interface org.elasticsearch.compute.data.IntBlock.Builder
- mvOrdering(Block.MvOrdering) - Method in interface org.elasticsearch.compute.data.LongBlock.Builder
- mvOrdering(Block.MvOrdering) - Method in class org.elasticsearch.compute.data.SingletonOrdinalsBuilder
- mvSortedAscending() - Method in interface org.elasticsearch.compute.data.Block
-
Are multivalued fields sorted ascending in each position
- mvSortedAscending() - Method in class org.elasticsearch.compute.data.CompositeBlock
N
- name() - Method in record class org.elasticsearch.compute.aggregation.IntermediateStateDesc
-
Returns the value of the
name
record component. - name() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.FieldInfo
-
Returns the value of the
name
record component. - name() - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Values
-
Returns the value of the
name
record component. - name() - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Key
-
Returns the value of the
name
record component. - needsInput() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.AggregationOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.AsyncOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.LimitOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.lookup.MergePositionsOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.MvExpandOperator
- needsInput() - Method in interface org.elasticsearch.compute.operator.Operator
-
whether the given operator can accept more input pages
- needsInput() - Method in class org.elasticsearch.compute.operator.OrdinalsGroupingOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.OutputOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.PageConsumerOperator
- needsInput() - Method in class org.elasticsearch.compute.operator.SourceOperator
-
A source operator needs no input - unconditionally returns false.
- needsInput() - Method in class org.elasticsearch.compute.operator.topn.TopNOperator
- newAggregateMetricDoubleBlockBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newBlockBuilder(int, BlockFactory) - Method in enum class org.elasticsearch.compute.data.ElementType
-
Create a new
Block.Builder
for blocks of this type. - newBlockBuilder(BlockFactory, int) - Static method in class org.elasticsearch.compute.data.DocBlock
-
A builder the for
DocBlock
. - newBooleanArrayBlock(boolean[], int, int[], BitSet, Block.MvOrdering) - Method in class org.elasticsearch.compute.data.BlockFactory
- newBooleanArrayBlock(boolean[], int, int[], BitSet, Block.MvOrdering, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newBooleanArrayVector(boolean[], int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newBooleanArrayVector(boolean[], int, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newBooleanBlockBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newBooleanVectorBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newBooleanVectorFixedBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
-
Build a
BooleanVector.FixedBuilder
that never grows. - newBytesRefArrayBlock(BytesRefArray, int, int[], BitSet, Block.MvOrdering) - Method in class org.elasticsearch.compute.data.BlockFactory
- newBytesRefArrayVector(BytesRefArray, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newBytesRefBlockBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newBytesRefVectorBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newChildFactory(LocalCircuitBreaker) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantAggregateMetricDoubleBlock(AggregateMetricDoubleBlockBuilder.AggregateMetricDoubleLiteral, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantBooleanBlockWith(boolean, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantBooleanBlockWith(boolean, int, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantBooleanVector(boolean, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantBytesRefBlockWith(BytesRef, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantBytesRefVector(BytesRef, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantDoubleBlockWith(double, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantDoubleBlockWith(double, int, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantDoubleVector(double, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantFloatBlockWith(float, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantFloatBlockWith(float, int, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantFloatVector(float, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantIntBlockWith(int, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantIntBlockWith(int, int, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantIntVector(int, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantLongBlockWith(long, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantLongBlockWith(long, int, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantLongVector(long, int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newConstantNullBlock(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newDoubleArrayBlock(double[], int, int[], BitSet, Block.MvOrdering) - Method in class org.elasticsearch.compute.data.BlockFactory
- newDoubleArrayBlock(double[], int, int[], BitSet, Block.MvOrdering, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newDoubleArrayVector(double[], int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newDoubleArrayVector(double[], int, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newDoubleBlockBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newDoubleVectorBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newDoubleVectorFixedBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
-
Build a
DoubleVector.FixedBuilder
that never grows. - newFloatArrayBlock(float[], int, int[], BitSet, Block.MvOrdering) - Method in class org.elasticsearch.compute.data.BlockFactory
- newFloatArrayBlock(float[], int, int[], BitSet, Block.MvOrdering, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newFloatArrayVector(float[], int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newFloatArrayVector(float[], int, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newFloatBlockBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newFloatVectorBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newFloatVectorFixedBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
-
Build a
FloatVector.FixedBuilder
that never grows. - newIntArrayBlock(int[], int, int[], BitSet, Block.MvOrdering) - Method in class org.elasticsearch.compute.data.BlockFactory
- newIntArrayBlock(int[], int, int[], BitSet, Block.MvOrdering, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newIntArrayVector(int[], int) - Method in class org.elasticsearch.compute.data.BlockFactory
-
Creates a new Vector with the given values and positionCount.
- newIntArrayVector(int[], int, long) - Method in class org.elasticsearch.compute.data.BlockFactory
-
Creates a new Vector with the given values and positionCount, where the caller has already pre-adjusted a number of bytes with the factory's breaker.
- newIntBlockBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newIntVectorBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newIntVectorFixedBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
-
Build a
IntVector.FixedBuilder
that never grows. - newLongArrayBlock(long[], int, int[], BitSet, Block.MvOrdering) - Method in class org.elasticsearch.compute.data.BlockFactory
- newLongArrayBlock(long[], int, int[], BitSet, Block.MvOrdering, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newLongArrayVector(long[], int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newLongArrayVector(long[], int, long) - Method in class org.elasticsearch.compute.data.BlockFactory
- newLongBlockBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newLongVectorBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- newLongVectorFixedBuilder(int) - Method in class org.elasticsearch.compute.data.BlockFactory
-
Build a
LongVector.FixedBuilder
that never grows. - newRemoteSink(Task, String, TransportService, Transport.Connection) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
-
Creates a new
RemoteSink
that fetches pages from an exchange sink located on the remote node. - newSourceLoader() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.ShardContext
-
Returns the value of the
newSourceLoader
record component. - next() - Method in record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
-
Returns the value of the
next
record component. - nextSlice() - Method in class org.elasticsearch.compute.lucene.LuceneSliceQueue
- NO_BLOCKS - Static variable in class org.elasticsearch.compute.data.BlockUtils
- NO_LIMIT - Static variable in class org.elasticsearch.compute.lucene.LuceneOperator
- NO_LIMIT - Static variable in class org.elasticsearch.compute.operator.Limiter
- NO_MATCH_SCORE - Static variable in class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator
- noMoreRightHandPages() - Method in class org.elasticsearch.compute.operator.lookup.RightChunkedLeftJoin
- nonEmpty() - Method in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
-
The grouping ids that are not empty.
- nonEmpty() - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizeBlockHash
- nonEmpty() - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizePackedValuesBlockHash
- nonEmpty() - Method in class org.elasticsearch.compute.aggregation.blockhash.TimeSeriesBlockHash
- nonGroupingIntermediateStateDesc() - Method in interface org.elasticsearch.compute.aggregation.AggregatorFunctionSupplier
- nonGroupingIntermediateStateDesc() - Method in record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
- nonRates() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Final
-
Returns the value of the
nonRates
record component. - nonRates() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
-
Returns the value of the
nonRates
record component. - nonRates() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
-
Returns the value of the
nonRates
record component. - NOOP_WARNINGS - Static variable in class org.elasticsearch.compute.operator.Warnings
- noops() - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- NOT_BLOCKED - Static variable in interface org.elasticsearch.compute.operator.Operator
- NULL - Enum constant in enum class org.elasticsearch.compute.data.ElementType
-
Blocks containing only null values.
- NULL_ORD - Static variable in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBoolean
-
Ordinal assigned to
null
. - NULL_VALUE - Static variable in interface org.elasticsearch.compute.data.BytesRefBlock
- nullsFirst() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.SortOrder
-
Returns the value of the
nullsFirst
record component. - nullsMask - Variable in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- nullsMask - Variable in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- nullsMask - Variable in class org.elasticsearch.compute.data.FloatBigArrayBlock
- nullsMask - Variable in class org.elasticsearch.compute.data.IntBigArrayBlock
- nullsMask - Variable in class org.elasticsearch.compute.data.LongBigArrayBlock
- nullsMask - Variable in class org.elasticsearch.compute.data.AbstractBlockBuilder
O
- objects() - Method in record class org.elasticsearch.compute.operator.ShowOperator.ShowOperatorFactory
-
Returns the value of the
objects
record component. - occupiedRows() - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- onlySingleValues - Variable in class org.elasticsearch.compute.operator.lookup.QueryList
- onlySingleValues() - Method in class org.elasticsearch.compute.operator.lookup.QueryList
-
Returns a copy of this query list that only returns queries for single-valued positions.
- openExchange(TransportService, Transport.Connection, String, int, Executor, ActionListener<Void>) - Static method in class org.elasticsearch.compute.operator.exchange.ExchangeService
-
Opens a remote sink handler on the remote node for the given session ID.
- operator() - Method in class org.elasticsearch.compute.operator.DriverStatus.OperatorStatus
- Operator - Interface in org.elasticsearch.compute.operator
-
Operator is low-level building block that consumes, transforms and produces data.
- Operator.OperatorFactory - Interface in org.elasticsearch.compute.operator
-
A factory for creating intermediate operators.
- Operator.Status - Interface in org.elasticsearch.compute.operator
-
Status of an
Operator
to be returned by the tasks API. - operators() - Method in class org.elasticsearch.compute.operator.DriverProfile
-
Status of each
Operator
in the driver when it finished. - OperatorStatus(String, Operator.Status) - Constructor for class org.elasticsearch.compute.operator.DriverStatus.OperatorStatus
- OrdinalBytesRefBlock - Class in org.elasticsearch.compute.data
-
A
BytesRefBlock
consists of a pair: anIntBlock
for ordinals and aBytesRefVector
for the dictionary. - OrdinalBytesRefBlock(IntBlock, BytesRefVector) - Constructor for class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- OrdinalBytesRefVector - Class in org.elasticsearch.compute.data
-
A
BytesRefVector
consists of a pair: anIntVector
for ordinals and aBytesRefVector
for the dictionary. - OrdinalBytesRefVector(IntVector, BytesRefVector) - Constructor for class org.elasticsearch.compute.data.OrdinalBytesRefVector
- OrdinalsGroupingOperator - Class in org.elasticsearch.compute.operator
-
Unlike
HashAggregationOperator
, this hash operator also extracts values or ordinals of the input documents. - OrdinalsGroupingOperator(IntFunction<BlockLoader>, List<ValuesSourceReaderOperator.ShardContext>, ElementType, int, String, List<GroupingAggregator.Factory>, int, DriverContext) - Constructor for class org.elasticsearch.compute.operator.OrdinalsGroupingOperator
- OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory - Record Class in org.elasticsearch.compute.operator
- OrdinalsGroupingOperatorFactory(IntFunction<BlockLoader>, List<ValuesSourceReaderOperator.ShardContext>, ElementType, int, String, List<GroupingAggregator.Factory>, int) - Constructor for record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Creates an instance of a
OrdinalsGroupingOperatorFactory
record class. - ords() - Method in record class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe.HashResult
-
Returns the value of the
ords
record component. - org.elasticsearch.compute - module org.elasticsearch.compute
- org.elasticsearch.compute - package org.elasticsearch.compute
-
This package exposes the core compute engine functionality.
- org.elasticsearch.compute.aggregation - package org.elasticsearch.compute.aggregation
- org.elasticsearch.compute.aggregation.blockhash - package org.elasticsearch.compute.aggregation.blockhash
- org.elasticsearch.compute.aggregation.spatial - package org.elasticsearch.compute.aggregation.spatial
- org.elasticsearch.compute.aggregation.table - package org.elasticsearch.compute.aggregation.table
- org.elasticsearch.compute.data - package org.elasticsearch.compute.data
- org.elasticsearch.compute.data.sort - package org.elasticsearch.compute.data.sort
- org.elasticsearch.compute.lucene - package org.elasticsearch.compute.lucene
- org.elasticsearch.compute.operator - package org.elasticsearch.compute.operator
- org.elasticsearch.compute.operator.exchange - package org.elasticsearch.compute.operator.exchange
-
Exchanges provide the ability to split an execution into multiple pipelines.
- org.elasticsearch.compute.operator.lookup - package org.elasticsearch.compute.operator.lookup
- org.elasticsearch.compute.operator.mvdedupe - package org.elasticsearch.compute.operator.mvdedupe
- org.elasticsearch.compute.operator.topn - package org.elasticsearch.compute.operator.topn
- org.elasticsearch.compute.querydsl.query - package org.elasticsearch.compute.querydsl.query
- outerRates() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Final
-
Returns the value of the
outerRates
record component. - OutputOperator - Class in org.elasticsearch.compute.operator
-
Sink operator that calls a given listener for each page received.
- OutputOperator(List<String>, Function<Page, Page>, Consumer<Page>) - Constructor for class org.elasticsearch.compute.operator.OutputOperator
- OutputOperator.OutputOperatorFactory - Record Class in org.elasticsearch.compute.operator
- OutputOperatorFactory(List<String>, Function<Page, Page>, Consumer<Page>) - Constructor for record class org.elasticsearch.compute.operator.OutputOperator.OutputOperatorFactory
-
Creates an instance of a
OutputOperatorFactory
record class. - overReservedBytes() - Method in record class org.elasticsearch.compute.data.LocalCircuitBreaker.SizeSettings
-
Returns the value of the
overReservedBytes
record component.
P
- Page - Class in org.elasticsearch.compute.data
-
A page is a column-oriented data abstraction that allows data to be passed between operators in batches.
- Page(int, Block...) - Constructor for class org.elasticsearch.compute.data.Page
-
Creates a new page with the given positionCount and blocks.
- Page(StreamInput) - Constructor for class org.elasticsearch.compute.data.Page
- Page(Block...) - Constructor for class org.elasticsearch.compute.data.Page
-
Creates a new page with the given blocks.
- PAGE_MEM_OVERHEAD_PER_BLOCK - Static variable in interface org.elasticsearch.compute.data.Block
-
We do not track memory for pages directly (only for single blocks), but the page memory overhead can still be significant, especially for pages containing thousands of blocks.
- pageConsumer() - Method in record class org.elasticsearch.compute.operator.OutputOperator.OutputOperatorFactory
-
Returns the value of the
pageConsumer
record component. - PageConsumerOperator - Class in org.elasticsearch.compute.operator
-
Sink operator that's useful for passing off pages to a
Consumer
. - PageConsumerOperator(Consumer<Page>) - Constructor for class org.elasticsearch.compute.operator.PageConsumerOperator
- pagesEmitted() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- pagesEmitted() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- pagesEmitted() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- pagesEmitted() - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- pagesEmitted() - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- pagesProcessed() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- pagesProcessed() - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
-
Count of pages this operator has processed.
- pagesProcessed() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
-
Count of pages this operator has processed.
- pagesProcessed() - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
-
Count of pages that have been processed by this operator.
- pagesReceived() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- pagesReceived() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.Status
- pagesReceived() - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- pagesReceived() - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- pagesWaiting() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- parent() - Method in class org.elasticsearch.compute.data.BlockFactory
- parentBreaker() - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- parserSupplier() - Method in record class org.elasticsearch.compute.operator.StringExtractOperator.StringExtractOperatorFactory
-
Returns the value of the
parserSupplier
record component. - PartialLeafReaderContext - Record Class in org.elasticsearch.compute.lucene
-
A subset of a
LeafReaderContext
. - PartialLeafReaderContext(LeafReaderContext) - Constructor for record class org.elasticsearch.compute.lucene.PartialLeafReaderContext
- PartialLeafReaderContext(LeafReaderContext, int, int) - Constructor for record class org.elasticsearch.compute.lucene.PartialLeafReaderContext
-
Creates an instance of a
PartialLeafReaderContext
record class. - PartialLeafReaderContext(IndexSearcher.LeafReaderContextPartition) - Constructor for record class org.elasticsearch.compute.lucene.PartialLeafReaderContext
- pascalCaseName() - Method in enum class org.elasticsearch.compute.data.ElementType
- performAsync(Page, ActionListener<Fetched>) - Method in class org.elasticsearch.compute.operator.AsyncOperator
-
Performs an external computation and notify the listener when the result is ready.
- PointType - Enum Class in org.elasticsearch.compute.aggregation.spatial
- pollPage() - Method in interface org.elasticsearch.compute.operator.exchange.ExchangeSource
-
Remove the page from this source if any; otherwise, returns null
- positionCount - Variable in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- positionCount - Variable in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- positionCount - Variable in class org.elasticsearch.compute.data.FloatBigArrayBlock
- positionCount - Variable in class org.elasticsearch.compute.data.IntBigArrayBlock
- positionCount - Variable in class org.elasticsearch.compute.data.LongBigArrayBlock
- positionCount - Variable in class org.elasticsearch.compute.data.AbstractBlockBuilder
- positionCount() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectEncoder
- positionCount() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
The number of positions in the current batch.
- positionCount() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder
-
The number of positions in the current batch.
- positionEntryIsOpen - Variable in class org.elasticsearch.compute.data.AbstractBlockBuilder
- positionsOrd() - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Factory
-
Returns the value of the
positionsOrd
record component. - preAdjustBreakerForBoolean(int) - Method in class org.elasticsearch.compute.data.BlockFactory
-
Pre-adjusts the breaker for the given position count and element type.
- preAdjustBreakerForDouble(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- preAdjustBreakerForInt(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- preAdjustBreakerForLong(int) - Method in class org.elasticsearch.compute.data.BlockFactory
- prepareProcessPage(SeenGroupIds, Page) - Method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- prepareProcessPage(SeenGroupIds, Page) - Method in class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- prepareProcessPage(SeenGroupIds, Page) - Method in class org.elasticsearch.compute.aggregation.GroupingAggregator
-
Prepare to process a single page of results.
- prepareProcessPage(SeenGroupIds, Page) - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorFunction
-
Prepare to process a single page of input.
- prepareProcessPage(SeenGroupIds, Page) - Method in class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- process(Page) - Method in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator
- process(Page) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- process(Page) - Method in class org.elasticsearch.compute.operator.ColumnExtractOperator
- process(Page) - Method in class org.elasticsearch.compute.operator.EvalOperator
- process(Page) - Method in class org.elasticsearch.compute.operator.FilterOperator
- process(Page) - Method in class org.elasticsearch.compute.operator.ProjectOperator
- process(Page) - Method in class org.elasticsearch.compute.operator.ScoreOperator
- process(Page) - Method in class org.elasticsearch.compute.operator.StringExtractOperator
- processedQueries() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- processedShards() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- processedSlices() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- processNanos() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- processNanos() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- processNanos() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- processPage(Page, BooleanVector) - Method in class org.elasticsearch.compute.aggregation.Aggregator
- profile() - Method in class org.elasticsearch.compute.operator.Driver
-
Build a "profile" of this driver's operations after it's been completed.
- projectBlocks(int[]) - Method in class org.elasticsearch.compute.data.Page
-
Returns a new page with blocks in the containing
Block
s shifted around or removed. - projection() - Method in record class org.elasticsearch.compute.operator.ProjectOperator.ProjectOperatorFactory
-
Returns the value of the
projection
record component. - ProjectOperator - Class in org.elasticsearch.compute.operator
- ProjectOperator(List<Integer>) - Constructor for class org.elasticsearch.compute.operator.ProjectOperator
-
Creates an operator that applies the given projection, encoded as an integer list where the ordinal indicates the output order and the value, the backing channel that to be used.
- ProjectOperator.ProjectOperatorFactory - Record Class in org.elasticsearch.compute.operator
- ProjectOperatorFactory(List<Integer>) - Constructor for record class org.elasticsearch.compute.operator.ProjectOperator.ProjectOperatorFactory
-
Creates an instance of a
ProjectOperatorFactory
record class.
Q
- QuantileStates - Class in org.elasticsearch.compute.aggregation
- query() - Method in record class org.elasticsearch.compute.lucene.LuceneQueryEvaluator.ShardConfig
-
Returns the value of the
query
record component. - QueryList - Class in org.elasticsearch.compute.operator.lookup
-
Generates a list of Lucene queries based on the input block.
- QueryList(MappedFieldType, SearchExecutionContext, Block, boolean) - Constructor for class org.elasticsearch.compute.operator.lookup.QueryList
- QUEUED - Enum constant in enum class org.elasticsearch.compute.operator.DriverStatus.Status
R
- ramBytesEstimated(IntVector, IntVector, IntVector, int[], int[]) - Static method in class org.elasticsearch.compute.data.DocVector
- ramBytesUsed() - Method in class org.elasticsearch.compute.aggregation.RateDoubleAggregator.DoubleRateGroupingState
- ramBytesUsed() - Method in class org.elasticsearch.compute.aggregation.RateFloatAggregator.FloatRateGroupingState
- ramBytesUsed() - Method in class org.elasticsearch.compute.aggregation.RateIntAggregator.IntRateGroupingState
- ramBytesUsed() - Method in class org.elasticsearch.compute.aggregation.RateLongAggregator.LongRateGroupingState
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.CompositeBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.DocBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.DocVector
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- ramBytesUsed() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- ramBytesUsed() - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
- ramBytesUsed() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectEncoder
- ramBytesUsed() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
- ramBytesUsed() - Method in class org.elasticsearch.compute.operator.topn.TopNOperator
- ramBytesUsed() - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- ramBytesUsedByBlocks() - Method in class org.elasticsearch.compute.data.Page
- ramBytesUsedByPage() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- range(int, int, BlockFactory) - Static method in interface org.elasticsearch.compute.data.IntVector
-
Create a vector for a range of ints.
- Range(int, int) - Constructor for record class org.elasticsearch.compute.aggregation.SeenGroupIds.Range
-
Creates an instance of a
Range
record class. - RateDoubleAggregator - Class in org.elasticsearch.compute.aggregation
-
A rate grouping aggregation definition for double.
- RateDoubleAggregator() - Constructor for class org.elasticsearch.compute.aggregation.RateDoubleAggregator
- RateDoubleAggregator.DoubleRateGroupingState - Class in org.elasticsearch.compute.aggregation
- RateFloatAggregator - Class in org.elasticsearch.compute.aggregation
-
A rate grouping aggregation definition for float.
- RateFloatAggregator() - Constructor for class org.elasticsearch.compute.aggregation.RateFloatAggregator
- RateFloatAggregator.FloatRateGroupingState - Class in org.elasticsearch.compute.aggregation
- RateIntAggregator - Class in org.elasticsearch.compute.aggregation
-
A rate grouping aggregation definition for int.
- RateIntAggregator() - Constructor for class org.elasticsearch.compute.aggregation.RateIntAggregator
- RateIntAggregator.IntRateGroupingState - Class in org.elasticsearch.compute.aggregation
- RateLongAggregator - Class in org.elasticsearch.compute.aggregation
-
A rate grouping aggregation definition for long.
- RateLongAggregator() - Constructor for class org.elasticsearch.compute.aggregation.RateLongAggregator
- RateLongAggregator.LongRateGroupingState - Class in org.elasticsearch.compute.aggregation
- rates() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
-
Returns the value of the
rates
record component. - rates() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
-
Returns the value of the
rates
record component. - rawTermQueryList(MappedFieldType, SearchExecutionContext, Block) - Static method in class org.elasticsearch.compute.operator.lookup.QueryList
-
Returns a list of term queries for the given field and the input block using only the
ElementType
of theBlock
to determine the query. - read(int, BytesRefBuilder) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectEncoder
- read(int, BytesRefBuilder) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
Read the value at the specified index.
- read(int, BytesRefBuilder) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder
-
Read the value at the specified index then append to the
dst
. - read(StreamInput) - Static method in record class org.elasticsearch.compute.operator.DriverSleeps
- read(StreamInput) - Static method in enum class org.elasticsearch.compute.operator.DriverStatus.Status
- reader() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.ShardContext
-
Returns the value of the
reader
record component. - readersBuilt() - Method in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Status
- readFrom(BlockFactory, StreamInput) - Static method in interface org.elasticsearch.compute.data.BooleanVector
-
Deserializes a Vector from the given stream input.
- readFrom(BlockFactory, StreamInput) - Static method in interface org.elasticsearch.compute.data.BytesRefVector
-
Deserializes a Vector from the given stream input.
- readFrom(BlockFactory, StreamInput) - Static method in interface org.elasticsearch.compute.data.DoubleVector
-
Deserializes a Vector from the given stream input.
- readFrom(BlockFactory, StreamInput) - Static method in interface org.elasticsearch.compute.data.FloatVector
-
Deserializes a Vector from the given stream input.
- readFrom(BlockFactory, StreamInput) - Static method in interface org.elasticsearch.compute.data.IntVector
-
Deserializes a Vector from the given stream input.
- readFrom(BlockFactory, StreamInput) - Static method in interface org.elasticsearch.compute.data.LongVector
-
Deserializes a Vector from the given stream input.
- readFrom(BlockStreamInput) - Static method in interface org.elasticsearch.compute.data.BooleanBlock
- readFrom(BlockStreamInput) - Static method in interface org.elasticsearch.compute.data.BytesRefBlock
- readFrom(BlockStreamInput) - Static method in interface org.elasticsearch.compute.data.DoubleBlock
- readFrom(BlockStreamInput) - Static method in interface org.elasticsearch.compute.data.FloatBlock
- readFrom(BlockStreamInput) - Static method in interface org.elasticsearch.compute.data.IntBlock
- readFrom(BlockStreamInput) - Static method in interface org.elasticsearch.compute.data.LongBlock
- readNextBatch() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
Encodes the next batch of values.
- readValueAtBlockIndex(int, BytesRefBuilder) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectBooleans
- readValueAtBlockIndex(int, BytesRefBuilder) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectBytesRefs
- readValueAtBlockIndex(int, BytesRefBuilder) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectDoubles
- readValueAtBlockIndex(int, BytesRefBuilder) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectEncoder
- readValueAtBlockIndex(int, BytesRefBuilder) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectInts
- readValueAtBlockIndex(int, BytesRefBuilder) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectLongs
- readValueAtBlockIndex(int, BytesRefBuilder) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectNulls
- reason() - Method in record class org.elasticsearch.compute.operator.DriverSleeps.Sleep
-
Returns the value of the
reason
record component. - reason() - Method in record class org.elasticsearch.compute.operator.IsBlockedResult
-
Returns the value of the
reason
record component. - receive(Page) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
-
Build and Iterator of results for a new page.
- receive(Page) - Method in class org.elasticsearch.compute.operator.ColumnLoadOperator
- receive(Page) - Method in class org.elasticsearch.compute.operator.RowInTableLookupOperator
- receivedPages() - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- registerException(Exception) - Method in class org.elasticsearch.compute.operator.Warnings
- registerTransportHandler(TransportService) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
- releasables() - Method in record class org.elasticsearch.compute.operator.DriverContext.Snapshot
-
Returns the value of the
releasables
record component. - releaseBlocks() - Method in class org.elasticsearch.compute.data.Page
-
Release all blocks in this page, decrementing any breakers accounting for these blocks.
- releaseFetchedOnAnyThread(Fetched) - Method in class org.elasticsearch.compute.operator.AsyncOperator
- releaseOnAnyThread() - Method in class org.elasticsearch.compute.operator.lookup.RightChunkedLeftJoin
-
Release this on any thread, rather than just the thread that built it.
- releasePageOnAnyThread(Page) - Static method in class org.elasticsearch.compute.operator.AsyncOperator
- remaining() - Method in class org.elasticsearch.compute.operator.Limiter
-
Returns the remaining number of hits that can be collected.
- RemoteSink - Interface in org.elasticsearch.compute.operator.exchange
- removeAsyncAction() - Method in class org.elasticsearch.compute.operator.DriverContext
- removeExchangeSourceHandler(String) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
- removeReleasable(Releasable) - Method in class org.elasticsearch.compute.operator.DriverContext
-
Removes a releasable from this context.
- replaceMissing(ValuesSource, Object, DocValueFormat, LongSupplier) - Method in class org.elasticsearch.compute.lucene.UnsupportedValueSourceType
- ResponseHeadersCollector - Class in org.elasticsearch.compute.operator
-
A helper class that can be used to collect and merge response headers from multiple child requests.
- ResponseHeadersCollector(ThreadContext) - Constructor for class org.elasticsearch.compute.operator.ResponseHeadersCollector
- ResultBuilderForNull - Class in org.elasticsearch.compute.operator.topn
- ResultBuilderForNull(BlockFactory) - Constructor for class org.elasticsearch.compute.operator.topn.ResultBuilderForNull
- rewrite(IndexSearcher) - Method in class org.elasticsearch.compute.querydsl.query.SingleValueMatchQuery
- RightChunkedLeftJoin - Class in org.elasticsearch.compute.operator.lookup
-
Performs a
LEFT JOIN
where many "right hand" pages are joined against a "left hand"Page
. - RightChunkedLeftJoin(Page, int) - Constructor for class org.elasticsearch.compute.operator.lookup.RightChunkedLeftJoin
- RowInTableLookup - Class in org.elasticsearch.compute.aggregation.table
-
Consumes
Page
s and looks up each row in a pre-built table, and returns the offsets of each row in the table. - RowInTableLookup() - Constructor for class org.elasticsearch.compute.aggregation.table.RowInTableLookup
- RowInTableLookupOperator - Class in org.elasticsearch.compute.operator
- RowInTableLookupOperator(BlockFactory, RowInTableLookupOperator.Key[], int[]) - Constructor for class org.elasticsearch.compute.operator.RowInTableLookupOperator
- RowInTableLookupOperator.Factory - Record Class in org.elasticsearch.compute.operator
-
Factory for
RowInTableLookupOperator
. - RowInTableLookupOperator.Key - Record Class in org.elasticsearch.compute.operator
- rowsEmitted() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- rowsEmitted() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- rowsEmitted() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- rowsEmitted() - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
-
Count of rows this operator has emitted.
- rowsEmitted() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- rowsEmitted() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
-
Count of rows this operator has emitted.
- rowsEmitted() - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
-
Count of rows this operator has emitted.
- rowsEmitted() - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- rowsEmitted() - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- rowsReceived() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- rowsReceived() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- rowsReceived() - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
-
Count of rows this operator has received.
- rowsReceived() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.Status
- rowsReceived() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
-
Count of rows this operator has received.
- rowsReceived() - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
-
Count of rows this operator has received.
- rowsReceived() - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- rowsReceived() - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- RUNNING - Enum constant in enum class org.elasticsearch.compute.operator.DriverStatus.Status
- runToCompletion(List<Driver>, ActionListener<Void>) - Method in class org.elasticsearch.compute.operator.DriverRunner
-
Run all drivers to completion asynchronously.
S
- sawNull() - Method in record class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe.HashResult
-
Returns the value of the
sawNull
record component. - score(Page) - Method in class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator
- score(Page) - Method in interface org.elasticsearch.compute.operator.ScoreOperator.ExpressionScorer
-
Scores the expression.
- scoreBlockPosition() - Method in record class org.elasticsearch.compute.operator.ScoreOperator.ScoreOperatorFactory
-
Returns the value of the
scoreBlockPosition
record component. - scoreMode - Variable in class org.elasticsearch.compute.lucene.LuceneOperator.Factory
- scoreMode() - Method in class org.elasticsearch.compute.lucene.LuceneQueryEvaluator
-
Returns the score mode to use on searches
- scoreMode() - Method in class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator
- scoreMode() - Method in class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator
- ScoreOperator - Class in org.elasticsearch.compute.operator
-
Evaluates scores for a ExpressionScorer.
- ScoreOperator(BlockFactory, ScoreOperator.ExpressionScorer, int) - Constructor for class org.elasticsearch.compute.operator.ScoreOperator
- ScoreOperator.ExpressionScorer - Interface in org.elasticsearch.compute.operator
-
Evaluates the score of an expression one
Page
at a time. - ScoreOperator.ExpressionScorer.Factory - Interface in org.elasticsearch.compute.operator
-
A Factory for creating ExpressionScorers.
- ScoreOperator.ScoreOperatorFactory - Record Class in org.elasticsearch.compute.operator
- ScoreOperatorFactory(ScoreOperator.ExpressionScorer.Factory, int) - Constructor for record class org.elasticsearch.compute.operator.ScoreOperator.ScoreOperatorFactory
-
Creates an instance of a
ScoreOperatorFactory
record class. - scorerFactory() - Method in record class org.elasticsearch.compute.operator.ScoreOperator.ScoreOperatorFactory
-
Returns the value of the
scorerFactory
record component. - searcher() - Method in record class org.elasticsearch.compute.lucene.LuceneQueryEvaluator.ShardConfig
-
Returns the value of the
searcher
record component. - searcher() - Method in interface org.elasticsearch.compute.lucene.ShardContext
-
Get
IndexSearcher
holding the actual data. - searchExecutionContext - Variable in class org.elasticsearch.compute.operator.lookup.QueryList
- seenGroupIds(BigArrays) - Method in class org.elasticsearch.compute.aggregation.blockhash.BlockHash
- seenGroupIds(BigArrays) - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizeBlockHash
- seenGroupIds(BigArrays) - Method in class org.elasticsearch.compute.aggregation.blockhash.CategorizePackedValuesBlockHash
- seenGroupIds(BigArrays) - Method in class org.elasticsearch.compute.aggregation.blockhash.TimeSeriesBlockHash
- seenGroupIds(BigArrays) - Method in record class org.elasticsearch.compute.aggregation.SeenGroupIds.Empty
- seenGroupIds(BigArrays) - Method in record class org.elasticsearch.compute.aggregation.SeenGroupIds.Range
- seenGroupIds(BigArrays) - Method in interface org.elasticsearch.compute.aggregation.SeenGroupIds
-
The grouping ids that have been seen already.
- SeenGroupIds - Interface in org.elasticsearch.compute.aggregation
- SeenGroupIds.Empty - Record Class in org.elasticsearch.compute.aggregation
- SeenGroupIds.Range - Record Class in org.elasticsearch.compute.aggregation
- segment() - Method in record class org.elasticsearch.compute.data.BlockUtils.Doc
-
Returns the value of the
segment
record component. - SEGMENT - Enum constant in enum class org.elasticsearch.compute.lucene.DataPartitioning
- segments() - Method in class org.elasticsearch.compute.data.DocVector
- selectedMayContainUnseenGroups(SeenGroupIds) - Method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- selectedMayContainUnseenGroups(SeenGroupIds) - Method in class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- selectedMayContainUnseenGroups(SeenGroupIds) - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorFunction
-
Call this to signal to the aggregation that the
selected
parameter that's passed toGroupingAggregatorFunction.evaluateIntermediate(org.elasticsearch.compute.data.Block[], int, org.elasticsearch.compute.data.IntVector)
orGroupingAggregatorFunction.evaluateFinal(org.elasticsearch.compute.data.Block[], int, org.elasticsearch.compute.data.IntVector, org.elasticsearch.compute.operator.DriverContext)
may reference groups that haven't been seen. - selectedMayContainUnseenGroups(SeenGroupIds) - Method in class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- SERIALIZE_BLOCK_ARRAY - Static variable in interface org.elasticsearch.compute.data.Block
- SERIALIZE_BLOCK_BIG_ARRAY - Static variable in interface org.elasticsearch.compute.data.Block
- SERIALIZE_BLOCK_ORDINAL - Static variable in interface org.elasticsearch.compute.data.Block
- SERIALIZE_BLOCK_VALUES - Static variable in interface org.elasticsearch.compute.data.Block
-
Serialization type for blocks: 0 and 1 replace false/true used in pre-8.14
- SERIALIZE_BLOCK_VECTOR - Static variable in interface org.elasticsearch.compute.data.Block
- SERIALIZE_VECTOR_ARRAY - Static variable in interface org.elasticsearch.compute.data.Vector
- SERIALIZE_VECTOR_BIG_ARRAY - Static variable in interface org.elasticsearch.compute.data.Vector
- SERIALIZE_VECTOR_CONSTANT - Static variable in interface org.elasticsearch.compute.data.Vector
- SERIALIZE_VECTOR_ORDINAL - Static variable in interface org.elasticsearch.compute.data.Vector
- SERIALIZE_VECTOR_VALUES - Static variable in interface org.elasticsearch.compute.data.Vector
-
The serialization type of vectors: 0 and 1 replaces the boolean false/true in pre-8.14.
- sessionId() - Method in class org.elasticsearch.compute.operator.Driver
- sessionId() - Method in class org.elasticsearch.compute.operator.DriverStatus
-
The session for this driver.
- setFailed(int) - Method in class org.elasticsearch.compute.aggregation.AbstractFallibleArrayState
- setLength(int) - Method in class org.elasticsearch.compute.operator.BreakingBytesRefBuilder
-
Set the number of bytes in this buffer.
- setLimitAndOverhead(long, double) - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- shallowCopy() - Method in class org.elasticsearch.compute.data.Page
- shard() - Method in record class org.elasticsearch.compute.data.BlockUtils.Doc
-
Returns the value of the
shard
record component. - SHARD - Enum constant in enum class org.elasticsearch.compute.lucene.DataPartitioning
- SHARD_SEGMENT_DOC_MAP_PER_ROW_OVERHEAD - Static variable in class org.elasticsearch.compute.data.DocVector
-
Per position memory cost to build the shard segment doc map required to load fields out of order.
- ShardConfig(Query, IndexSearcher) - Constructor for record class org.elasticsearch.compute.lucene.LuceneQueryEvaluator.ShardConfig
-
Creates an instance of a
ShardConfig
record class. - shardConfigs() - Method in record class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator.Factory
-
Returns the value of the
shardConfigs
record component. - shardConfigs() - Method in record class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator.Factory
-
Returns the value of the
shardConfigs
record component. - shardContext() - Method in record class org.elasticsearch.compute.lucene.LuceneSlice
-
Returns the value of the
shardContext
record component. - ShardContext - Interface in org.elasticsearch.compute.lucene
-
Context of each shard we're operating against.
- ShardContext(IndexReader, Supplier<SourceLoader>) - Constructor for record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.ShardContext
-
Creates an instance of a
ShardContext
record class. - shardContexts() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Factory
-
Returns the value of the
shardContexts
record component. - shardContexts() - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Returns the value of the
shardContexts
record component. - shardIdentifier() - Method in interface org.elasticsearch.compute.lucene.ShardContext
-
A "name" for the shard that you can look up against other APIs like
_cat/shards
. - shards() - Method in class org.elasticsearch.compute.data.DocVector
- shardSegmentDocMapBackwards() - Method in class org.elasticsearch.compute.data.DocVector
-
Reverse of
DocVector.shardSegmentDocMapForwards
. - shardSegmentDocMapForwards() - Method in class org.elasticsearch.compute.data.DocVector
-
Map from the positions in this page to the positions in lucene's native order for loading doc values.
- shiftNullsToExpandedPositions() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- shiftNullsToExpandedPositions() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- shiftNullsToExpandedPositions() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- shiftNullsToExpandedPositions() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- shiftNullsToExpandedPositions() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- ShowOperator - Class in org.elasticsearch.compute.operator
- ShowOperator(BlockFactory, LocalSourceOperator.ListSupplier) - Constructor for class org.elasticsearch.compute.operator.ShowOperator
- ShowOperator.ShowOperatorFactory - Record Class in org.elasticsearch.compute.operator
- ShowOperatorFactory(List<List<Object>>) - Constructor for record class org.elasticsearch.compute.operator.ShowOperator.ShowOperatorFactory
-
Creates an instance of a
ShowOperatorFactory
record class. - SINGLE - Enum constant in enum class org.elasticsearch.compute.aggregation.AggregatorMode
-
Maps raw inputs to final outputs.
- singleSegment() - Method in class org.elasticsearch.compute.data.DocVector
- singleSegmentNonDecreasing() - Method in class org.elasticsearch.compute.data.DocVector
- SingletonOrdinalsBuilder - Class in org.elasticsearch.compute.data
- SingletonOrdinalsBuilder(BlockFactory, SortedDocValues, int) - Constructor for class org.elasticsearch.compute.data.SingletonOrdinalsBuilder
- singleValued() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- SingleValueMatchQuery - Class in org.elasticsearch.compute.querydsl.query
-
Finds all fields with a single-value.
- SingleValueMatchQuery(IndexFieldData<?>, Warnings) - Constructor for class org.elasticsearch.compute.querydsl.query.SingleValueMatchQuery
- sinkKeys() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
- SinkOperator - Class in org.elasticsearch.compute.operator
-
A sink operator - accepts input, produces no output.
- SinkOperator() - Constructor for class org.elasticsearch.compute.operator.SinkOperator
- SinkOperator.SinkOperatorFactory - Interface in org.elasticsearch.compute.operator
-
A factory for creating sink operators.
- sizeOf(int[]) - Static method in class org.elasticsearch.compute.data.BlockRamUsageEstimator
-
Returns the size in bytes of the int[] object.
- sizeOfBitSet(long) - Static method in class org.elasticsearch.compute.data.BlockRamUsageEstimator
- sizeOfBitSet(BitSet) - Static method in class org.elasticsearch.compute.data.BlockRamUsageEstimator
-
Returns the size in bytes used by the bitset.
- SizeSettings(long, long) - Constructor for record class org.elasticsearch.compute.data.LocalCircuitBreaker.SizeSettings
-
Creates an instance of a
SizeSettings
record class. - SizeSettings(Settings) - Constructor for record class org.elasticsearch.compute.data.LocalCircuitBreaker.SizeSettings
- sleep() - Method in record class org.elasticsearch.compute.operator.DriverSleeps.Sleep
-
Returns the value of the
sleep
record component. - sleep(String, long) - Method in record class org.elasticsearch.compute.operator.DriverSleeps
-
Record a sleep.
- Sleep(String, long, long) - Constructor for record class org.elasticsearch.compute.operator.DriverSleeps.Sleep
-
Creates an instance of a
Sleep
record class. - sleeps() - Method in class org.elasticsearch.compute.operator.DriverProfile
-
Records of the times the driver has slept.
- sleeps() - Method in class org.elasticsearch.compute.operator.DriverStatus
-
Records of the times the driver has slept.
- sliceIndex() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- sliceMax() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- sliceMin() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- sliceQueue - Variable in class org.elasticsearch.compute.lucene.LuceneOperator.Factory
- Snapshot(Set<Releasable>) - Constructor for record class org.elasticsearch.compute.operator.DriverContext.Snapshot
-
Creates an instance of a
Snapshot
record class. - SortableTopNEncoder - Class in org.elasticsearch.compute.operator.topn
-
A
TopNEncoder
that encodes values to byte arrays that may be sorted directly. - SortableTopNEncoder() - Constructor for class org.elasticsearch.compute.operator.topn.SortableTopNEncoder
- SORTED_ASCENDING - Enum constant in enum class org.elasticsearch.compute.data.Block.MvOrdering
- SortOrder(int, boolean, boolean) - Constructor for record class org.elasticsearch.compute.operator.topn.TopNOperator.SortOrder
-
Creates an instance of a
SortOrder
record class. - sortOrders() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
-
Returns the value of the
sortOrders
record component. - sortToBlock(BlockFactory, boolean) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBoolean
-
Sort values from each position and write the results to a
Block
. - sortToBlock(BlockFactory, boolean) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBytesRef
-
Sort values from each position and write the results to a
Block
. - sortToBlock(BlockFactory, boolean) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeDouble
-
Sort values from each position and write the results to a
Block
. - sortToBlock(BlockFactory, boolean) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeInt
-
Sort values from each position and write the results to a
Block
. - sortToBlock(BlockFactory, boolean) - Method in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeLong
-
Sort values from each position and write the results to a
Block
. - SourceOperator - Class in org.elasticsearch.compute.operator
-
A source operator - produces output, accepts no input.
- SourceOperator() - Constructor for class org.elasticsearch.compute.operator.SourceOperator
- SourceOperator.SourceOperatorFactory - Interface in org.elasticsearch.compute.operator
-
A factory for creating source operators.
- sourcesFinished() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeRequest
-
True if the
ExchangeSourceHandler
has enough input. - SpatialAggregationUtils - Class in org.elasticsearch.compute.aggregation.spatial
- start(ThreadContext, Executor, Driver, int, ActionListener<Void>) - Static method in class org.elasticsearch.compute.operator.Driver
- start(Driver, ActionListener<Void>) - Method in class org.elasticsearch.compute.operator.DriverRunner
-
Start a driver.
- started() - Method in class org.elasticsearch.compute.operator.DriverStatus
-
When this
Driver
was started. - STARTING - Enum constant in enum class org.elasticsearch.compute.operator.DriverStatus.Status
- startMillis() - Method in class org.elasticsearch.compute.operator.DriverProfile
-
Millis since epoch when the driver started.
- startPosition() - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
Implementations of
BatchEncoder.MVEncoder.readNextBatch()
should call this before any values at the current position. - status() - Method in class org.elasticsearch.compute.lucene.LuceneOperator
- status() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- status() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- status() - Method in class org.elasticsearch.compute.operator.AggregationOperator
- status() - Method in class org.elasticsearch.compute.operator.AsyncOperator
- status() - Method in class org.elasticsearch.compute.operator.Driver
-
Get the last status update from the driver.
- status() - Method in class org.elasticsearch.compute.operator.DriverStatus.OperatorStatus
- status() - Method in class org.elasticsearch.compute.operator.DriverStatus
-
The state of the overall driver - queue, starting, running, finished.
- status() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator
- status() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator
- status() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator
- status() - Method in class org.elasticsearch.compute.operator.LimitOperator
- status() - Method in class org.elasticsearch.compute.operator.MvExpandOperator
- status() - Method in interface org.elasticsearch.compute.operator.Operator
-
The status of the operator.
- status() - Method in class org.elasticsearch.compute.operator.topn.TopNOperator
- status(long, int, int, long, long) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- status(long, int, long, long) - Method in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator
- status(long, int, long, long) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- status(long, long, long) - Method in class org.elasticsearch.compute.operator.AsyncOperator
- Status(int, int, int, long, long) - Constructor for class org.elasticsearch.compute.operator.LimitOperator.Status
- Status(long, int, int, long, long) - Constructor for class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- Status(long, int, long, long) - Constructor for class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- Status(long, long, int, long, long) - Constructor for class org.elasticsearch.compute.operator.AggregationOperator.Status
-
Build.
- Status(long, long, int, long, long) - Constructor for class org.elasticsearch.compute.operator.HashAggregationOperator.Status
-
Build.
- Status(long, long, long) - Constructor for class org.elasticsearch.compute.operator.AsyncOperator.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.compute.operator.AggregationOperator.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.compute.operator.AsyncOperator.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.compute.operator.HashAggregationOperator.Status
- Status(StreamInput) - Constructor for class org.elasticsearch.compute.operator.LimitOperator.Status
- StdDevDoubleAggregator - Class in org.elasticsearch.compute.aggregation
-
A standard deviation aggregation definition for double.
- StdDevDoubleAggregator() - Constructor for class org.elasticsearch.compute.aggregation.StdDevDoubleAggregator
- StdDevFloatAggregator - Class in org.elasticsearch.compute.aggregation
-
A standard deviation aggregation definition for float.
- StdDevFloatAggregator() - Constructor for class org.elasticsearch.compute.aggregation.StdDevFloatAggregator
- StdDevIntAggregator - Class in org.elasticsearch.compute.aggregation
-
A standard deviation aggregation definition for int.
- StdDevIntAggregator() - Constructor for class org.elasticsearch.compute.aggregation.StdDevIntAggregator
- StdDevLongAggregator - Class in org.elasticsearch.compute.aggregation
-
A standard deviation aggregation definition for long.
- StdDevLongAggregator() - Constructor for class org.elasticsearch.compute.aggregation.StdDevLongAggregator
- StdDevStates - Class in org.elasticsearch.compute.aggregation
- stopMillis() - Method in class org.elasticsearch.compute.operator.DriverProfile
-
Millis since epoch when the driver stopped.
- StringExtractOperator - Class in org.elasticsearch.compute.operator
- StringExtractOperator(String[], EvalOperator.ExpressionEvaluator, Function<String, Map<String, String>>, DriverContext) - Constructor for class org.elasticsearch.compute.operator.StringExtractOperator
- StringExtractOperator.StringExtractOperatorFactory - Record Class in org.elasticsearch.compute.operator
- StringExtractOperatorFactory(String[], EvalOperator.ExpressionEvaluator.Factory, Supplier<Function<String, Map<String, String>>>) - Constructor for record class org.elasticsearch.compute.operator.StringExtractOperator.StringExtractOperatorFactory
-
Creates an instance of a
StringExtractOperatorFactory
record class. - sum() - Method in record class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.AggregateMetricDoubleLiteral
-
Returns the value of the
sum
record component. - sum() - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- SUM - Enum constant in enum class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.Metric
- supplier - Variable in class org.elasticsearch.compute.operator.LocalSourceOperator
- supplier() - Static method in class org.elasticsearch.compute.aggregation.CountAggregatorFunction
- supplier() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.SupplierWithChannels
-
Returns the value of the
supplier
record component. - SupplierWithChannels(AggregatorFunctionSupplier, List<Integer>) - Constructor for record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.SupplierWithChannels
-
Creates an instance of a
SupplierWithChannels
record class.
T
- takePage() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
-
Take the ownership of the page responded by
RemoteSink
. - TARGET_PAGE_SIZE - Static variable in interface org.elasticsearch.compute.operator.Operator
-
Target number of bytes in a page.
- taskConcurrency - Variable in class org.elasticsearch.compute.lucene.LuceneOperator.Factory
- taskConcurrency() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Factory
- timeBucketChannel() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
-
Returns the value of the
timeBucketChannel
record component. - timeBucketChannel() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
-
Returns the value of the
timeBucketChannel
record component. - TimeSeriesAggregationOperatorFactories - Class in org.elasticsearch.compute.operator
-
This class provides operator factories for time-series aggregations.
- TimeSeriesAggregationOperatorFactories() - Constructor for class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories
- TimeSeriesAggregationOperatorFactories.Final - Record Class in org.elasticsearch.compute.operator
- TimeSeriesAggregationOperatorFactories.Initial - Record Class in org.elasticsearch.compute.operator
- TimeSeriesAggregationOperatorFactories.Intermediate - Record Class in org.elasticsearch.compute.operator
- TimeSeriesAggregationOperatorFactories.SupplierWithChannels - Record Class in org.elasticsearch.compute.operator
- TimeSeriesBlockHash - Class in org.elasticsearch.compute.aggregation.blockhash
- TimeSeriesBlockHash(int, int, DriverContext) - Constructor for class org.elasticsearch.compute.aggregation.blockhash.TimeSeriesBlockHash
- TimeSeriesSortedSourceOperatorFactory - Class in org.elasticsearch.compute.lucene
-
Creates a source operator that takes advantage of the natural sorting of segments in a tsdb index.
- to() - Method in record class org.elasticsearch.compute.aggregation.SeenGroupIds.Range
-
Returns the value of the
to
record component. - toBlock(BlockFactory, IntVector) - Method in class org.elasticsearch.compute.data.sort.BooleanBucketedSort
-
Creates a block with the values from the
selected
groups. - toBlock(BlockFactory, IntVector) - Method in class org.elasticsearch.compute.data.sort.BytesRefBucketedSort
-
Creates a block with the values from the
selected
groups. - toBlock(BlockFactory, IntVector) - Method in class org.elasticsearch.compute.data.sort.DoubleBucketedSort
-
Creates a block with the values from the
selected
groups. - toBlock(BlockFactory, IntVector) - Method in class org.elasticsearch.compute.data.sort.FloatBucketedSort
-
Creates a block with the values from the
selected
groups. - toBlock(BlockFactory, IntVector) - Method in class org.elasticsearch.compute.data.sort.IntBucketedSort
-
Creates a block with the values from the
selected
groups. - toBlock(BlockFactory, IntVector) - Method in class org.elasticsearch.compute.data.sort.IpBucketedSort
-
Creates a block with the values from the
selected
groups. - toBlock(BlockFactory, IntVector) - Method in class org.elasticsearch.compute.data.sort.LongBucketedSort
-
Creates a block with the values from the
selected
groups. - toIntermediate(Block[], int, IntVector, DriverContext) - Method in class org.elasticsearch.compute.aggregation.BytesRefArrayState
-
Extracts an intermediate view of the contents of this state.
- toIntermediate(Block[], int, IntVector, DriverContext) - Method in interface org.elasticsearch.compute.aggregation.GroupingAggregatorState
-
Extracts an intermediate view of the contents of this state.
- toIntermediate(Block[], int, IntVector, DriverContext) - Method in class org.elasticsearch.compute.aggregation.IpArrayState
-
Extracts an intermediate view of the contents of this state.
- toIntermediate(Block[], int, IntVector, DriverContext) - Method in class org.elasticsearch.compute.aggregation.RateDoubleAggregator.DoubleRateGroupingState
- toIntermediate(Block[], int, IntVector, DriverContext) - Method in class org.elasticsearch.compute.aggregation.RateFloatAggregator.FloatRateGroupingState
- toIntermediate(Block[], int, IntVector, DriverContext) - Method in class org.elasticsearch.compute.aggregation.RateIntAggregator.IntRateGroupingState
- toIntermediate(Block[], int, IntVector, DriverContext) - Method in class org.elasticsearch.compute.aggregation.RateLongAggregator.LongRateGroupingState
- toIntermediate(Block[], int, DriverContext) - Method in interface org.elasticsearch.compute.aggregation.AggregatorState
-
Extracts an intermediate view of the contents of this state.
- toJavaObject(Block, int) - Static method in class org.elasticsearch.compute.data.BlockUtils
-
Read all values from a positions into a java object.
- toMask() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- toMask() - Method in interface org.elasticsearch.compute.data.BooleanBlock
-
Convert this to a
"mask"
that's appropriate for passing toBooleanBlock.keepMask(org.elasticsearch.compute.data.BooleanVector)
. - toMask() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- ToMask - Record Class in org.elasticsearch.compute.data
-
Result from calling
BooleanBlock.toMask()
. - ToMask(BooleanVector, boolean) - Constructor for record class org.elasticsearch.compute.data.ToMask
-
Creates an instance of a
ToMask
record class. - tookNanos() - Method in class org.elasticsearch.compute.operator.DriverProfile
-
Nanos between creation and completion of the
Driver
. - ToPartialAggregatorFunction - Class in org.elasticsearch.compute.aggregation
- ToPartialAggregatorFunction(AggregatorFunction, List<Integer>) - Constructor for class org.elasticsearch.compute.aggregation.ToPartialAggregatorFunction
- ToPartialGroupingAggregatorFunction - Class in org.elasticsearch.compute.aggregation
-
An internal aggregate function that always emits intermediate (or partial) output regardless of the aggregate mode.
- ToPartialGroupingAggregatorFunction(GroupingAggregatorFunction, List<Integer>) - Constructor for class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- topCount() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
-
Returns the value of the
topCount
record component. - TopNEncoder - Interface in org.elasticsearch.compute.operator.topn
-
Encodes values for
TopNOperator
. - TopNOperator - Class in org.elasticsearch.compute.operator.topn
-
An operator that sorts "rows" of values by encoding the values to sort on, as bytes (using BytesRef).
- TopNOperator(BlockFactory, CircuitBreaker, int, List<ElementType>, List<TopNEncoder>, List<TopNOperator.SortOrder>, int) - Constructor for class org.elasticsearch.compute.operator.topn.TopNOperator
- TopNOperator.SortOrder - Record Class in org.elasticsearch.compute.operator.topn
- TopNOperator.TopNOperatorFactory - Record Class in org.elasticsearch.compute.operator.topn
- TopNOperatorFactory(int, List<ElementType>, List<TopNEncoder>, List<TopNOperator.SortOrder>, int) - Constructor for record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
-
Creates an instance of a
TopNOperatorFactory
record class. - TopNOperatorStatus - Class in org.elasticsearch.compute.operator.topn
- TopNOperatorStatus(int, long, int, int, long, long) - Constructor for class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- toSortable() - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
-
Get a version of this encoder that encodes values such that sorting the encoded bytes sorts by the values.
- toString() - Method in class org.elasticsearch.compute.aggregation.Aggregator
- toString() - Method in record class org.elasticsearch.compute.aggregation.blockhash.BlockHash.GroupSpec
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.aggregation.blockhash.TimeSeriesBlockHash
- toString() - Method in class org.elasticsearch.compute.aggregation.CountAggregatorFunction
- toString() - Method in class org.elasticsearch.compute.aggregation.CountGroupingAggregatorFunction
- toString() - Method in record class org.elasticsearch.compute.aggregation.FilteredAggregatorFunctionSupplier
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.aggregation.FromPartialAggregatorFunction
- toString() - Method in class org.elasticsearch.compute.aggregation.FromPartialGroupingAggregatorFunction
- toString() - Method in class org.elasticsearch.compute.aggregation.GroupingAggregator
- toString() - Method in record class org.elasticsearch.compute.aggregation.IntermediateStateDesc
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.aggregation.SeenGroupIds.Empty
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.aggregation.SeenGroupIds.Range
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.aggregation.table.AscendingSequenceRowInTableLookup
- toString() - Method in class org.elasticsearch.compute.aggregation.table.EmptyRowInTableLookup
- toString() - Method in class org.elasticsearch.compute.aggregation.table.RowInTableLookup
- toString() - Method in class org.elasticsearch.compute.aggregation.ToPartialAggregatorFunction
- toString() - Method in class org.elasticsearch.compute.aggregation.ToPartialGroupingAggregatorFunction
- toString() - Method in record class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.AggregateMetricDoubleLiteral
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.data.BlockUtils.BuilderWrapper
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.data.BlockUtils.Doc
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- toString() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- toString() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- toString() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- toString() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- toString() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- toString() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- toString() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- toString() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- toString() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- toString() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- toString() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- toString() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- toString() - Method in record class org.elasticsearch.compute.data.LocalCircuitBreaker.SizeSettings
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.data.LocalCircuitBreaker
- toString() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- toString() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- toString() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- toString() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- toString() - Method in class org.elasticsearch.compute.data.Page
- toString() - Method in record class org.elasticsearch.compute.data.ToMask
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- toString() - Method in class org.elasticsearch.compute.lucene.LuceneOperator
- toString() - Method in record class org.elasticsearch.compute.lucene.LuceneQueryEvaluator.ShardConfig
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.lucene.LuceneQueryExpressionEvaluator.Factory
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.lucene.LuceneQueryScoreEvaluator.Factory
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.lucene.LuceneSlice
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.lucene.PartialLeafReaderContext
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Factory
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.FieldInfo
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.ShardContext
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Status
- toString() - Method in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator
- toString() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- toString() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator
- toString() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- toString() - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator
- toString() - Method in record class org.elasticsearch.compute.operator.AggregationOperator.AggregationOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
- toString() - Method in class org.elasticsearch.compute.operator.AggregationOperator
- toString() - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- toString() - Method in record class org.elasticsearch.compute.operator.ColumnExtractOperator.Factory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.ColumnExtractOperator
- toString() - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Factory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.ColumnLoadOperator
- toString() - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Values
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.Driver
- toString() - Method in record class org.elasticsearch.compute.operator.DriverContext.Snapshot
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.DriverProfile
- toString() - Method in record class org.elasticsearch.compute.operator.DriverSleeps.Sleep
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.operator.DriverSleeps
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.DriverStatus.OperatorStatus
- toString() - Method in class org.elasticsearch.compute.operator.DriverStatus
- toString() - Method in record class org.elasticsearch.compute.operator.EvalOperator.EvalOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.EvalOperator
- toString() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeService
- toString() - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.ExchangeSinkOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.Status
- toString() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator
- toString() - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.ExchangeSourceOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- toString() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator
- toString() - Method in record class org.elasticsearch.compute.operator.FilterOperator.FilterOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.FilterOperator
- toString() - Method in record class org.elasticsearch.compute.operator.HashAggregationOperator.HashAggregationOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
- toString() - Method in class org.elasticsearch.compute.operator.HashAggregationOperator
- toString() - Method in record class org.elasticsearch.compute.operator.IsBlockedResult
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
- toString() - Method in class org.elasticsearch.compute.operator.LimitOperator
- toString() - Method in record class org.elasticsearch.compute.operator.LocalSourceOperator.LocalSourceFactory
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupe.HashResult
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.operator.MvExpandOperator.Factory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- toString() - Method in class org.elasticsearch.compute.operator.MvExpandOperator
- toString() - Method in record class org.elasticsearch.compute.operator.OrdinalsGroupingOperator.OrdinalsGroupingOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.OrdinalsGroupingOperator
- toString() - Method in record class org.elasticsearch.compute.operator.OutputOperator.OutputOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.OutputOperator
- toString() - Method in class org.elasticsearch.compute.operator.PageConsumerOperator
- toString() - Method in record class org.elasticsearch.compute.operator.ProjectOperator.ProjectOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.ProjectOperator
- toString() - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Factory
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.operator.RowInTableLookupOperator.Key
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.RowInTableLookupOperator
- toString() - Method in record class org.elasticsearch.compute.operator.ScoreOperator.ScoreOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.ScoreOperator
- toString() - Method in record class org.elasticsearch.compute.operator.ShowOperator.ShowOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.operator.StringExtractOperator.StringExtractOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.StringExtractOperator
- toString() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Final
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.SupplierWithChannels
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.topn.ResultBuilderForNull
- toString() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.SortOrder
-
Returns a string representation of this record class.
- toString() - Method in record class org.elasticsearch.compute.operator.topn.TopNOperator.TopNOperatorFactory
-
Returns a string representation of this record class.
- toString() - Method in class org.elasticsearch.compute.operator.topn.TopNOperator
- toString(String) - Method in class org.elasticsearch.compute.querydsl.query.SingleValueMatchQuery
- totalSlices() - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- totalSlices() - Method in class org.elasticsearch.compute.lucene.LuceneSliceQueue
- totalTimeInMillis() - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- toUnsortable() - Method in interface org.elasticsearch.compute.operator.topn.TopNEncoder
-
Get a version of this encoder that encodes values as fast as possible without making the encoded bytes sortable.
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in record class org.elasticsearch.compute.operator.DriverSleeps.Sleep
- toXContent(XContentBuilder, ToXContent.Params) - Method in record class org.elasticsearch.compute.operator.DriverSleeps
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.DriverStatus.OperatorStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in enum class org.elasticsearch.compute.operator.DriverStatus.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.DriverStatus
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- toXContent(XContentBuilder, ToXContent.Params) - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
- toXContentChunked(ToXContent.Params) - Method in class org.elasticsearch.compute.operator.DriverProfile
- trackGroupId(int) - Method in class org.elasticsearch.compute.aggregation.AbstractArrayState
- trackingGroupIds() - Method in class org.elasticsearch.compute.aggregation.AbstractArrayState
- transformer() - Method in record class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.ExchangeSinkOperatorFactory
-
Returns the value of the
transformer
record component. - TRUE_ORD - Static variable in class org.elasticsearch.compute.operator.mvdedupe.MultivalueDedupeBoolean
-
Ordinal assigned to
true
. - tryAccumulateHits(int) - Method in class org.elasticsearch.compute.operator.Limiter
-
Tries to accumulate hits and returns the number of hits that has been accepted.
- tryIncRef() - Method in class org.elasticsearch.compute.data.BooleanBigArrayBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.BooleanBigArrayVector
- tryIncRef() - Method in class org.elasticsearch.compute.data.BooleanVectorBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.BytesRefVectorBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.CompositeBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.ConstantNullVector
- tryIncRef() - Method in class org.elasticsearch.compute.data.DocBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.DocVector
- tryIncRef() - Method in class org.elasticsearch.compute.data.DoubleBigArrayBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.DoubleBigArrayVector
- tryIncRef() - Method in class org.elasticsearch.compute.data.DoubleVectorBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.FloatBigArrayBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.FloatBigArrayVector
- tryIncRef() - Method in class org.elasticsearch.compute.data.FloatVectorBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.IntBigArrayBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.IntBigArrayVector
- tryIncRef() - Method in class org.elasticsearch.compute.data.IntVectorBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.LongBigArrayBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.LongBigArrayVector
- tryIncRef() - Method in class org.elasticsearch.compute.data.LongVectorBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefBlock
- tryIncRef() - Method in class org.elasticsearch.compute.data.OrdinalBytesRefVector
- tryIncRef() - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- tsHashChannel() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Initial
-
Returns the value of the
tsHashChannel
record component. - tsHashChannel() - Method in record class org.elasticsearch.compute.operator.TimeSeriesAggregationOperatorFactories.Intermediate
-
Returns the value of the
tsHashChannel
record component. - type() - Method in record class org.elasticsearch.compute.aggregation.IntermediateStateDesc
-
Returns the value of the
type
record component. - type() - Method in record class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.FieldInfo
-
Returns the value of the
type
record component. - typeName() - Method in class org.elasticsearch.compute.lucene.UnsupportedValueSourceType
- types() - Method in record class org.elasticsearch.compute.operator.ColumnExtractOperator.Factory
-
Returns the value of the
types
record component.
U
- UNKNOWN - Enum constant in enum class org.elasticsearch.compute.data.ElementType
-
Intermediate blocks which don't support retrieving elements.
- UNORDERED - Enum constant in enum class org.elasticsearch.compute.data.Block.MvOrdering
- UNSUPPORTED - Static variable in interface org.elasticsearch.compute.operator.topn.TopNEncoder
-
Placeholder encoder for unsupported data types.
- UnsupportedValueSourceType - Class in org.elasticsearch.compute.lucene
- UnsupportedValueSourceType(String) - Constructor for class org.elasticsearch.compute.lucene.UnsupportedValueSourceType
- unwrapAndCollect(Exception) - Method in class org.elasticsearch.compute.operator.FailureCollector
- updatePosition() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- UTF8 - Static variable in interface org.elasticsearch.compute.operator.topn.TopNEncoder
-
An encoder for UTF-8 text.
V
- valueCount - Variable in class org.elasticsearch.compute.data.AbstractBlockBuilder
- valueCount - Variable in class org.elasticsearch.compute.data.AbstractVectorBuilder
- valueCount(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.DirectEncoder
- valueCount(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder.MVEncoder
-
The number of values at the position with this offset in the batch.
- valueCount(int) - Method in class org.elasticsearch.compute.operator.mvdedupe.BatchEncoder
-
The number of values at the position with this offset in the batch.
- valueOf(String) - Static method in enum class org.elasticsearch.compute.aggregation.AggregatorMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.compute.aggregation.spatial.PointType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.Metric
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.compute.data.Block.MvOrdering
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.compute.data.ElementType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.compute.lucene.DataPartitioning
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.compute.operator.DriverContext.WarningsMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.elasticsearch.compute.operator.DriverStatus.Status
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class org.elasticsearch.compute.aggregation.AggregatorMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.compute.aggregation.spatial.PointType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder.Metric
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.compute.data.Block.MvOrdering
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.compute.data.ElementType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.compute.lucene.DataPartitioning
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.compute.lucene.LuceneMaxFactory.NumberType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.compute.lucene.LuceneMinFactory.NumberType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in record class org.elasticsearch.compute.operator.ColumnLoadOperator.Factory
-
Returns the value of the
values
record component. - values() - Static method in enum class org.elasticsearch.compute.operator.DriverContext.WarningsMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.elasticsearch.compute.operator.DriverStatus.Status
-
Returns an array containing the constants of this enum class, in the order they are declared.
- Values(String, Block) - Constructor for record class org.elasticsearch.compute.operator.ColumnLoadOperator.Values
-
Creates an instance of a
Values
record class. - valuesLength() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
-
The length of the internal values array.
- valuesLength() - Method in class org.elasticsearch.compute.data.AbstractVectorBuilder
-
The length of the internal values array.
- valuesLength() - Method in class org.elasticsearch.compute.data.AggregateMetricDoubleBlockBuilder
- ValuesSourceReaderOperator - Class in org.elasticsearch.compute.lucene
-
Operator that extracts doc_values from a Lucene index out of pages that have been produced by
LuceneSourceOperator
and outputs them to a new column. - ValuesSourceReaderOperator(BlockFactory, List<ValuesSourceReaderOperator.FieldInfo>, List<ValuesSourceReaderOperator.ShardContext>, int) - Constructor for class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator
-
Creates a new extractor
- ValuesSourceReaderOperator.Factory - Record Class in org.elasticsearch.compute.lucene
-
Creates a factory for
ValuesSourceReaderOperator
. - ValuesSourceReaderOperator.FieldInfo - Record Class in org.elasticsearch.compute.lucene
-
Configuration for a field to load.
- ValuesSourceReaderOperator.ShardContext - Record Class in org.elasticsearch.compute.lucene
- ValuesSourceReaderOperator.Status - Class in org.elasticsearch.compute.lucene
- Vector - Interface in org.elasticsearch.compute.data
-
A dense Vector of single values.
- Vector.Builder - Interface in org.elasticsearch.compute.data
-
Builds
Vector
s. - VERSION - Static variable in interface org.elasticsearch.compute.operator.topn.TopNEncoder
-
An encoder for semver versions.
- visit(QueryVisitor) - Method in class org.elasticsearch.compute.querydsl.query.SingleValueMatchQuery
W
- waitForAsyncActions(ActionListener<Void>) - Method in class org.elasticsearch.compute.operator.DriverContext
- waitForReading() - Method in interface org.elasticsearch.compute.operator.exchange.ExchangeSource
-
Allows callers to stop reading from the source when it's blocked
- waitForWriting() - Method in interface org.elasticsearch.compute.operator.exchange.ExchangeSink
-
Whether the sink is blocked on adding more pages
- WAITING - Enum constant in enum class org.elasticsearch.compute.operator.DriverStatus.Status
- wake() - Method in record class org.elasticsearch.compute.operator.DriverSleeps.Sleep
-
Returns the value of the
wake
record component. - wake(long) - Method in record class org.elasticsearch.compute.operator.DriverSleeps
-
Record a wake.
- Warnings - Class in org.elasticsearch.compute.operator
-
Utilities to collect warnings for running an executor.
- warningsMode() - Method in class org.elasticsearch.compute.operator.DriverContext
-
Evaluators should use this function to decide their warning behavior.
- weight() - Method in record class org.elasticsearch.compute.lucene.LuceneSlice
-
Returns the value of the
weight
record component. - WelfordAlgorithm - Class in org.elasticsearch.compute.aggregation
-
Algorithm for calculating standard deviation, one value at a time.
- WelfordAlgorithm() - Constructor for class org.elasticsearch.compute.aggregation.WelfordAlgorithm
- WelfordAlgorithm(double, double, long) - Constructor for class org.elasticsearch.compute.aggregation.WelfordAlgorithm
- wrapPage(Page) - Method in class org.elasticsearch.compute.operator.HashAggregationOperator
- wrapperFor(BlockFactory, ElementType, int) - Static method in class org.elasticsearch.compute.data.BlockUtils
- writeNullValue() - Method in class org.elasticsearch.compute.data.AbstractBlockBuilder
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.BooleanBlock
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.BooleanVector
-
Serializes this Vector to the given stream output.
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.BytesRefBlock
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.BytesRefVector
-
Serializes this Vector to the given stream output.
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.data.CompositeBlock
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.data.ConstantNullVector
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.data.DocBlock
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.DoubleBlock
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.DoubleVector
-
Serializes this Vector to the given stream output.
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.FloatBlock
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.FloatVector
-
Serializes this Vector to the given stream output.
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.IntBlock
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.IntVector
-
Serializes this Vector to the given stream output.
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.LongBlock
- writeTo(StreamOutput) - Method in interface org.elasticsearch.compute.data.LongVector
-
Serializes this Vector to the given stream output.
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.data.Page
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.lucene.LuceneOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.lucene.ValuesSourceReaderOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.AbstractPageMappingToIteratorOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.AggregationOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.AsyncOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.DriverProfile
- writeTo(StreamOutput) - Method in record class org.elasticsearch.compute.operator.DriverSleeps.Sleep
- writeTo(StreamOutput) - Method in record class org.elasticsearch.compute.operator.DriverSleeps
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.DriverStatus.OperatorStatus
- writeTo(StreamOutput) - Method in enum class org.elasticsearch.compute.operator.DriverStatus.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.DriverStatus
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeRequest
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeResponse
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSinkOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.exchange.ExchangeSourceOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.HashAggregationOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.LimitOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.MvExpandOperator.Status
- writeTo(StreamOutput) - Method in class org.elasticsearch.compute.operator.topn.TopNOperatorStatus
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form