Hierarchy For All Packages
- 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.enrich,
- org.elasticsearch.xpack.esql.evaluator,
- org.elasticsearch.xpack.esql.evaluator.command,
- org.elasticsearch.xpack.esql.evaluator.mapper,
- org.elasticsearch.xpack.esql.evaluator.predicate.operator.logical,
- 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.fulltext,
- org.elasticsearch.xpack.esql.expression.function.grouping,
- 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.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.spatial,
- org.elasticsearch.xpack.esql.expression.function.scalar.string,
- org.elasticsearch.xpack.esql.expression.function.scalar.util,
- 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.formatter,
- org.elasticsearch.xpack.esql.index,
- 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.physical,
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local,
- org.elasticsearch.xpack.esql.parser,
- org.elasticsearch.xpack.esql.plan,
- org.elasticsearch.xpack.esql.plan.logical,
- org.elasticsearch.xpack.esql.plan.logical.join,
- org.elasticsearch.xpack.esql.plan.logical.local,
- org.elasticsearch.xpack.esql.plan.logical.show,
- org.elasticsearch.xpack.esql.plan.physical,
- org.elasticsearch.xpack.esql.planner,
- org.elasticsearch.xpack.esql.planner.mapper,
- org.elasticsearch.xpack.esql.plugin,
- org.elasticsearch.xpack.esql.querydsl.query,
- 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
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.enrich.EnrichLookupService
- org.elasticsearch.xpack.esql.enrich.LookupFromIndexService
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.AbstractMultivalueFunction.AbstractNullableEvaluator (implements org.elasticsearch.compute.operator.EvalOperator.ExpressionEvaluator)
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.AbstractMultivalueFunction.AbstractEvaluator
- org.antlr.v4.runtime.tree.AbstractParseTreeVisitor<T> (implements org.antlr.v4.runtime.tree.ParseTreeVisitor<T>)
- org.elasticsearch.xpack.esql.parser.EsqlBaseParserBaseVisitor<T> (implements org.elasticsearch.xpack.esql.parser.EsqlBaseParserVisitor<T>)
- org.elasticsearch.xpack.esql.parser.ExpressionBuilder
- org.elasticsearch.xpack.esql.parser.LogicalPlanBuilder
- org.elasticsearch.xpack.esql.parser.AstBuilder
- org.elasticsearch.xpack.esql.parser.LogicalPlanBuilder
- org.elasticsearch.xpack.esql.parser.ExpressionBuilder
- org.elasticsearch.xpack.esql.parser.EsqlBaseParserBaseVisitor<T> (implements org.elasticsearch.xpack.esql.parser.EsqlBaseParserVisitor<T>)
- org.elasticsearch.xpack.esql.planner.AbstractPhysicalOperationProviders
- org.elasticsearch.xpack.esql.planner.EsPhysicalOperationProviders
- org.elasticsearch.index.query.AbstractQueryBuilder<QB> (implements org.elasticsearch.index.query.QueryBuilder)
- org.elasticsearch.xpack.esql.querydsl.query.SingleValueQuery.Builder
- org.elasticsearch.action.ActionRequestBuilder<Request,
Response> (implements org.elasticsearch.action.RequestBuilder<Request, Response>) - org.elasticsearch.xpack.core.esql.action.EsqlQueryRequestBuilder<Request,
Response> - org.elasticsearch.xpack.esql.action.EsqlQueryRequestBuilder
- org.elasticsearch.xpack.core.esql.action.EsqlQueryRequestBuilder<Request,
- org.elasticsearch.action.ActionType<Response>
- org.elasticsearch.xpack.esql.action.EsqlAsyncGetResultAction
- org.elasticsearch.xpack.esql.action.EsqlAsyncStopAction
- org.elasticsearch.xpack.esql.action.EsqlQueryAction
- org.elasticsearch.xpack.esql.plugin.EsqlStatsAction
- org.elasticsearch.xpack.esql.expression.function.aggregate.AggregateWritables
- org.elasticsearch.xpack.esql.analysis.AnalyzerRules
- org.elasticsearch.compute.operator.AsyncOperator<Fetched> (implements org.elasticsearch.compute.operator.Operator)
- org.elasticsearch.xpack.esql.enrich.EnrichLookupOperator
- org.elasticsearch.xpack.esql.enrich.LookupFromIndexOperator
- org.elasticsearch.compute.operator.AsyncOperator.Status (implements org.elasticsearch.compute.operator.Operator.Status)
- org.elasticsearch.xpack.esql.enrich.EnrichLookupOperator.Status
- org.elasticsearch.xpack.esql.enrich.LookupFromIndexOperator.Status
- org.elasticsearch.xpack.esql.expression.function.scalar.string.AutomataMatch
- org.elasticsearch.rest.BaseRestHandler (implements org.elasticsearch.rest.RestHandler)
- org.elasticsearch.xpack.esql.action.RestEsqlAsyncQueryAction
- org.elasticsearch.xpack.esql.action.RestEsqlDeleteAsyncResultAction
- org.elasticsearch.xpack.esql.action.RestEsqlGetAsyncResultAction
- org.elasticsearch.xpack.esql.action.RestEsqlQueryAction
- org.elasticsearch.xpack.esql.action.RestEsqlStopAsyncAction
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.BinarySpatialFunction.BinarySpatialComparator<T>
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialRelatesFunction.SpatialRelations
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StDistance.DistanceCalculator
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StDistance.CartesianDistanceCalculator
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StDistance.GeoDistanceCalculator
- 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.action.ColumnInfoImpl (implements org.elasticsearch.xpack.core.esql.action.ColumnInfo)
- org.elasticsearch.xpack.esql.plugin.ComputeService
- org.elasticsearch.xpack.esql.session.Configuration (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.enrich.EnrichLookupService.Request
- org.elasticsearch.xpack.esql.enrich.EnrichPolicyResolver
- org.elasticsearch.xpack.esql.analysis.EnrichResolution
- org.elasticsearch.xpack.esql.planner.EsPhysicalOperationProviders.DefaultShardContext (implements org.elasticsearch.xpack.esql.planner.EsPhysicalOperationProviders.ShardContext)
- org.elasticsearch.xpack.esql.parser.EsqlBaseParserBaseListener (implements org.elasticsearch.xpack.esql.parser.EsqlBaseParserListener)
- org.elasticsearch.xpack.esql.action.EsqlCapabilities
- 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.expression.function.EsqlFunctionRegistry
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.ArgSignature
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.MapArgSignature
- org.elasticsearch.xpack.esql.session.EsqlLicenseChecker
- org.elasticsearch.xpack.esql.plugin.EsqlMediaTypeParser
- org.elasticsearch.xpack.esql.parser.EsqlParser
- org.elasticsearch.xpack.esql.action.EsqlQueryResponse.Profile (implements org.elasticsearch.common.xcontent.ChunkedToXContentObject, org.elasticsearch.common.io.stream.Writeable)
- 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.ExceptionUtils
- org.elasticsearch.xpack.esql.evaluator.mapper.ExpressionMapper<E>
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.InsensitiveEqualsMapper
- org.elasticsearch.xpack.esql.expression.ExpressionWritables
- org.elasticsearch.xpack.esql.common.Failure
- org.elasticsearch.xpack.esql.common.Failures
- 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.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.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.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.common.io.stream.StreamInput
- org.elasticsearch.common.io.stream.FilterStreamInput
- org.elasticsearch.common.io.stream.NamedWriteableAwareStreamInput
- org.elasticsearch.xpack.esql.io.stream.PlanStreamInput (implements org.elasticsearch.xpack.esql.core.util.PlanStreamInput)
- org.elasticsearch.common.io.stream.NamedWriteableAwareStreamInput
- org.elasticsearch.common.io.stream.FilterStreamInput
- org.elasticsearch.common.io.stream.StreamInput
- org.elasticsearch.xpack.esql.plan.logical.join.JoinTypes
- org.elasticsearch.xpack.esql.plan.logical.join.JoinTypes.UsingJoinType (implements org.elasticsearch.xpack.esql.plan.logical.join.JoinType)
- 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.optimizer.LogicalOptimizerContext
- org.elasticsearch.xpack.esql.optimizer.LocalLogicalOptimizerContext
- org.elasticsearch.xpack.esql.optimizer.LogicalVerifier
- 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.telemetry.Metrics
- org.elasticsearch.xpack.esql.expression.function.scalar.multivalue.MvFunctionWritables
- org.elasticsearch.xpack.esql.expression.NamedExpressions
- 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.expression.function.aggregate.FilteredExpression
- org.elasticsearch.xpack.esql.expression.predicate.fulltext.FullTextPredicate
- org.elasticsearch.xpack.esql.expression.predicate.fulltext.MultiMatchQueryPredicate (implements org.elasticsearch.xpack.esql.capabilities.TranslationAware)
- 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.Avg (implements org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Count (implements 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.FromPartial (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Max (implements 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.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.MedianAbsoluteDeviation (implements org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Percentile (implements org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Sum (implements org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Rate (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, 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.Top (implements org.elasticsearch.xpack.esql.expression.SurrogateExpression, org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.ToPartial (implements org.elasticsearch.xpack.esql.planner.ToAggregator)
- org.elasticsearch.xpack.esql.expression.function.aggregate.Values (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.TranslationAware)
- org.elasticsearch.xpack.esql.expression.function.fulltext.Kql
- org.elasticsearch.xpack.esql.expression.function.fulltext.Match (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument, org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware)
- org.elasticsearch.xpack.esql.expression.function.fulltext.MatchOperator
- org.elasticsearch.xpack.esql.expression.function.fulltext.QueryString (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.fulltext.Term (implements org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware)
- org.elasticsearch.xpack.esql.expression.function.grouping.GroupingFunction (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware)
- org.elasticsearch.xpack.esql.expression.function.grouping.Bucket (implements org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware, org.elasticsearch.xpack.esql.expression.function.TwoOptionalArguments)
- org.elasticsearch.xpack.esql.expression.function.grouping.Categorize
- org.elasticsearch.xpack.esql.core.expression.function.scalar.ScalarFunction
- org.elasticsearch.xpack.esql.core.expression.function.scalar.BinaryScalarFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.date.BinaryDateTimeFunction
- 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.expression.predicate.operator.arithmetic.DateTimeArithmeticOperation
- org.elasticsearch.xpack.esql.expression.predicate.operator.arithmetic.EsqlArithmeticOperation (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- 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.operator.comparison.EsqlBinaryComparison (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- 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.operator.arithmetic.ArithmeticOperation
- org.elasticsearch.xpack.esql.core.expression.predicate.BinaryOperator<T,
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.BinarySpatialFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialRelatesFunction (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.capabilities.TranslationAware)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialContains
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialDisjoint
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialIntersects
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialWithin (implements org.elasticsearch.xpack.esql.expression.SurrogateExpression)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.StDistance (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.spatial.SpatialRelatesFunction (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.capabilities.TranslationAware)
- 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.string.Split (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper)
- org.elasticsearch.xpack.esql.expression.function.scalar.math.DoubleConstantFunction
- 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.ip.CIDRMatch (implements org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- 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.date.DateDiff
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateParse (implements org.elasticsearch.xpack.esql.expression.function.OptionalArgument)
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateTrunc
- 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
- org.elasticsearch.xpack.esql.expression.function.scalar.string.ChangeCase
- 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.Now
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.FromAggregateMetricDouble
- 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.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.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.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.UnaryScalarFunction
- org.elasticsearch.xpack.esql.expression.function.scalar.math.Abs
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.AbstractConvertFunction
- 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.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.ToDouble
- 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.ToInteger
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToIP
- 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.ToUnsignedLong
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.ToVersion
- org.elasticsearch.xpack.esql.expression.function.scalar.convert.FoldablesConvertFunction (implements org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware)
- org.elasticsearch.xpack.esql.expression.function.scalar.string.AbstractHashFunction
- 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
- 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
- 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
- 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.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.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.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.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.core.expression.predicate.Negatable<T>, org.elasticsearch.xpack.esql.capabilities.TranslationAware)
- org.elasticsearch.xpack.esql.expression.predicate.nulls.IsNull (implements org.elasticsearch.xpack.esql.core.expression.predicate.Negatable<T>, org.elasticsearch.xpack.esql.capabilities.TranslationAware)
- org.elasticsearch.xpack.esql.expression.predicate.logical.Not (implements 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.core.expression.predicate.regex.RLike
- org.elasticsearch.xpack.esql.expression.function.scalar.string.RLike (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- org.elasticsearch.xpack.esql.core.expression.predicate.regex.WildcardLike
- org.elasticsearch.xpack.esql.expression.function.scalar.string.WildcardLike (implements org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper, org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware)
- org.elasticsearch.xpack.esql.core.expression.predicate.regex.RLike
- org.elasticsearch.xpack.esql.core.expression.function.scalar.BinaryScalarFunction
- org.elasticsearch.xpack.esql.expression.function.UnresolvedFunction (implements org.elasticsearch.xpack.esql.core.capabilities.Unresolvable)
- org.elasticsearch.xpack.esql.expression.function.aggregate.AggregateFunction (implements org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware)
- org.elasticsearch.xpack.esql.core.expression.NamedExpression (implements org.elasticsearch.common.io.stream.NamedWriteable)
- org.elasticsearch.xpack.esql.core.expression.Attribute
- org.elasticsearch.xpack.esql.core.expression.TypedAttribute
- org.elasticsearch.xpack.esql.core.expression.FieldAttribute
- org.elasticsearch.xpack.esql.expression.function.UnsupportedAttribute (implements org.elasticsearch.xpack.esql.core.capabilities.Unresolvable)
- org.elasticsearch.xpack.esql.core.expression.FieldAttribute
- org.elasticsearch.xpack.esql.core.expression.TypedAttribute
- org.elasticsearch.xpack.esql.core.expression.UnresolvedNamedExpression (implements org.elasticsearch.xpack.esql.core.capabilities.Unresolvable)
- org.elasticsearch.xpack.esql.expression.UnresolvedNamePattern
- org.elasticsearch.xpack.esql.core.expression.Attribute
- org.elasticsearch.xpack.esql.expression.Order
- 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.join.Join (implements org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic)
- org.elasticsearch.xpack.esql.plan.logical.join.InlineJoin
- org.elasticsearch.xpack.esql.plan.logical.join.LookupJoin (implements org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SurrogateLogicalPlan, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.join.Join (implements org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic)
- org.elasticsearch.xpack.esql.plan.logical.LeafPlan
- org.elasticsearch.xpack.esql.plan.logical.EsRelation
- org.elasticsearch.xpack.esql.plan.logical.Explain (implements org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.local.LocalRelation
- org.elasticsearch.xpack.esql.plan.logical.Row (implements org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.show.ShowInfo (implements org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.join.StubRelation
- org.elasticsearch.xpack.esql.plan.logical.UnresolvedRelation (implements org.elasticsearch.xpack.esql.capabilities.TelemetryAware, org.elasticsearch.xpack.esql.core.capabilities.Unresolvable)
- org.elasticsearch.xpack.esql.plan.logical.UnaryPlan
- org.elasticsearch.xpack.esql.plan.logical.Aggregate (implements 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.Drop (implements org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Enrich (implements org.elasticsearch.xpack.esql.plan.GeneratingPlan<PlanType>, org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware, org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, 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.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.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.InlineStats (implements org.elasticsearch.common.io.stream.NamedWriteable, 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.Insist (implements org.elasticsearch.xpack.esql.plan.logical.SurrogateLogicalPlan)
- org.elasticsearch.xpack.esql.plan.logical.Limit (implements 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.capabilities.PostAnalysisVerificationAware, org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware, 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.local.EsqlProject
- org.elasticsearch.xpack.esql.plan.logical.Keep (implements org.elasticsearch.xpack.esql.plan.logical.SortAgnostic, org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- 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.Dissect (implements org.elasticsearch.xpack.esql.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.Grok (implements 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.capabilities.TelemetryAware)
- org.elasticsearch.xpack.esql.plan.logical.TopN
- org.elasticsearch.xpack.esql.plan.logical.BinaryPlan
- org.elasticsearch.xpack.esql.plan.physical.PhysicalPlan
- org.elasticsearch.xpack.esql.plan.physical.BinaryExec
- org.elasticsearch.xpack.esql.plan.physical.HashJoinExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.LookupJoinExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.LeafExec
- org.elasticsearch.xpack.esql.plan.physical.EsQueryExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.EsSourceExec
- org.elasticsearch.xpack.esql.plan.physical.EsStatsQueryExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.ExchangeSourceExec
- org.elasticsearch.xpack.esql.plan.physical.FragmentExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.LocalSourceExec
- org.elasticsearch.xpack.esql.plan.physical.ShowExec
- org.elasticsearch.xpack.esql.plan.physical.UnaryExec
- org.elasticsearch.xpack.esql.plan.physical.AggregateExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.EnrichExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.EvalExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.ExchangeExec
- org.elasticsearch.xpack.esql.plan.physical.ExchangeSinkExec
- org.elasticsearch.xpack.esql.plan.physical.FieldExtractExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.FilterExec
- org.elasticsearch.xpack.esql.plan.physical.LimitExec
- org.elasticsearch.xpack.esql.plan.physical.MvExpandExec
- org.elasticsearch.xpack.esql.plan.physical.OutputExec
- org.elasticsearch.xpack.esql.plan.physical.ProjectExec
- org.elasticsearch.xpack.esql.plan.physical.RegexExtractExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.DissectExec
- org.elasticsearch.xpack.esql.plan.physical.GrokExec
- org.elasticsearch.xpack.esql.plan.physical.SubqueryExec
- org.elasticsearch.xpack.esql.plan.physical.TopNExec (implements org.elasticsearch.xpack.esql.plan.physical.EstimatesRowSize)
- org.elasticsearch.xpack.esql.plan.physical.BinaryExec
- org.elasticsearch.xpack.esql.plan.logical.LogicalPlan (implements org.elasticsearch.xpack.esql.core.capabilities.Resolvable)
- org.elasticsearch.xpack.esql.core.expression.Expression (implements org.elasticsearch.xpack.esql.core.capabilities.Resolvable)
- org.elasticsearch.xpack.esql.evaluator.predicate.operator.logical.Not
- org.elasticsearch.xpack.esql.optimizer.rules.logical.OptimizerRules
- java.io.OutputStream (implements java.io.Closeable, java.io.Flushable)
- org.elasticsearch.common.io.stream.StreamOutput
- org.elasticsearch.xpack.esql.io.stream.PlanStreamOutput (implements org.elasticsearch.xpack.esql.core.util.PlanStreamOutput)
- org.elasticsearch.common.io.stream.StreamOutput
- org.elasticsearch.xpack.esql.parser.ParserUtils
- org.elasticsearch.xpack.esql.action.ParseTables
- org.elasticsearch.xpack.esql.optimizer.PhysicalOptimizerRules
- org.elasticsearch.xpack.esql.optimizer.PhysicalVerifier
- org.elasticsearch.xpack.esql.optimizer.rules.PlanConsistencyChecker
- org.elasticsearch.xpack.esql.execution.PlanExecutor
- org.elasticsearch.xpack.esql.planner.PlannerUtils
- 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.plugin.EsqlPlugin (implements org.elasticsearch.plugins.ActionPlugin)
- org.elasticsearch.xpack.esql.analysis.PreAnalyzer
- org.elasticsearch.xpack.esql.analysis.PreAnalyzer.PreAnalysis
- org.elasticsearch.xpack.esql.expression.predicate.Predicates
- org.elasticsearch.xpack.esql.core.querydsl.query.Query
- org.elasticsearch.xpack.esql.querydsl.query.KqlQuery
- org.elasticsearch.xpack.esql.querydsl.query.MatchQuery
- org.elasticsearch.xpack.esql.querydsl.query.MultiMatchQuery
- org.elasticsearch.xpack.esql.querydsl.query.SingleValueQuery
- org.elasticsearch.xpack.esql.querydsl.query.SpatialRelatesQuery
- org.elasticsearch.xpack.esql.querydsl.query.TranslationAwareExpressionQuery
- org.elasticsearch.xpack.esql.session.QueryBuilderResolver
- org.elasticsearch.xpack.esql.parser.QueryParams
- org.elasticsearch.xpack.esql.plugin.QueryPragmas (implements org.elasticsearch.common.io.stream.Writeable)
- org.antlr.v4.runtime.Recognizer<Symbol,
ATNInterpreter> - org.antlr.v4.runtime.Lexer (implements org.antlr.v4.runtime.TokenSource)
- org.elasticsearch.xpack.esql.parser.LexerConfig
- org.elasticsearch.xpack.esql.parser.EsqlBaseLexer
- org.elasticsearch.xpack.esql.parser.LexerConfig
- org.antlr.v4.runtime.Parser
- org.elasticsearch.xpack.esql.parser.ParserConfig
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser
- org.elasticsearch.xpack.esql.parser.ParserConfig
- org.antlr.v4.runtime.Lexer (implements org.antlr.v4.runtime.TokenSource)
- org.elasticsearch.xpack.esql.action.ResponseValueUtils
- org.elasticsearch.rest.action.RestActionListener<Response> (implements org.elasticsearch.action.ActionListener<Response>)
- org.elasticsearch.rest.action.RestChunkedToXContentListener<Response>
- org.elasticsearch.rest.action.RestRefCountedChunkedToXContentListener<Response>
- org.elasticsearch.xpack.esql.action.EsqlResponseListener
- org.elasticsearch.rest.action.RestRefCountedChunkedToXContentListener<Response>
- org.elasticsearch.rest.action.RestChunkedToXContentListener<Response>
- org.elasticsearch.xpack.esql.rule.Rule<E,
T> - org.elasticsearch.xpack.esql.analysis.AnalyzerRules.AnalyzerRule<SubPlan>
- org.elasticsearch.xpack.esql.analysis.AnalyzerRules.BaseAnalyzerRule
- org.elasticsearch.xpack.esql.optimizer.rules.logical.local.InferIsNotNull
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local.InsertFieldExtraction
- org.elasticsearch.xpack.esql.optimizer.rules.logical.OptimizerRules.OptimizerRule<SubPlan>
- org.elasticsearch.xpack.esql.optimizer.rules.logical.CombineEvals
- org.elasticsearch.xpack.esql.optimizer.rules.logical.CombineProjections
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ExtractAggregateCommonFilter
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PropagateInlineEvals
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PruneEmptyPlans
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PruneFilters
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PruneLiteralsInOrderBy
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PruneRedundantOrderBy
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PruneRedundantSortClauses
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PushDownAndCombineFilters
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PushDownAndCombineOrderBy
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PushDownEnrich
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PushDownEval
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PushDownRegexExtract
- org.elasticsearch.xpack.esql.optimizer.rules.logical.RemoveStatsOverride
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceAggregateAggExpressionWithEval
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceAggregateNestedExpressionWithEval
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceLimitAndSortAsTopN
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceLookupWithJoin
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceOrderByExpressionWithEval
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceStatsFilteredAggWithEval
- org.elasticsearch.xpack.esql.optimizer.rules.logical.local.ReplaceTopNWithLimitAndSort
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceTrivialTypeConversions
- org.elasticsearch.xpack.esql.optimizer.rules.logical.SkipQueryOnEmptyMappings
- org.elasticsearch.xpack.esql.optimizer.rules.logical.SubstituteSurrogatePlans
- org.elasticsearch.xpack.esql.optimizer.rules.logical.SubstituteSurrogates
- org.elasticsearch.xpack.esql.optimizer.rules.logical.TranslateMetricsAggregate
- org.elasticsearch.xpack.esql.rule.ParameterizedRule<E,
T, P> - org.elasticsearch.xpack.esql.analysis.AnalyzerRules.ParameterizedAnalyzerRule<SubPlan,
P> - org.elasticsearch.xpack.esql.analysis.Analyzer.ResolveRefs
- org.elasticsearch.xpack.esql.optimizer.rules.logical.OptimizerRules.OptimizerExpressionRule<E>
- org.elasticsearch.xpack.esql.optimizer.rules.logical.BooleanFunctionEqualsElimination
- org.elasticsearch.xpack.esql.optimizer.rules.logical.BooleanSimplification
- org.elasticsearch.xpack.esql.optimizer.rules.logical.CombineBinaryComparisons
- org.elasticsearch.xpack.esql.optimizer.rules.logical.CombineDisjunctions
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ConstantFolding
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ConvertStringToByteRef
- org.elasticsearch.xpack.esql.optimizer.rules.logical.FoldNull
- org.elasticsearch.xpack.esql.optimizer.rules.logical.LiteralsOnTheRight
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PartiallyFoldCase
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PropagateEquals
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PropagateNullable
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceRegexMatch
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceStringCasingWithInsensitiveEquals
- org.elasticsearch.xpack.esql.optimizer.rules.logical.SimplifyComparisonsArithmetics
- org.elasticsearch.xpack.esql.optimizer.rules.logical.SplitInWithFoldableValue
- org.elasticsearch.xpack.esql.optimizer.rules.logical.SubstituteFilteredExpression
- org.elasticsearch.xpack.esql.optimizer.rules.logical.SubstituteSpatialSurrogates
- org.elasticsearch.xpack.esql.optimizer.rules.logical.OptimizerRules.ParameterizedOptimizerRule<SubPlan,
P> - org.elasticsearch.xpack.esql.optimizer.rules.logical.local.InferNonNullAggConstraint
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PropagateEmptyRelation
- org.elasticsearch.xpack.esql.optimizer.rules.logical.local.LocalPropagateEmptyRelation
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PushDownAndCombineLimits
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceRowAsLocalRelation
- org.elasticsearch.xpack.esql.optimizer.rules.logical.SkipQueryOnLimitZero
- org.elasticsearch.xpack.esql.optimizer.PhysicalOptimizerRules.ParameterizedOptimizerRule<SubPlan,
P> - org.elasticsearch.xpack.esql.optimizer.rules.physical.local.EnableSpatialDistancePushdown
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local.PushFiltersToSource
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local.PushStatsToSource
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local.PushTopNToSource
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local.SpatialDocValuesExtraction
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local.SpatialShapeBoundsExtraction
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PropagateEvalFoldables
- org.elasticsearch.xpack.esql.optimizer.rules.logical.local.ReplaceMissingFieldWithNull
- org.elasticsearch.xpack.esql.analysis.AnalyzerRules.ParameterizedAnalyzerRule<SubPlan,
- org.elasticsearch.xpack.esql.optimizer.PhysicalOptimizerRules.OptimizerRule<SubPlan>
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local.PushLimitToSource
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local.ReplaceSourceAttributes
- org.elasticsearch.xpack.esql.optimizer.rules.physical.ProjectAwayColumns
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PropgateUnmappedFields
- org.elasticsearch.xpack.esql.optimizer.rules.logical.PruneColumns
- org.elasticsearch.xpack.esql.optimizer.rules.logical.ReplaceAliasingEvalWithProject
- org.elasticsearch.xpack.esql.optimizer.rules.logical.SetAsOptimized
- org.elasticsearch.xpack.esql.analysis.AnalyzerRules.AnalyzerRule<SubPlan>
- org.antlr.v4.runtime.RuleContext (implements org.antlr.v4.runtime.tree.RuleNode)
- org.antlr.v4.runtime.ParserRuleContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.AggFieldContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.AggFieldsContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.BooleanExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.BooleanDefaultContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.IsNullContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.LogicalBinaryContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.LogicalInContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.LogicalNotContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.MatchExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.RegexExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.BooleanValueContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ClusterStringContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.CommandOptionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.CommandOptionsContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ComparisonOperatorContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ConstantContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.BooleanArrayLiteralContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.BooleanLiteralContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.DecimalLiteralContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.InputParameterContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.IntegerLiteralContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.NullLiteralContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.NumericArrayLiteralContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.QualifiedIntegerLiteralContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.StringArrayLiteralContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.StringLiteralContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.DataTypeContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ToDataTypeContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.DecimalValueContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.DissectCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.DropCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.EnrichCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.EnrichWithClauseContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.EntryExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.EvalCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ExplainCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.FieldContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.FieldsContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.FromCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.FunctionExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.FunctionNameContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.GrokCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.IdentifierContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.IdentifierOrParameterContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.IdentifierPatternContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.IndexPatternContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.IndexStringContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.InlinestatsCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.InsistCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.IntegerValueContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.JoinCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.JoinConditionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.JoinPredicateContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.JoinTargetContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.KeepCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.LimitCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.LookupCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.MapExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.MatchBooleanExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.MetadataContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.MetricsCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.MvExpandCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.NumericValueContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.OperatorExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ArithmeticBinaryContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ArithmeticUnaryContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.OperatorExpressionDefaultContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.OrderExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ParameterContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.InputNamedOrPositionalParamContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.InputParamContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.PrimaryExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ConstantDefaultContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.DereferenceContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.FunctionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.InlineCastContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ParenthesizedExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ProcessingCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.QualifiedNameContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.QualifiedNamePatternContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.QualifiedNamePatternsContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.QueryContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.CompositeQueryContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.SingleCommandQueryContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.RegexBooleanExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.RenameClauseContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.RenameCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.RowCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ShowCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ShowInfoContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.SingleStatementContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.SortCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.SourceCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.StatsCommandContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.StringContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.SubqueryExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ValueExpressionContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ComparisonContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.ValueExpressionDefaultContext
- org.elasticsearch.xpack.esql.parser.EsqlBaseParser.WhereCommandContext
- org.antlr.v4.runtime.ParserRuleContext
- org.elasticsearch.xpack.esql.rule.RuleExecutor<TreeType>
- org.elasticsearch.xpack.esql.rule.ParameterizedRuleExecutor<TreeType,
Context> - org.elasticsearch.xpack.esql.analysis.Analyzer
- org.elasticsearch.xpack.esql.optimizer.LocalLogicalPlanOptimizer
- org.elasticsearch.xpack.esql.optimizer.LocalPhysicalPlanOptimizer
- org.elasticsearch.xpack.esql.optimizer.LogicalPlanOptimizer
- org.elasticsearch.xpack.esql.optimizer.PhysicalPlanOptimizer
- org.elasticsearch.xpack.esql.rule.ParameterizedRuleExecutor<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.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.session.SessionUtils
- 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.analysis.TableInfo
- org.elasticsearch.tasks.Task (implements org.elasticsearch.telemetry.tracing.Traceable)
- org.elasticsearch.tasks.CancellableTask
- org.elasticsearch.xpack.core.async.StoredAsyncTask<Response> (implements org.elasticsearch.xpack.core.async.AsyncTask)
- org.elasticsearch.xpack.esql.action.EsqlQueryTask
- org.elasticsearch.xpack.core.async.StoredAsyncTask<Response> (implements org.elasticsearch.xpack.core.async.AsyncTask)
- org.elasticsearch.tasks.CancellableTask
- org.elasticsearch.xpack.esql.formatter.TextFormatter
- java.lang.Throwable (implements java.io.Serializable)
- java.lang.Exception
- java.lang.RuntimeException
- org.elasticsearch.ElasticsearchException (implements org.elasticsearch.xcontent.ToXContentFragment, org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.core.QlException
- org.elasticsearch.xpack.esql.core.QlClientException
- org.elasticsearch.xpack.esql.EsqlClientException
- org.elasticsearch.xpack.esql.parser.ParsingException
- org.elasticsearch.xpack.esql.VerificationException
- org.elasticsearch.xpack.esql.index.MappingException
- org.elasticsearch.xpack.esql.EsqlClientException
- org.elasticsearch.xpack.esql.core.QlServerException
- org.elasticsearch.xpack.esql.core.QlIllegalArgumentException
- org.elasticsearch.xpack.esql.EsqlIllegalArgumentException
- org.elasticsearch.xpack.esql.rule.RuleExecutionException
- org.elasticsearch.xpack.esql.core.QlIllegalArgumentException
- org.elasticsearch.xpack.esql.core.QlClientException
- org.elasticsearch.xpack.esql.core.QlException
- org.elasticsearch.xpack.esql.session.NoClustersToSearchException
- org.elasticsearch.ElasticsearchException (implements org.elasticsearch.xcontent.ToXContentFragment, org.elasticsearch.common.io.stream.Writeable)
- java.lang.RuntimeException
- java.lang.Exception
- org.elasticsearch.xpack.esql.planner.TranslatorHandler
- org.elasticsearch.action.support.TransportAction<Request,
Response> - org.elasticsearch.action.support.HandledTransportAction<Request,
Response> - org.elasticsearch.xpack.esql.core.plugin.AbstractTransportQlAsyncGetResultsAction<Response,
AsyncTask> - org.elasticsearch.xpack.esql.plugin.TransportEsqlAsyncGetResultsAction
- org.elasticsearch.xpack.esql.action.EsqlResolveFieldsAction
- org.elasticsearch.xpack.esql.action.EsqlSearchShardsAction
- org.elasticsearch.xpack.esql.plugin.TransportEsqlAsyncStopAction
- org.elasticsearch.xpack.esql.plugin.TransportEsqlQueryAction (implements org.elasticsearch.xpack.esql.core.async.AsyncTaskManagementService.AsyncOperation<Request,
Response, T>) - org.elasticsearch.action.support.master.TransportMasterNodeAction<Request,
Response> (implements org.elasticsearch.reservedstate.ActionWithReservedState<T>) - org.elasticsearch.xpack.core.action.XPackUsageFeatureTransportAction
- org.elasticsearch.xpack.esql.EsqlUsageTransportAction
- org.elasticsearch.xpack.core.action.XPackUsageFeatureTransportAction
- org.elasticsearch.xpack.core.action.XPackInfoFeatureTransportAction
- org.elasticsearch.xpack.esql.EsqlInfoTransportAction
- org.elasticsearch.xpack.esql.core.plugin.AbstractTransportQlAsyncGetResultsAction<Response,
- org.elasticsearch.action.support.nodes.TransportNodesAction<NodesRequest,
NodesResponse, NodeRequest, NodeResponse, ActionContext> - org.elasticsearch.xpack.esql.plugin.TransportEsqlStatsAction
- org.elasticsearch.action.support.HandledTransportAction<Request,
- org.elasticsearch.transport.TransportMessage (implements org.elasticsearch.core.RefCounted, org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.transport.TransportRequest (implements org.elasticsearch.tasks.TaskAwareRequest)
- org.elasticsearch.action.ActionRequest
- org.elasticsearch.action.support.nodes.BaseNodesRequest
- org.elasticsearch.xpack.esql.plugin.EsqlStatsRequest
- org.elasticsearch.xpack.core.esql.action.EsqlQueryRequest
- org.elasticsearch.xpack.esql.action.EsqlQueryRequest (implements org.elasticsearch.action.CompositeIndicesRequest)
- org.elasticsearch.action.support.nodes.BaseNodesRequest
- org.elasticsearch.xpack.esql.enrich.EnrichLookupService.TransportRequest
- org.elasticsearch.xpack.esql.enrich.LookupFromIndexService.TransportRequest
- org.elasticsearch.action.ActionRequest
- org.elasticsearch.transport.TransportResponse
- org.elasticsearch.action.ActionResponse
- org.elasticsearch.action.support.nodes.BaseNodesResponse<TNodeResponse>
- org.elasticsearch.xpack.esql.plugin.EsqlStatsResponse (implements org.elasticsearch.xcontent.ToXContentObject)
- org.elasticsearch.xpack.core.esql.action.EsqlQueryResponse (implements org.elasticsearch.core.Releasable)
- org.elasticsearch.xpack.esql.action.EsqlQueryResponse (implements org.elasticsearch.common.xcontent.ChunkedToXContentObject, org.elasticsearch.core.Releasable)
- org.elasticsearch.action.support.nodes.BaseNodesResponse<TNodeResponse>
- org.elasticsearch.action.support.nodes.BaseNodeResponse
- org.elasticsearch.xpack.esql.plugin.EsqlStatsResponse.NodeStatsResponse (implements org.elasticsearch.xcontent.ToXContentObject)
- org.elasticsearch.xpack.esql.enrich.LookupFromIndexService.LookupResponse
- org.elasticsearch.action.ActionResponse
- org.elasticsearch.transport.TransportRequest (implements org.elasticsearch.tasks.TaskAwareRequest)
- org.elasticsearch.xpack.esql.expression.Validations
- org.elasticsearch.xpack.esql.analysis.Verifier
Interface Hierarchy
- org.elasticsearch.xpack.esql.enrich.AbstractLookupService.LookupShardContextFactory
- 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.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.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.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.EstimatesRowSize
- org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper
- org.elasticsearch.xpack.esql.evaluator.mapper.EvaluatorMapper.ToEvaluator
- org.elasticsearch.xpack.esql.score.ExpressionScoreMapper
- org.elasticsearch.xpack.esql.score.ExpressionScoreMapper.ToScorer
- 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.planner.Layout
- org.elasticsearch.xpack.esql.LicenseAware
- org.elasticsearch.xpack.esql.optimizer.rules.physical.local.LucenePushdownPredicates
- org.elasticsearch.xpack.esql.expression.function.OptionalArgument
- org.antlr.v4.runtime.tree.ParseTreeListener
- org.elasticsearch.xpack.esql.parser.EsqlBaseParserListener
- org.antlr.v4.runtime.tree.ParseTreeVisitor<T>
- org.elasticsearch.xpack.esql.parser.EsqlBaseParserVisitor<T>
- org.elasticsearch.xpack.esql.capabilities.PostAnalysisPlanVerificationAware
- org.elasticsearch.xpack.esql.capabilities.PostAnalysisVerificationAware
- org.elasticsearch.xpack.esql.capabilities.PostOptimizationVerificationAware
- org.elasticsearch.xpack.esql.stats.SearchStats
- org.elasticsearch.compute.lucene.ShardContext
- org.elasticsearch.xpack.esql.planner.EsPhysicalOperationProviders.ShardContext
- org.elasticsearch.xpack.esql.plan.logical.SortAgnostic
- java.util.function.Supplier<T>
- org.elasticsearch.xpack.esql.plan.logical.local.LocalSupplier (also extends org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.expression.SurrogateExpression
- org.elasticsearch.xpack.esql.plan.logical.SurrogateLogicalPlan
- org.elasticsearch.xpack.esql.capabilities.TelemetryAware
- org.elasticsearch.xpack.esql.planner.ToAggregator
- org.elasticsearch.xpack.esql.capabilities.TranslationAware
- org.elasticsearch.xpack.esql.capabilities.TranslationAware.SingleValueTranslationAware
- org.elasticsearch.xpack.esql.expression.function.TwoOptionalArguments
- org.elasticsearch.common.io.stream.Writeable
- org.elasticsearch.xpack.esql.plan.logical.join.JoinType
- org.elasticsearch.xpack.esql.plan.logical.local.LocalSupplier (also extends java.util.function.Supplier<T>)
Annotation Interface Hierarchy
- org.elasticsearch.xpack.esql.expression.function.Example (implements java.lang.annotation.Annotation)
- org.elasticsearch.xpack.esql.expression.function.FunctionAppliesTo (implements java.lang.annotation.Annotation)
- org.elasticsearch.xpack.esql.expression.function.FunctionInfo (implements java.lang.annotation.Annotation)
- org.elasticsearch.xpack.esql.expression.function.MapParam (implements java.lang.annotation.Annotation)
- org.elasticsearch.xpack.esql.expression.function.MapParam.MapParamEntry (implements java.lang.annotation.Annotation)
- org.elasticsearch.xpack.esql.expression.function.Param (implements java.lang.annotation.Annotation)
Enum Class Hierarchy
- java.lang.Object
- java.lang.Enum<E> (implements java.lang.Comparable<T>, java.lang.constant.Constable, java.io.Serializable)
- org.elasticsearch.xpack.esql.plan.logical.Aggregate.AggregateType
- org.elasticsearch.xpack.esql.expression.predicate.logical.BinaryLogicOperation (implements org.elasticsearch.xpack.esql.core.expression.predicate.PredicateBiFunction<T,
U, R>) - org.elasticsearch.xpack.esql.expression.function.scalar.spatial.BinarySpatialFunction.SpatialCrsType
- org.elasticsearch.xpack.esql.expression.function.scalar.string.ChangeCase.Case
- org.elasticsearch.xpack.esql.expression.function.scalar.date.DateDiff.Part (implements org.elasticsearch.xpack.esql.expression.function.scalar.date.DateTimeField)
- org.elasticsearch.xpack.esql.plan.logical.Enrich.Mode
- org.elasticsearch.xpack.esql.expression.predicate.operator.comparison.EsqlBinaryComparison.BinaryComparisonOperation (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.action.EsqlCapabilities.Cap
- org.elasticsearch.xpack.esql.type.EsqlDataTypeConverter.EsqlConverter (implements org.elasticsearch.xpack.esql.core.type.Converter)
- org.elasticsearch.xpack.esql.type.EsqlDataTypeConverter.INTERVALS
- org.elasticsearch.xpack.esql.action.EsqlExecutionInfo.Cluster.Status
- org.elasticsearch.xpack.esql.plan.physical.EsQueryExec.Direction
- org.elasticsearch.xpack.esql.plan.physical.EsQueryExec.Missing
- org.elasticsearch.xpack.esql.plan.physical.EsStatsQueryExec.StatsType
- org.elasticsearch.xpack.esql.plan.logical.Explain.Type
- org.elasticsearch.xpack.esql.telemetry.FeatureMetric
- org.elasticsearch.xpack.esql.expression.predicate.fulltext.FullTextPredicate.Operator
- org.elasticsearch.xpack.esql.expression.function.FunctionAppliesToLifecycle
- org.elasticsearch.xpack.esql.expression.function.FunctionType
- org.elasticsearch.xpack.esql.plan.logical.LogicalPlan.Stage
- org.elasticsearch.xpack.esql.optimizer.rules.logical.OptimizerRules.TransformDirection
- org.elasticsearch.xpack.esql.expression.Order.NullsPosition
- org.elasticsearch.xpack.esql.expression.Order.OrderDirection
- org.elasticsearch.xpack.esql.parser.ParserUtils.ParamClassification
- org.elasticsearch.xpack.esql.telemetry.QueryMetric
- org.elasticsearch.xpack.esql.formatter.TextFormat (implements org.elasticsearch.xcontent.MediaType)
- java.lang.Enum<E> (implements java.lang.Comparable<T>, java.lang.constant.Constable, java.io.Serializable)
Record Class Hierarchy
- java.lang.Object
- java.lang.Record
- org.elasticsearch.xpack.esql.enrich.AbstractLookupService.LookupShardContext
- org.elasticsearch.xpack.esql.analysis.AnalyzerContext
- org.elasticsearch.xpack.esql.Column (implements org.elasticsearch.core.Releasable, org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.plan.logical.Dissect.Parser (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.enrich.EnrichLookupOperator.Factory (implements org.elasticsearch.compute.operator.Operator.OperatorFactory)
- org.elasticsearch.xpack.esql.enrich.EnrichPolicyResolver.UnresolvedPolicy
- org.elasticsearch.xpack.esql.index.EsIndex (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.FunctionDescription
- org.elasticsearch.xpack.esql.expression.function.EsqlFunctionRegistry.MapEntryArgSignature
- org.elasticsearch.xpack.esql.plan.physical.EsQueryExec.FieldSort (implements org.elasticsearch.xpack.esql.plan.physical.EsQueryExec.Sort)
- org.elasticsearch.xpack.esql.plan.physical.EsQueryExec.GeoDistanceSort (implements org.elasticsearch.xpack.esql.plan.physical.EsQueryExec.Sort)
- org.elasticsearch.xpack.esql.plan.physical.EsQueryExec.ScoreSort (implements org.elasticsearch.xpack.esql.plan.physical.EsQueryExec.Sort)
- org.elasticsearch.xpack.esql.plan.physical.EsStatsQueryExec.Stat
- org.elasticsearch.xpack.esql.parser.ExpressionBuilder.ParsingContext
- org.elasticsearch.xpack.esql.plan.logical.Grok.Parser
- org.elasticsearch.xpack.esql.expression.function.scalar.string.Hash.HashFunction
- org.elasticsearch.xpack.esql.plan.logical.join.JoinConfig (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.planner.Layout.ChannelAndType
- org.elasticsearch.xpack.esql.planner.Layout.ChannelSet
- org.elasticsearch.xpack.esql.planner.LocalExecutionPlanner.LocalExecutionPlannerContext
- org.elasticsearch.xpack.esql.optimizer.LocalPhysicalOptimizerContext
- org.elasticsearch.xpack.esql.enrich.LookupFromIndexOperator.Factory (implements org.elasticsearch.compute.operator.Operator.OperatorFactory)
- org.elasticsearch.xpack.esql.enrich.LookupFromIndexOperator.OngoingJoin (implements org.elasticsearch.core.Releasable)
- org.elasticsearch.xpack.esql.optimizer.PhysicalOptimizerContext
- org.elasticsearch.xpack.esql.parser.QueryParam
- org.elasticsearch.xpack.esql.enrich.ResolvedEnrichPolicy (implements org.elasticsearch.common.io.stream.Writeable)
- org.elasticsearch.xpack.esql.session.Result
- org.elasticsearch.xpack.esql.stats.SearchStats.EmptySearchStats (implements org.elasticsearch.xpack.esql.stats.SearchStats)
- java.lang.Record