Package Hierarchies:
- org.elasticsearch.xpack.esql,
- org.elasticsearch.xpack.esql.action,
- org.elasticsearch.xpack.esql.analysis,
- org.elasticsearch.xpack.esql.capabilities,
- org.elasticsearch.xpack.esql.common,
- org.elasticsearch.xpack.esql.common.spatial,
- org.elasticsearch.xpack.esql.core.async,
- org.elasticsearch.xpack.esql.core.capabilities,
- org.elasticsearch.xpack.esql.core.expression,
- org.elasticsearch.xpack.esql.core.expression.function,
- org.elasticsearch.xpack.esql.core.expression.function.scalar,
- org.elasticsearch.xpack.esql.core.expression.predicate,
- org.elasticsearch.xpack.esql.core.expression.predicate.operator.arithmetic,
- org.elasticsearch.xpack.esql.core.expression.predicate.operator.comparison,
- org.elasticsearch.xpack.esql.core.expression.predicate.operator.math,
- org.elasticsearch.xpack.esql.core.expression.predicate.regex,
- org.elasticsearch.xpack.esql.core.plugin,
- org.elasticsearch.xpack.esql.core.querydsl.query,
- org.elasticsearch.xpack.esql.core.tree,
- org.elasticsearch.xpack.esql.core.type,
- org.elasticsearch.xpack.esql.core.util,
- org.elasticsearch.xpack.esql.enrich,
- org.elasticsearch.xpack.esql.evaluator,
- org.elasticsearch.xpack.esql.evaluator.command,
- org.elasticsearch.xpack.esql.evaluator.mapper,
- org.elasticsearch.xpack.esql.execution,
- org.elasticsearch.xpack.esql.expression,
- org.elasticsearch.xpack.esql.expression.function,
- org.elasticsearch.xpack.esql.expression.function.aggregate,
- org.elasticsearch.xpack.esql.expression.function.blockloader,
- org.elasticsearch.xpack.esql.expression.function.fulltext,
- org.elasticsearch.xpack.esql.expression.function.grouping,
- org.elasticsearch.xpack.esql.expression.function.inference,
- org.elasticsearch.xpack.esql.expression.function.scalar,
- org.elasticsearch.xpack.esql.expression.function.scalar.conditional,
- org.elasticsearch.xpack.esql.expression.function.scalar.convert,
- org.elasticsearch.xpack.esql.expression.function.scalar.date,
- org.elasticsearch.xpack.esql.expression.function.scalar.histogram,
- org.elasticsearch.xpack.esql.expression.function.scalar.internal,
- org.elasticsearch.xpack.esql.expression.function.scalar.ip,
- org.elasticsearch.xpack.esql.expression.function.scalar.math,
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue,
- org.elasticsearch.xpack.esql.expression.function.scalar.nulls,
- org.elasticsearch.xpack.esql.expression.function.scalar.score,
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial,
- org.elasticsearch.xpack.esql.expression.function.scalar.string,
- org.elasticsearch.xpack.esql.expression.function.scalar.string.regex,
- org.elasticsearch.xpack.esql.expression.function.scalar.util,
- org.elasticsearch.xpack.esql.expression.function.vector,
- org.elasticsearch.xpack.esql.expression.predicate,
- org.elasticsearch.xpack.esql.expression.predicate.fulltext,
- org.elasticsearch.xpack.esql.expression.predicate.logical,
- org.elasticsearch.xpack.esql.expression.predicate.nulls,
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic,
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison,
- org.elasticsearch.xpack.esql.expression.promql.function,
- org.elasticsearch.xpack.esql.expression.promql.subquery,
- org.elasticsearch.xpack.esql.formatter,
- org.elasticsearch.xpack.esql.index,
- org.elasticsearch.xpack.esql.inference,
- org.elasticsearch.xpack.esql.inference.bulk,
- org.elasticsearch.xpack.esql.inference.completion,
- org.elasticsearch.xpack.esql.inference.rerank,
- org.elasticsearch.xpack.esql.inference.textembedding,
- org.elasticsearch.xpack.esql.io.stream,
- org.elasticsearch.xpack.esql.optimizer,
- org.elasticsearch.xpack.esql.optimizer.rules,
- org.elasticsearch.xpack.esql.optimizer.rules.logical,
- org.elasticsearch.xpack.esql.optimizer.rules.logical.local,
- org.elasticsearch.xpack.esql.optimizer.rules.logical.preoptimizer,
- org.elasticsearch.xpack.esql.optimizer.rules.logical.promql,
- org.elasticsearch.xpack.esql.optimizer.rules.physical,
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local,
- org.elasticsearch.xpack.esql.parser,
- org.elasticsearch.xpack.esql.parser.promql,
- org.elasticsearch.xpack.esql.plan,
- org.elasticsearch.xpack.esql.plan.logical,
- org.elasticsearch.xpack.esql.plan.logical.fuse,
- org.elasticsearch.xpack.esql.plan.logical.inference,
- org.elasticsearch.xpack.esql.plan.logical.join,
- org.elasticsearch.xpack.esql.plan.logical.local,
- org.elasticsearch.xpack.esql.plan.logical.promql,
- org.elasticsearch.xpack.esql.plan.logical.promql.operator,
- org.elasticsearch.xpack.esql.plan.logical.promql.operator.arithmetic,
- org.elasticsearch.xpack.esql.plan.logical.promql.operator.comparison,
- org.elasticsearch.xpack.esql.plan.logical.promql.operator.set,
- org.elasticsearch.xpack.esql.plan.logical.promql.selector,
- org.elasticsearch.xpack.esql.plan.logical.show,
- org.elasticsearch.xpack.esql.plan.physical,
- org.elasticsearch.xpack.esql.plan.physical.inference,
- org.elasticsearch.xpack.esql.planner,
- org.elasticsearch.xpack.esql.planner.mapper,
- org.elasticsearch.xpack.esql.planner.premapper,
- org.elasticsearch.xpack.esql.plugin,
- org.elasticsearch.xpack.esql.querydsl.query,
- org.elasticsearch.xpack.esql.querylog,
- org.elasticsearch.xpack.esql.rule,
- org.elasticsearch.xpack.esql.score,
- org.elasticsearch.xpack.esql.session,
- org.elasticsearch.xpack.esql.stats,
- org.elasticsearch.xpack.esql.telemetry,
- org.elasticsearch.xpack.esql.type,
- org.elasticsearch.xpack.esql.view
Class Hierarchy
- java.lang.Object
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.AbstractConvertFunction.AbstractEvaluator (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- org.elasticsearch.xpack.esql.enrich.AbstractLookupService<R,T>
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.AbstractMultivalueFunction.AbstractNullableEvaluator (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- org.antlr.v4.runtime.tree.AbstractParseTreeVisitor<T> (implements org.antlr.v4.runtime.tree.ParseTreeVisitor<T>)
- org.elasticsearch.xpack.esql.planner.AbstractPhysicalOperationProviders
- org.elasticsearch.index.query.AbstractQueryBuilder<QB> (implements org.elasticsearch.index.query.QueryBuilder)
- org.elasticsearch.xpack.esql.core.expression.predicate.regex.AbstractStringPattern (implements org.elasticsearch.xpack.esql.core.expression.predicate.regex.StringPattern)
- org.elasticsearch.xpack.esql.core.expression.predicate.regex.RLikePattern (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.core.expression.predicate.regex.RLikePatternList (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.core.expression.predicate.regex.WildcardPattern (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.core.expression.predicate.regex.WildcardPatternList (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.action.ActionType<Response>
- org.elasticsearch.xpack.esql.planner.AggregateMapper
- org.elasticsearch.xpack.esql.expression.function.aggregate.AggregateWritables
- org.elasticsearch.xpack.esql.analysis.AnalyzerContext
- org.elasticsearch.xpack.esql.analysis.AnalyzerRules
- org.elasticsearch.xpack.esql.core.expression.predicate.operator.arithmetic.Arithmetics
- org.elasticsearch.compute.operator.AsyncOperator<Fetched> (implements org.elasticsearch.compute.operator.Operator)
- org.elasticsearch.compute.operator.AsyncOperator.Status (implements org.elasticsearch.compute.operator.Operator.Status)
- org.elasticsearch.xpack.esql.core.async.AsyncTaskManagementService<Request,Response,T>
- org.elasticsearch.xpack.esql.core.expression.AttributeMap<E> (implements java.util.Map<K,V>)
- org.elasticsearch.xpack.esql.core.expression.AttributeMap.Builder<E>
- org.elasticsearch.xpack.esql.core.expression.AttributeSet (implements java.util.Set<E>)
- org.elasticsearch.xpack.esql.core.expression.AttributeSet.Builder
- org.elasticsearch.xpack.esql.expression.function.scalar.string.AutomataMatch
- org.elasticsearch.xpack.esql.optimizer.rules.logical.promql.AutomatonUtils
- org.elasticsearch.xpack.esql.optimizer.rules.logical.promql.AutomatonUtils.PatternFragment
- org.elasticsearch.rest.BaseRestHandler (implements org.elasticsearch.rest.RestHandler)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.BinarySpatialFunction.BinarySpatialComparator<T>
- org.elasticsearch.xpack.esql.expression.function.BlockLoaderWarnings (implements org.elasticsearch.index.mapper.blockloader.Warnings)
- org.elasticsearch.xpack.esql.inference.bulk.BulkInferenceExecutionState
- org.elasticsearch.xpack.esql.inference.bulk.BulkInferenceRunner
- org.elasticsearch.xpack.esql.parser.CaseChangingCharStream (implements org.antlr.v4.runtime.CharStream)
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Cast
- org.elasticsearch.xpack.esql.core.util.Check
- org.elasticsearch.xpack.esql.expression.function.scalar.util.ChunkUtils
- org.elasticsearch.xpack.esql.core.util.CollectionUtils
- org.elasticsearch.xpack.esql.action.ColumnInfoImpl (implements org.elasticsearch.xpack.core.esql.action.ColumnInfo)
- org.elasticsearch.xpack.esql.core.expression.predicate.operator.comparison.Comparisons
- org.elasticsearch.xpack.esql.plugin.ComputeService
- org.elasticsearch.xpack.esql.session.Configuration (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.plan.logical.local.CopyingLocalSupplier (implements org.elasticsearch.xpack.esql.plan.logical.local.LocalSupplier)
- org.elasticsearch.xpack.esql.core.type.DataType.DataTypesTransportVersions
- org.elasticsearch.xpack.esql.core.type.DataTypeConverter
- org.elasticsearch.xpack.esql.core.util.DateUtils
- org.elasticsearch.xpack.esql.plan.logical.local.EmptyLocalSupplier (implements org.elasticsearch.xpack.esql.plan.logical.local.LocalSupplier)
- org.elasticsearch.xpack.esql.enrich.EnrichLookupService.Request
- org.elasticsearch.xpack.esql.enrich.EnrichPolicyResolver
- org.elasticsearch.xpack.esql.analysis.EnrichResolution
- org.elasticsearch.xpack.esql.core.type.EsField (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.core.type.EsField.Exact
- org.elasticsearch.xpack.esql.planner.EsPhysicalOperationProviders.ShardContext (implements org.elasticsearch.core.Releasable, org.elasticsearch.compute.lucene.ShardContext)
- org.elasticsearch.xpack.esql.parser.EsqlBaseParserBaseListener (implements org.elasticsearch.xpack.esql.parser.EsqlBaseParserListener)
- org.elasticsearch.xpack.esql.action.EsqlCapabilities
- org.elasticsearch.xpack.esql.session.EsqlCCSUtils
- org.elasticsearch.xpack.esql.parser.EsqlConfig
- org.elasticsearch.xpack.esql.type.EsqlDataTypeConverter
- org.elasticsearch.xpack.esql.type.EsqlDataTypeRegistry
- org.elasticsearch.xpack.esql.action.EsqlExecutionInfo (implements org.elasticsearch.common.xcontent.ChunkedToXContentObject, org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.action.EsqlExecutionInfo.Cluster (implements org.elasticsearch.xcontent.ToXContentFragment, org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.action.EsqlExecutionInfo.Cluster.Builder
- org.elasticsearch.xpack.esql.plugin.EsqlFeatures (implements org.elasticsearch.features.FeatureSpecification)
- org.elasticsearch.xpack.esql.plugin.EsqlFlags
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.ArgSignature
- org.elasticsearch.xpack.esql.session.EsqlLicenseChecker
- org.elasticsearch.xpack.esql.plugin.EsqlMediaTypeParser
- org.elasticsearch.xpack.esql.parser.EsqlParser
- org.elasticsearch.xpack.esql.querylog.EsqlQueryLog
- org.elasticsearch.xpack.esql.action.EsqlResponseImpl (implements org.elasticsearch.xpack.core.esql.action.EsqlResponse)
- org.elasticsearch.xpack.esql.session.EsqlSession
- org.elasticsearch.xpack.esql.expression.EsqlTypeResolutions
- org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize.State
- org.elasticsearch.xpack.esql.evaluator.EvalMapper
- org.elasticsearch.xpack.esql.plan.logical.promql.selector.Evaluation
- org.elasticsearch.xpack.esql.ExceptionUtils
- org.elasticsearch.xpack.esql.core.expression.Expression.TypeResolution
- org.elasticsearch.xpack.esql.core.expression.ExpressionCoreWritables
- org.elasticsearch.xpack.esql.evaluator.mapper.ExpressionMapper<E>
- org.elasticsearch.xpack.esql.enrich.ExpressionQueryList (implements org.elasticsearch.compute.operator.lookup.LookupEnrichQueryGenerator)
- org.elasticsearch.xpack.esql.core.expression.Expressions
- org.elasticsearch.xpack.esql.core.expression.ExpressionSet<E> (implements java.util.Set<E>)
- org.elasticsearch.xpack.esql.expression.ExpressionWritables
- org.elasticsearch.xpack.esql.common.Failure
- org.elasticsearch.xpack.esql.common.Failures
- org.elasticsearch.xpack.esql.session.FieldNameUtils
- org.elasticsearch.xpack.esql.expression.Foldables
- org.elasticsearch.xpack.esql.expression.Foldables.TypeResolutionValidator
- org.elasticsearch.xpack.esql.core.expression.FoldContext
- org.elasticsearch.xpack.esql.optimizer.rules.logical.preoptimizer.FoldInferenceFunctions (implements org.elasticsearch.xpack.esql.optimizer.rules.logical.preoptimizer.LogicalPlanPreOptimizerRule)
- org.elasticsearch.xpack.esql.expression.function.fulltext.FullTextWritables
- org.elasticsearch.xpack.esql.expression.function.FunctionDefinition
- org.elasticsearch.xpack.esql.expression.function.Functions
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.GeoHexBoundedPredicate
- org.elasticsearch.xpack.esql.evaluator.command.GrokEvaluatorExtracter (implements org.elasticsearch.compute.operator.ColumnExtractOperator.Evaluator, org.elasticsearch.grok.GrokCaptureExtracter)
- org.elasticsearch.xpack.esql.expression.function.grouping.GroupingWritables
- org.elasticsearch.xpack.esql.common.spatial.H3SphericalUtil
- org.elasticsearch.xpack.esql.plan.logical.local.ImmediateLocalSupplier (implements org.elasticsearch.xpack.esql.plan.logical.local.LocalSupplier)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.InBooleanEvaluator (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.InBytesRefEvaluator (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- org.elasticsearch.xpack.esql.plan.IndexPattern
- org.elasticsearch.xpack.esql.index.IndexResolution
- org.elasticsearch.xpack.esql.session.IndexResolver
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.InDoubleEvaluator (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- org.elasticsearch.xpack.esql.inference.InferenceFunctionEvaluator
- org.elasticsearch.xpack.esql.inference.InferenceFunctionEvaluator.Factory
- org.elasticsearch.xpack.esql.inference.InferenceResolution
- org.elasticsearch.xpack.esql.inference.InferenceResolution.Builder
- org.elasticsearch.xpack.esql.inference.InferenceResolver
- org.elasticsearch.xpack.esql.inference.InferenceResolver.Factory
- org.elasticsearch.xpack.esql.inference.InferenceService
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.InIntEvaluator (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.InLongEvaluator (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.InMillisNanosEvaluator (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.InNanosMillisEvaluator (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- java.io.InputStream (implements java.io.Closeable)
- org.elasticsearch.xpack.esql.inference.InputTextReader (implements org.elasticsearch.core.Releasable)
- org.elasticsearch.xpack.esql.plan.logical.join.JoinTypes
- org.elasticsearch.xpack.esql.plan.logical.promql.selector.LabelMatcher
- org.elasticsearch.xpack.esql.plan.logical.promql.selector.LabelMatchers
- org.elasticsearch.xpack.esql.planner.Layout.Builder
- org.elasticsearch.xpack.esql.planner.LocalExecutionPlanner
- org.elasticsearch.xpack.esql.planner.LocalExecutionPlanner.LocalExecutionPlan (implements org.elasticsearch.compute.Describable)
- org.elasticsearch.xpack.esql.planner.LocalExecutionPlanner.PhysicalOperation (implements org.elasticsearch.compute.Describable)
- org.elasticsearch.xpack.esql.planner.mapper.LocalMapper
- org.elasticsearch.xpack.esql.core.tree.Location
- org.elasticsearch.xpack.esql.optimizer.LogicalOptimizerContext
- org.elasticsearch.xpack.esql.optimizer.LogicalPlanPreOptimizer
- org.elasticsearch.xpack.esql.enrich.LookupFromIndexService.Request
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.LuceneComponent2DUtils
- org.elasticsearch.xpack.esql.planner.mapper.Mapper
- org.elasticsearch.xpack.esql.planner.mapper.MapperUtils
- org.elasticsearch.xpack.esql.enrich.MatchConfig (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.core.expression.predicate.operator.math.Maths
- org.elasticsearch.xpack.esql.telemetry.Metrics
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvFunctionWritables
- org.elasticsearch.xpack.esql.expression.NamedExpressions
- org.elasticsearch.xpack.esql.core.expression.NameId (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.core.tree.Node<T> (implements org.elasticsearch.common.io.stream.NamedWriteable)
- org.elasticsearch.xpack.esql.core.expression.Expression (implements org.elasticsearch.xpack.esql.core.capabilities.Resolvable)
- org.elasticsearch.xpack.esql.core.expression.EntryExpression
- org.elasticsearch.xpack.esql.expression.function.aggregate.FilteredExpression
- org.elasticsearch.xpack.esql.expression.predicate.fulltext.FullTextPredicate
- org.elasticsearch.xpack.esql.core.expression.function.Function
- org.elasticsearch.xpack.esql.expression.function.aggregate.AggregateFunction (implements org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Absent (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.aggregate.AllFirst (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.AllLast (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Avg (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Count (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.expression.SurrogateExpression, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.CountDistinct (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.SurrogateExpression, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.DimensionValues (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.First (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.FirstDocId (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.HistogramMerge (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Last (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Max (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.expression.SurrogateExpression, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Median (implements org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Min (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.expression.SurrogateExpression, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.NumericAggregate (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Present (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Sample (implements org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.SpatialAggregateFunction (implements org.elasticsearch.xpack.esql.LicenseAware)
- org.elasticsearch.xpack.esql.expression.function.aggregate.SpatialCentroid (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.SpatialExtent (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.StdDev (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.TimeSeriesAggregateFunction (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.aggregate.AbsentOverTime (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport)
- org.elasticsearch.xpack.esql.expression.function.aggregate.AvgOverTime (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.aggregate.CountDistinctOverTime (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.aggregate.CountOverTime (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Delta (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.function.TimestampAware, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Deriv (implements org.elasticsearch.xpack.esql.expression.function.TimestampAware, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.FirstOverTime (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.function.TimestampAware, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.HistogramMergeOverTime (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Idelta (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.function.TimestampAware, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Increase (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.function.TimestampAware, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Irate (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.function.TimestampAware, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.LastOverTime (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.function.TimestampAware, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.MaxOverTime (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.aggregate.MinOverTime (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.aggregate.PercentileOverTime
- org.elasticsearch.xpack.esql.expression.function.aggregate.PresentOverTime (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Rate (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.function.TimestampAware, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.StddevOverTime
- org.elasticsearch.xpack.esql.expression.function.aggregate.SumOverTime (implements org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport, org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.aggregate.VarianceOverTime
- org.elasticsearch.xpack.esql.expression.function.aggregate.Top (implements org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware, org.elasticsearch.xpack.esql.expression.SurrogateExpression, org.elasticsearch.xpack.esql.planner.ToAggregator, org.elasticsearch.xpack.esql.expression.function.TwoOptionalArguments)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Values (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Variance (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.WeightedAvg (implements org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.fulltext.FullTextFunction (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.score.ExpressionScoreMapper, org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware, org.elasticsearch.xpack.esql.capabilities.PostOptimizationPlanVerificationAware, org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware, org.elasticsearch.xpack.esql.capabilities.RewriteableAware, org.elasticsearch.xpack.esql.capabilities.TranslationAware)
- org.elasticsearch.xpack.esql.expression.function.grouping.GroupingFunction (implements org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware)
- org.elasticsearch.xpack.esql.expression.function.inference.InferenceFunction<PlanType>
- org.elasticsearch.xpack.esql.core.expression.function.scalar.ScalarFunction
- org.elasticsearch.xpack.esql.core.expression.function.scalar.BinaryScalarFunction
- org.elasticsearch.xpack.esql.core.expression.predicate.BinaryPredicate<T,U,R,F>
- org.elasticsearch.xpack.esql.core.expression.predicate.BinaryOperator<T,U,R,F>
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.ArithmeticOperation
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.EsqlArithmeticOperation (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.DateTimeArithmeticOperation
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.Add (implements org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.BinaryComparisonInversible)
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.Sub (implements org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.BinaryComparisonInversible)
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.Div (implements org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.BinaryComparisonInversible)
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.Mod
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.Mul (implements org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.BinaryComparisonInversible)
- org.elasticsearch.xpack.esql.core.expression.predicate.operator.comparison.BinaryComparison
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.EsqlBinaryComparison (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.Equals (implements org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.GreaterThan (implements org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.GreaterThanOrEqual (implements org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.LessThan (implements org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.LessThanOrEqual (implements org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.NotEquals (implements org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>)
- org.elasticsearch.xpack.esql.expression.predicate.logical.BinaryLogic (implements org.elasticsearch.xpack.esql.score.ExpressionScoreMapper, org.elasticsearch.xpack.esql.capabilities.TranslationAware)
- org.elasticsearch.xpack.esql.expression.predicate.logical.And (implements org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>)
- org.elasticsearch.xpack.esql.expression.predicate.logical.Or (implements org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.BinarySpatialFunction
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.InsensitiveBinaryComparison (implements org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.InsensitiveEquals
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvConcat (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvContains (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvIntersection (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Split (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.vector.VectorSimilarityFunction (implements org.elasticsearch.xpack.esql.expression.function.blockloader.BlockLoaderExpression, org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.expression.function.vector.VectorFunction)
- org.elasticsearch.xpack.esql.expression.function.vector.CosineSimilarity
- org.elasticsearch.xpack.esql.expression.function.vector.DotProduct
- org.elasticsearch.xpack.esql.expression.function.vector.Hamming
- org.elasticsearch.xpack.esql.expression.function.vector.L1Norm
- org.elasticsearch.xpack.esql.expression.function.vector.L2Norm
- org.elasticsearch.xpack.esql.expression.function.scalar.math.DoubleConstantFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.math.E
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Pi
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Tau
- org.elasticsearch.xpack.esql.expression.function.scalar.EsqlScalarFunction (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Atan2
- org.elasticsearch.xpack.esql.expression.function.scalar.conditional.Case
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Chunk (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.ip.CIDRMatch (implements org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- org.elasticsearch.xpack.esql.expression.function.scalar.Clamp (implements org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.scalar.conditional.ClampMax
- org.elasticsearch.xpack.esql.expression.function.scalar.conditional.ClampMin
- org.elasticsearch.xpack.esql.expression.function.scalar.nulls.Coalesce (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Concat
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Contains (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.math.CopySign
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateParse (implements org.elasticsearch.xpack.esql.expression.function.TwoOptionalArguments)
- org.elasticsearch.xpack.esql.expression.function.scalar.score.Decay (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware)
- org.elasticsearch.xpack.esql.expression.function.scalar.string.EndsWith (implements org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- org.elasticsearch.xpack.esql.expression.function.scalar.EsqlConfigurationFunction (implements org.elasticsearch.xpack.esql.expression.function.ConfigurationFunction)
- org.elasticsearch.xpack.esql.expression.function.scalar.string.ChangeCase
- org.elasticsearch.xpack.esql.expression.function.scalar.string.ToLower
- org.elasticsearch.xpack.esql.expression.function.scalar.string.ToUpper
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateDiff
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateExtract
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateFormat (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateTrunc
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DayName
- org.elasticsearch.xpack.esql.expression.function.scalar.date.MonthName
- org.elasticsearch.xpack.esql.expression.function.scalar.date.Now
- org.elasticsearch.xpack.esql.expression.function.scalar.date.TRange (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware, org.elasticsearch.xpack.esql.expression.SurrogateExpression, org.elasticsearch.xpack.esql.expression.function.TimestampAware)
- org.elasticsearch.xpack.esql.expression.function.scalar.histogram.ExtractHistogramComponent
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.FromAggregateMetricDouble (implements org.elasticsearch.xpack.esql.expression.function.blockloader.BlockLoaderExpression, org.elasticsearch.xpack.esql.expression.function.scalar.convert.ConvertFunction)
- org.elasticsearch.xpack.esql.expression.function.scalar.conditional.Greatest (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Hash
- org.elasticsearch.xpack.esql.expression.function.scalar.histogram.HistogramPercentile
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Hypot
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.In (implements org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- org.elasticsearch.xpack.esql.expression.function.scalar.ip.IpPrefix (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.conditional.Least (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Left
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Locate (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Log (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvAppend (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvPercentile
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvPSeriesWeightedSum (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvSlice (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvSort (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware)
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvZip (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.ip.NetworkDirection
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Pow
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Repeat (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Replace
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Right
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Round (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.math.RoundTo
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Scalb
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialDocValuesFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialGridFunction (implements org.elasticsearch.xpack.esql.LicenseAware, org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StGeohash (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StGeohex (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StGeotile (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialUnaryDocValuesFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StEnvelope
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StX
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StXMax
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StXMin
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StY
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StYMax
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StYMin
- org.elasticsearch.xpack.esql.expression.function.scalar.string.StartsWith (implements org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Substring (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToIntegerBase
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToIntegerSurrogate (implements org.elasticsearch.xpack.esql.expression.function.scalar.convert.ConvertFunction, org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToIp (implements org.elasticsearch.xpack.esql.expression.function.scalar.convert.ConvertFunction, org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToLongBase
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToLongSurrogate (implements org.elasticsearch.xpack.esql.expression.function.scalar.convert.ConvertFunction, org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.scalar.string.TopSnippets (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.UnaryScalarFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Abs
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.AbstractConvertFunction (implements org.elasticsearch.xpack.esql.expression.function.scalar.convert.ConvertFunction)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.FoldablesConvertFunction (implements org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToDatePeriod
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToTimeDuration
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToAggregateMetricDouble
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToBoolean
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToCartesianPoint
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToCartesianShape
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToDateNanos
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToDatetime
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToDegrees (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToDenseVector
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToDouble
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToGeohash
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToGeohex
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToGeoPoint
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToGeoShape
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToGeotile
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToInteger
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToIpLeadingZerosDecimal
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToIpLeadingZerosOctal
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToIpLeadingZerosRejected
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToLong
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToRadians (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToString (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToTDigest
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToUnsignedLong
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToVersion
- org.elasticsearch.xpack.esql.expression.function.scalar.string.AbstractHashFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Md5
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Sha1
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Sha256
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.AbstractMultivalueFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvAvg
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvCount
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvDedupe
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvFirst
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvLast
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvMax (implements org.elasticsearch.xpack.esql.expression.function.blockloader.BlockLoaderExpression)
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvMedian
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvMedianAbsoluteDeviation
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvMin (implements org.elasticsearch.xpack.esql.expression.function.blockloader.BlockLoaderExpression)
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvSum
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Acos
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Asin
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Atan
- org.elasticsearch.xpack.esql.expression.function.scalar.string.BitLength
- org.elasticsearch.xpack.esql.expression.function.scalar.string.ByteLength
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Cbrt
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Ceil
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Cos
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Cosh
- org.elasticsearch.xpack.esql.expression.function.scalar.util.Delay
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Exp
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Floor
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.FromBase64
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Length (implements org.elasticsearch.xpack.esql.expression.function.blockloader.BlockLoaderExpression)
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Log10
- org.elasticsearch.xpack.esql.expression.function.scalar.string.LTrim
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.Neg
- org.elasticsearch.xpack.esql.expression.function.scalar.internal.PackDimension
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Reverse
- org.elasticsearch.xpack.esql.expression.function.scalar.string.RTrim
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Signum
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Sin
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Sinh
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Space
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Sqrt
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Tan
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Tanh
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToBase64
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Trim
- org.elasticsearch.xpack.esql.expression.function.scalar.internal.UnpackDimension
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.UrlDecode
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.UrlEncode
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.UrlEncodeComponent
- org.elasticsearch.xpack.esql.expression.predicate.Range (implements org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- org.elasticsearch.xpack.esql.core.expression.function.scalar.UnaryScalarFunction
- org.elasticsearch.xpack.esql.expression.predicate.nulls.IsNotNull (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>, org.elasticsearch.xpack.esql.capabilities.TranslationAware)
- org.elasticsearch.xpack.esql.expression.predicate.nulls.IsNull (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>, org.elasticsearch.xpack.esql.capabilities.TranslationAware)
- org.elasticsearch.xpack.esql.expression.function.vector.Magnitude (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.expression.function.vector.VectorFunction)
- org.elasticsearch.xpack.esql.core.expression.predicate.operator.arithmetic.Neg
- org.elasticsearch.xpack.esql.expression.predicate.logical.Not (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>, org.elasticsearch.xpack.esql.capabilities.TranslationAware)
- org.elasticsearch.xpack.esql.core.expression.predicate.regex.RegexMatch<T>
- org.elasticsearch.xpack.esql.expression.function.scalar.string.regex.RLike
- org.elasticsearch.xpack.esql.expression.function.scalar.string.regex.RLikeList
- org.elasticsearch.xpack.esql.expression.function.scalar.string.regex.WildcardLike
- org.elasticsearch.xpack.esql.expression.function.scalar.string.regex.WildcardLikeList
- org.elasticsearch.xpack.esql.expression.function.fulltext.Score (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.UnresolvedFunction (implements org.elasticsearch.xpack.esql.core.capabilities.Unresolvable)
- org.elasticsearch.xpack.esql.core.expression.LeafExpression
- org.elasticsearch.xpack.esql.core.expression.Literal (implements org.apache.lucene.util.Accountable)
- org.elasticsearch.xpack.esql.core.expression.MapExpression
- org.elasticsearch.xpack.esql.core.expression.NamedExpression (implements org.elasticsearch.common.io.stream.NamedWriteable)
- org.elasticsearch.xpack.esql.expression.Order
- org.elasticsearch.xpack.esql.core.expression.UnaryExpression
- org.elasticsearch.xpack.esql.plan.QueryPlan<PlanType>
- org.elasticsearch.xpack.esql.plan.logical.LogicalPlan (implements org.elasticsearch.xpack.esql.core.capabilities.Resolvable)
- org.elasticsearch.xpack.esql.plan.logical.BinaryPlan
- org.elasticsearch.xpack.esql.plan.logical.Fork (implements org.elasticsearch.xpack.esql.plan.logical.ExecutesOn.Coordinator, org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.LeafPlan
- org.elasticsearch.xpack.esql.plan.logical.UnaryPlan
- org.elasticsearch.xpack.esql.plan.logical.Aggregate (implements org.elasticsearch.xpack.esql.plan.logical.ExecutesOn.Coordinator, org.elasticsearch.xpack.esql.plan.logical.PipelineBreaker, org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.ChangePoint (implements org.elasticsearch.xpack.esql.plan.logical.ExecutesOn.Coordinator, org.elasticsearch.xpack.esql.LicenseAware, org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SortPreserving, org.elasticsearch.xpack.esql.plan.logical.SurrogateLogicalPlan)
- org.elasticsearch.xpack.esql.plan.logical.Drop (implements org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.Streaming, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Enrich (implements org.elasticsearch.xpack.esql.plan.logical.ExecutesOn, org.elasticsearch.xpack.esql.plan.GeneratingPlan<PlanType>, org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware.CoordinatorOnly, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.SortPreserving, org.elasticsearch.xpack.esql.plan.logical.Streaming, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Eval (implements org.elasticsearch.xpack.esql.plan.GeneratingPlan<PlanType>, org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.SortPreserving, org.elasticsearch.xpack.esql.plan.logical.Streaming, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Filter (implements org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.SortPreserving, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.fuse.Fuse (implements org.elasticsearch.xpack.esql.plan.logical.ExecutesOn.Coordinator, org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.fuse.FuseScoreEval (implements org.elasticsearch.xpack.esql.plan.logical.ExecutesOn.Coordinator, org.elasticsearch.xpack.esql.LicenseAware, org.elasticsearch.xpack.esql.plan.logical.PipelineBreaker, org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware)
- org.elasticsearch.xpack.esql.plan.logical.inference.InferencePlan<PlanType> (implements org.elasticsearch.xpack.esql.plan.logical.ExecutesOn.Coordinator, org.elasticsearch.xpack.esql.plan.GeneratingPlan<PlanType>, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.SortPreserving, org.elasticsearch.xpack.esql.plan.logical.Streaming, org.elasticsearch.xpack.esql.plan.logical.SurrogateLogicalPlan)
- org.elasticsearch.xpack.esql.plan.logical.InlineStats (implements org.elasticsearch.common.io.stream.NamedWriteable, org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.SortPreserving, org.elasticsearch.xpack.esql.plan.logical.SurrogateLogicalPlan, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Insist (implements org.elasticsearch.xpack.esql.plan.logical.Streaming, org.elasticsearch.xpack.esql.plan.logical.SurrogateLogicalPlan)
- org.elasticsearch.xpack.esql.plan.logical.Limit (implements org.elasticsearch.xpack.esql.plan.logical.ExecutesOn, org.elasticsearch.xpack.esql.plan.logical.PipelineBreaker, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Lookup (implements org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.SurrogateLogicalPlan, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.MvExpand (implements org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.OrderBy (implements org.elasticsearch.xpack.esql.plan.logical.PipelineBreaker, org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.capabilities.PostOptimizationPlanVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Project (implements org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.SortPreserving, org.elasticsearch.xpack.esql.plan.logical.Streaming)
- org.elasticsearch.xpack.esql.plan.logical.local.EsqlProject
- org.elasticsearch.xpack.esql.plan.logical.Keep (implements org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.Streaming, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.promql.PromqlCommand (implements org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.capabilities.TelemetryAware, org.elasticsearch.xpack.esql.expression.function.TimestampAware)
- org.elasticsearch.xpack.esql.plan.logical.promql.PromqlFunctionCall
- org.elasticsearch.xpack.esql.plan.logical.RegexExtract (implements org.elasticsearch.xpack.esql.plan.GeneratingPlan<PlanType>, org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.SortPreserving, org.elasticsearch.xpack.esql.plan.logical.Streaming)
- org.elasticsearch.xpack.esql.plan.logical.Dissect (implements org.elasticsearch.xpack.esql.plan.logical.SortPreserving, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Grok (implements org.elasticsearch.xpack.esql.plan.logical.SortPreserving, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Rename (implements org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.plan.logical.Streaming, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Sample (implements org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.promql.selector.Selector
- org.elasticsearch.xpack.esql.plan.logical.promql.selector.InstantSelector
- org.elasticsearch.xpack.esql.plan.logical.promql.selector.LiteralSelector
- org.elasticsearch.xpack.esql.plan.logical.promql.selector.RangeSelector
- org.elasticsearch.xpack.esql.expression.promql.subquery.Subquery
- org.elasticsearch.xpack.esql.plan.logical.Subquery (implements org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.TopN (implements org.elasticsearch.xpack.esql.plan.logical.ExecutesOn, org.elasticsearch.xpack.esql.plan.logical.PipelineBreaker)
- org.elasticsearch.xpack.esql.plan.physical.PhysicalPlan
- org.elasticsearch.xpack.esql.plan.physical.BinaryExec
- org.elasticsearch.xpack.esql.plan.physical.LeafExec
- org.elasticsearch.xpack.esql.plan.physical.MergeExec
- org.elasticsearch.xpack.esql.plan.physical.UnaryExec
- org.elasticsearch.xpack.esql.core.tree.NodeInfo<T>
- org.elasticsearch.xpack.esql.core.tree.NodeUtils
- org.elasticsearch.xpack.esql.optimizer.rules.logical.OptimizerRules
- org.elasticsearch.xpack.esql.expression.function.Options
- java.io.OutputStream (implements java.io.Closeable, java.io.Flushable)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ParseIp
- org.elasticsearch.xpack.esql.parser.ParserUtils
- org.elasticsearch.xpack.esql.action.ParseTables
- org.elasticsearch.xpack.esql.optimizer.PhysicalOptimizerRules
- org.elasticsearch.xpack.esql.planner.PlanConcurrencyCalculator
- org.elasticsearch.xpack.esql.optimizer.rules.PlanConsistencyChecker
- org.elasticsearch.xpack.esql.execution.PlanExecutor
- org.elasticsearch.xpack.esql.planner.PlannerSettings
- org.elasticsearch.xpack.esql.planner.PlannerUtils
- org.elasticsearch.xpack.esql.io.stream.PlanStreamInput.NameIdMapper (implements java.util.function.LongFunction<R>)
- org.elasticsearch.xpack.esql.io.stream.PlanStreamWrapperQueryBuilder (implements org.elasticsearch.index.query.QueryBuilder)
- org.elasticsearch.xpack.esql.telemetry.PlanTelemetry
- org.elasticsearch.xpack.esql.telemetry.PlanTelemetryManager
- org.elasticsearch.xpack.esql.plan.PlanWritables
- org.elasticsearch.plugins.Plugin (implements java.io.Closeable)
- org.elasticsearch.xpack.esql.action.PositionToXContent
- org.elasticsearch.xpack.esql.optimizer.PostOptimizationPhasePlanVerifier<P>
- org.elasticsearch.xpack.esql.analysis.PreAnalyzer
- org.elasticsearch.xpack.esql.expression.predicate.Predicates
- org.elasticsearch.xpack.esql.planner.premapper.PreMapper
- org.elasticsearch.xpack.esql.parser.PromqlBaseParserBaseListener (implements org.elasticsearch.xpack.esql.parser.PromqlBaseParserListener)
- org.elasticsearch.xpack.esql.action.PromqlFeatures
- org.elasticsearch.xpack.esql.parser.promql.PromqlFoldingUtils
- org.elasticsearch.xpack.esql.expression.promql.function.PromqlFunctionRegistry
- org.elasticsearch.xpack.esql.parser.PromqlParser
- org.elasticsearch.xpack.esql.parser.promql.PromqlParserUtils
- org.elasticsearch.xpack.esql.core.util.Queries
- org.elasticsearch.xpack.esql.core.querydsl.query.Query
- org.elasticsearch.xpack.esql.expression.function.fulltext.QueryBuilderResolver
- org.elasticsearch.compute.operator.lookup.QueryList (implements org.elasticsearch.compute.operator.lookup.LookupEnrichQueryGenerator)
- org.elasticsearch.xpack.esql.parser.QueryParams
- org.elasticsearch.xpack.esql.plugin.QueryPragmas (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.plan.QuerySetting
- org.elasticsearch.xpack.esql.plan.QuerySettings
- org.antlr.v4.runtime.Recognizer<Symbol,ATNInterpreter>
- org.antlr.v4.runtime.Lexer (implements org.antlr.v4.runtime.TokenSource)
- org.antlr.v4.runtime.Parser
- org.elasticsearch.xpack.esql.core.util.ReflectionUtils
- org.elasticsearch.xpack.esql.core.expression.predicate.regex.RegexOperation
- org.elasticsearch.xpack.esql.core.capabilities.Resolvables
- org.elasticsearch.xpack.esql.action.ResponseValueUtils
- org.elasticsearch.rest.action.RestActionListener<Response> (implements org.elasticsearch.action.ActionListener<Response>)
- org.elasticsearch.xpack.esql.rule.Rule<E,T>
- org.antlr.v4.runtime.RuleContext (implements org.antlr.v4.runtime.tree.RuleNode)
- org.antlr.v4.runtime.ParserRuleContext
- org.elasticsearch.xpack.esql.rule.RuleExecutor<TreeType>
- org.elasticsearch.xpack.esql.rule.RuleExecutor.Batch<TreeType>
- org.elasticsearch.xpack.esql.rule.RuleExecutor.ExecutionInfo
- org.elasticsearch.xpack.esql.rule.RuleExecutor.Limiter
- org.elasticsearch.xpack.esql.rule.RuleExecutor.Transformation
- org.elasticsearch.xpack.esql.optimizer.rules.RuleUtils
- org.elasticsearch.xpack.esql.expression.function.scalar.ScalarFunctionWritables
- org.elasticsearch.xpack.esql.score.ScoreMapper
- org.elasticsearch.xpack.esql.score.ScoreMapper.DefaultScoreMapper (implements org.elasticsearch.compute.operator.ScoreOperator.ExpressionScorer.Factory)
- org.elasticsearch.xpack.esql.stats.SearchContextStats (implements org.elasticsearch.xpack.esql.stats.SearchStats)
- org.elasticsearch.xpack.esql.stats.SearchStats.UnsupportedSearchStats (implements org.elasticsearch.xpack.esql.stats.SearchStats)
- org.elasticsearch.xpack.esql.session.SessionUtils
- org.elasticsearch.xpack.esql.core.tree.Source (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialEnvelopeResults<T>
- org.elasticsearch.xpack.esql.querydsl.query.SpatialRelatesQuery.ShapeQueryBuilder (implements org.elasticsearch.index.query.QueryBuilder)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialRelatesUtils
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StGeohash.GeoHashBoundedGrid (implements org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialGridFunction.BoundedGrid)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StGeohash.GeoHashBoundedGrid.Factory
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StGeohex.GeoHexBoundedGrid (implements org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialGridFunction.BoundedGrid)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StGeohex.GeoHexBoundedGrid.Factory
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StGeotile.GeoTileBoundedGrid (implements org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialGridFunction.BoundedGrid)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StGeotile.GeoTileBoundedGrid.Factory
- org.elasticsearch.xpack.esql.core.type.StringUtils
- org.elasticsearch.tasks.Task (implements org.elasticsearch.telemetry.tracing.Traceable)
- org.elasticsearch.xpack.esql.formatter.TextFormatter
- java.lang.Throwable (implements java.io.Serializable)
- org.elasticsearch.xpack.esql.action.TimeSpan.Builder
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToAggregateMetricDouble.DoubleFactory (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator.Factory)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToAggregateMetricDouble.IntFactory (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator.Factory)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToAggregateMetricDouble.LongFactory (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator.Factory)
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToAggregateMetricDouble.UnsignedLongFactory (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator.Factory)
- org.elasticsearch.xpack.esql.telemetry.TookMetrics
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToStringFromAggregateMetricDoubleEvaluator.Factory (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator.Factory)
- org.elasticsearch.xpack.esql.planner.TranslatorHandler
- org.elasticsearch.action.support.TransportAction<Request,Response>
- org.elasticsearch.transport.TransportMessage (implements org.elasticsearch.core.RefCounted, org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.core.expression.TypeResolutions
- org.elasticsearch.xpack.esql.expression.function.scalar.util.UrlCodecUtils
- org.elasticsearch.xpack.esql.expression.Validations
- org.elasticsearch.xpack.esql.plan.logical.promql.operator.VectorMatch
- org.elasticsearch.xpack.esql.expression.function.vector.VectorWritables
- org.elasticsearch.xpack.esql.analysis.Verifier
- org.elasticsearch.xpack.esql.view.ViewService
- org.elasticsearch.xpack.esql.inference.XContentRowEncoder (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- org.elasticsearch.xpack.esql.inference.XContentRowEncoder.Factory (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator.Factory)
Interface Hierarchy
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.AbstractConvertFunction.BuildFactory
- org.elasticsearch.xpack.esql.enrich.AbstractLookupService.LookupShardContextFactory
- org.elasticsearch.xpack.esql.expression.function.AggregateMetricDoubleNativeSupport
- org.elasticsearch.xpack.esql.core.async.AsyncTaskManagementService.AsyncOperation<Request,Response,T>
- java.lang.AutoCloseable
- java.io.Closeable
- org.elasticsearch.core.Releasable
- java.util.function.BiFunction<T,U,R>
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.BinaryComparisonInversible
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.BinaryComparisonInversible.ArithmeticOperationFactory
- org.elasticsearch.xpack.esql.expression.function.blockloader.BlockLoaderExpression
- org.elasticsearch.xpack.esql.inference.bulk.BulkInferenceRunner.Factory
- org.elasticsearch.xpack.esql.capabilities.ConfigurationAware
- org.elasticsearch.xpack.esql.expression.function.ConfigurationFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ConvertFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateDiff.DateDiffConstantFactory
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateDiff.DateDiffFactory
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateTimeField
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateTrunc.DateTruncFactoryProvider
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.EsqlArithmeticOperation.BinaryEvaluator
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.EsqlBinaryComparison.BinaryOperatorConstructor
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.BinaryBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.BinaryConfigurationAwareBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.BinaryVariadicWithOptionsBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.ConfigurationAwareBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.FunctionBuilder
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.NaryBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.QuaternaryBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.QuaternaryConfigurationAwareBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.QuinaryBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.TernaryBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.TernaryConfigurationAwareBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.UnaryConfigurationAwareBuilder<T>
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.UnaryVariadicBuilder<T>
- org.elasticsearch.xpack.esql.session.EsqlSession.PlanRunner
- org.elasticsearch.xpack.esql.plan.physical.EsQueryExec.Sort
- org.elasticsearch.xpack.esql.plan.physical.EsStatsQueryExec.Stat
- org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize
- org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper
- org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper.ToEvaluator
- org.elasticsearch.xpack.esql.plan.logical.ExecutesOn
- org.elasticsearch.xpack.esql.score.ExpressionScoreMapper
- org.elasticsearch.xpack.esql.score.ExpressionScoreMapper.ToScorer
- java.util.function.Function<T,R>
- org.elasticsearch.xpack.esql.expression.function.FunctionDefinition.Builder
- org.elasticsearch.xpack.esql.expression.function.FunctionResolutionStrategy
- org.elasticsearch.xpack.esql.plan.GeneratingPlan<PlanType>
- org.elasticsearch.xpack.esql.session.IndexResolver.OriginalIndexExtractor
- java.util.Iterator<E>
- org.elasticsearch.xpack.esql.planner.Layout
- org.elasticsearch.xpack.esql.LicenseAware
- org.elasticsearch.xpack.esql.optimizer.rules.logical.preoptimizer.LogicalPlanPreOptimizerRule
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local.LucenePushdownPredicates
- org.elasticsearch.xpack.esql.expression.function.vector.Magnitude.ScalarEvaluatorFunction
- org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>
- org.elasticsearch.xpack.esql.core.tree.NodeInfo.NodeCtor10<P1,P2,P3,P4,P5,P6,P7,P8,P9,P10,T>
- org.elasticsearch.xpack.esql.core.tree.NodeInfo.NodeCtor2<P1,P2,T>
- org.elasticsearch.xpack.esql.core.tree.NodeInfo.NodeCtor3<P1,P2,P3,T>
- org.elasticsearch.xpack.esql.core.tree.NodeInfo.NodeCtor4<P1,P2,P3,P4,T>
- org.elasticsearch.xpack.esql.core.tree.NodeInfo.NodeCtor5<P1,P2,P3,P4,P5,T>
- org.elasticsearch.xpack.esql.core.tree.NodeInfo.NodeCtor6<P1,P2,P3,P4,P5,P6,T>
- org.elasticsearch.xpack.esql.core.tree.NodeInfo.NodeCtor7<P1,P2,P3,P4,P5,P6,P7,T>
- org.elasticsearch.xpack.esql.core.tree.NodeInfo.NodeCtor8<P1,P2,P3,P4,P5,P6,P7,P8,T>
- org.elasticsearch.xpack.esql.core.tree.NodeInfo.NodeCtor9<P1,P2,P3,P4,P5,P6,P7,P8,P9,T>
- org.elasticsearch.xpack.esql.optimizer.rules.logical.OptimizerRules.LocalAware<SubPlan>
- org.elasticsearch.xpack.esql.expression.function.OptionalArgument
- org.antlr.v4.runtime.tree.ParseTreeListener
- org.antlr.v4.runtime.tree.ParseTreeVisitor<T>
- org.elasticsearch.xpack.esql.plan.logical.PipelineBreaker
- org.elasticsearch.xpack.esql.analysis.PlanCheckerProvider
- org.elasticsearch.xpack.esql.planner.PlannerUtils.PlanReduction
- org.elasticsearch.xpack.esql.core.util.PlanStreamInput
- org.elasticsearch.xpack.esql.core.util.PlanStreamOutput
- org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware
- org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware
- org.elasticsearch.xpack.esql.capabilities.PostOptimizationPlanVerificationAware
- org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware
- org.elasticsearch.xpack.esql.capabilities.PostPhysicalOptimizationVerificationAware
- org.elasticsearch.xpack.esql.expression.promql.function.PromqlFunctionRegistry.AcrossSeriesBinary<T>
- org.elasticsearch.xpack.esql.expression.promql.function.PromqlFunctionRegistry.AcrossSeriesUnary<T>
- org.elasticsearch.xpack.esql.expression.promql.function.PromqlFunctionRegistry.OverTimeWithinSeries<T>
- org.elasticsearch.xpack.esql.expression.promql.function.PromqlFunctionRegistry.OverTimeWithinSeriesBinary<T>
- org.elasticsearch.xpack.esql.expression.promql.function.PromqlFunctionRegistry.WithinSeries<T>
- org.elasticsearch.xpack.esql.expression.promql.function.PromqlFunctionRegistry.WithinSeriesWindow<T>
- org.elasticsearch.xpack.esql.plan.QuerySettings.QuerySettingDef.Parser<T>
- org.elasticsearch.xpack.esql.plan.QuerySettings.QuerySettingDef.Validator
- org.elasticsearch.xpack.esql.core.capabilities.Resolvable
- org.elasticsearch.xpack.esql.stats.SearchStats
- org.elasticsearch.xpack.esql.plan.logical.SortAgnostic
- org.elasticsearch.xpack.esql.plan.logical.SortPreserving
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialGridFunction.BoundedGrid
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialGridFunction.UnboundedGrid
- org.elasticsearch.xpack.esql.plan.logical.Streaming
- org.elasticsearch.xpack.esql.core.expression.predicate.regex.StringPattern
- java.util.function.Supplier<T>
- org.elasticsearch.xpack.esql.core.type.SupportedVersion
- org.elasticsearch.xpack.esql.expression.SurrogateExpression
- org.elasticsearch.xpack.esql.core.expression.function.scalar.SurrogateFunction
- org.elasticsearch.xpack.esql.plan.logical.SurrogateLogicalPlan
- org.elasticsearch.xpack.esql.capabilities.TelemetryAware
- org.elasticsearch.xpack.esql.expression.function.TimestampAware
- org.elasticsearch.xpack.esql.planner.ToAggregator
- org.elasticsearch.xpack.esql.capabilities.TranslationAware
- org.elasticsearch.xpack.esql.expression.function.TwoOptionalArguments
- org.elasticsearch.xpack.esql.plan.logical.promql.operator.VectorBinaryOperator.BinaryOp
- org.elasticsearch.xpack.esql.plan.logical.promql.operator.VectorBinaryOperator.ScalarFunctionFactory
- org.elasticsearch.xpack.esql.expression.function.vector.VectorFunction
- org.elasticsearch.common.io.stream.Writeable
Annotation Interface Hierarchy