A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes All Packages

A

abort() - Method in interface io.prestosql.execution.RemoteTask
 
abort() - Method in class io.prestosql.execution.scheduler.SqlQueryScheduler
 
abort() - Method in class io.prestosql.execution.SqlStageExecution
 
abort() - Method in class io.prestosql.execution.SqlTask
 
abort() - Method in class io.prestosql.execution.TaskStateMachine
 
abort() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
abort(OutputBuffers.OutputBufferId) - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
abort(OutputBuffers.OutputBufferId) - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
abort(OutputBuffers.OutputBufferId) - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
abort(OutputBuffers.OutputBufferId) - Method in interface io.prestosql.execution.buffer.OutputBuffer
Closes the specified output buffer.
abort(OutputBuffers.OutputBufferId) - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
ABORT - io.prestosql.sql.analyzer.FeaturesConfig.DataIntegrityVerification
 
ABORTED - io.prestosql.execution.StageState
Stage was aborted due to a failure in the query.
ABORTED - io.prestosql.execution.TaskState
Task was aborted due to a failure in the query.
abortResults(TaskId, OutputBuffers.OutputBufferId, UriInfo) - Method in class io.prestosql.server.TaskResource
 
abortTask(TaskId) - Method in class io.prestosql.execution.SqlTaskManager
 
abortTask(TaskId) - Method in interface io.prestosql.execution.TaskManager
Aborts a task.
abortTaskResults(OutputBuffers.OutputBufferId) - Method in class io.prestosql.execution.SqlTask
 
abortTaskResults(TaskId, OutputBuffers.OutputBufferId) - Method in class io.prestosql.execution.SqlTaskManager
 
abortTaskResults(TaskId, OutputBuffers.OutputBufferId) - Method in interface io.prestosql.execution.TaskManager
Aborts a result buffer for a task.
abs(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
abs(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
absFloat(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
absInteger(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
absLong(Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Abs
 
absShort(long) - Static method in class io.prestosql.operator.scalar.MathFunctions.Abs
 
absSmallint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
absTinyint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
AbstractGreatestLeast - Class in io.prestosql.operator.scalar
 
AbstractGreatestLeast(boolean, String) - Constructor for class io.prestosql.operator.scalar.AbstractGreatestLeast
 
AbstractGroupCollectionAggregationState<T> - Class in io.prestosql.operator.aggregation
Instances of this state use a single PageBuilder for all groups.
AbstractGroupCollectionAggregationState(PageBuilder) - Constructor for class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
 
AbstractGroupedAccumulatorState - Class in io.prestosql.operator.aggregation.state
 
AbstractGroupedAccumulatorState() - Constructor for class io.prestosql.operator.aggregation.state.AbstractGroupedAccumulatorState
 
AbstractMinMaxAggregationFunction - Class in io.prestosql.operator.aggregation
 
AbstractMinMaxAggregationFunction(String, boolean, String) - Constructor for class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
AbstractMinMaxBy - Class in io.prestosql.operator.aggregation.minmaxby
 
AbstractMinMaxBy(boolean, String) - Constructor for class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxBy
 
AbstractMinMaxByNAggregationFunction - Class in io.prestosql.operator.aggregation.minmaxby
 
AbstractMinMaxByNAggregationFunction(String, Function<Type, BlockTypeOperators.BlockPositionComparison>, String) - Constructor for class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
AbstractMinMaxNAggregationFunction - Class in io.prestosql.operator.aggregation
 
AbstractMinMaxNAggregationFunction(String, Function<Type, BlockTypeOperators.BlockPositionComparison>, String) - Constructor for class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
AbstractTypedJacksonModule<T> - Class in io.prestosql.metadata
 
AbstractTypedJacksonModule(Class<T>, Function<T, String>, Function<String, Class<? extends T>>) - Constructor for class io.prestosql.metadata.AbstractTypedJacksonModule
 
AbstractWindowFunctionSupplier - Class in io.prestosql.operator.window
 
AbstractWindowFunctionSupplier(Signature, String, List<Class<?>>) - Constructor for class io.prestosql.operator.window.AbstractWindowFunctionSupplier
 
accept(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.memory.QueryContext
 
accept(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.operator.DriverContext
 
accept(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.operator.OperatorContext
 
accept(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.operator.PipelineContext
 
accept(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.operator.TaskContext
 
accept(ArrayAggregationStateConsumer, PageBuilder, int) - Method in class io.prestosql.operator.aggregation.arrayagg.GroupArrayAggregationState
 
accept(MultimapAggregationStateConsumer, PageBuilder, int) - Method in class io.prestosql.operator.aggregation.multimapagg.GroupedMultimapAggregationState
 
accept(Block, int) - Method in interface io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateConsumer
 
accept(Block, Block, int) - Method in interface io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateConsumer
 
accept(Page) - Method in interface io.prestosql.operator.exchange.LocalExchanger
 
accept(Page) - Method in class io.prestosql.operator.exchange.PassthroughExchanger
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.iterative.GroupReference
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.AssignUniqueId
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.DeleteNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.DistinctLimitNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.EnforceSingleRowNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.ExceptNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.ExchangeNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.ExplainAnalyzeNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.FilterNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.IndexJoinNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.IndexSourceNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.IntersectNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.JoinNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.LimitNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.MarkDistinctNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.OffsetNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.OutputNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.PlanNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.ProjectNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.RemoteSourceNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.RowNumberNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.SampleNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.SortNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.TableDeleteNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.TableFinishNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.TableScanNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.TopNNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.UnionNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.ValuesNode
 
accept(PlanVisitor<R, C>, C) - Method in class io.prestosql.sql.planner.plan.WindowNode
 
accept(RowExpressionVisitor<R, C>, C) - Method in class io.prestosql.sql.relational.CallExpression
 
accept(RowExpressionVisitor<R, C>, C) - Method in class io.prestosql.sql.relational.ConstantExpression
 
accept(RowExpressionVisitor<R, C>, C) - Method in class io.prestosql.sql.relational.InputReferenceExpression
 
accept(RowExpressionVisitor<R, C>, C) - Method in class io.prestosql.sql.relational.LambdaDefinitionExpression
 
accept(RowExpressionVisitor<R, C>, C) - Method in class io.prestosql.sql.relational.RowExpression
 
accept(RowExpressionVisitor<R, C>, C) - Method in class io.prestosql.sql.relational.SpecialForm
 
accept(RowExpressionVisitor<R, C>, C) - Method in class io.prestosql.sql.relational.VariableReferenceExpression
 
accept(T, PageBuilder, int) - Method in class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
 
acceptChildren(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.memory.QueryContext
 
acceptChildren(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.operator.DriverContext
 
acceptChildren(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.operator.PipelineContext
 
acceptChildren(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.operator.TaskContext
 
AccessControl - Interface in io.prestosql.security
 
AccessControlConfig - Class in io.prestosql.security
 
AccessControlConfig() - Constructor for class io.prestosql.security.AccessControlConfig
 
AccessControlInfo(AccessControl, Identity) - Constructor for class io.prestosql.sql.analyzer.Analysis.AccessControlInfo
 
AccessControlManager - Class in io.prestosql.security
 
AccessControlManager(TransactionManager, EventListenerManager, AccessControlConfig) - Constructor for class io.prestosql.security.AccessControlManager
 
AccessControlModule - Class in io.prestosql.security
 
AccessControlModule() - Constructor for class io.prestosql.security.AccessControlModule
 
AccessControlUtil - Class in io.prestosql.security
 
AccessToken(String, Optional<Instant>) - Constructor for class io.prestosql.server.security.oauth2.OAuth2Client.AccessToken
 
Accumulator - Interface in io.prestosql.operator.aggregation
 
AccumulatorCompiler - Class in io.prestosql.operator.aggregation
 
AccumulatorFactory - Interface in io.prestosql.operator.aggregation
 
AccumulatorFactoryBinder - Interface in io.prestosql.operator.aggregation
 
AccumulatorStateDescriptor(Class<?>, AccumulatorStateSerializer<?>, AccumulatorStateFactory<?>) - Constructor for class io.prestosql.operator.aggregation.AggregationMetadata.AccumulatorStateDescriptor
 
acknowledge(OutputBuffers.OutputBufferId, long) - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
acknowledge(OutputBuffers.OutputBufferId, long) - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
acknowledge(OutputBuffers.OutputBufferId, long) - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
acknowledge(OutputBuffers.OutputBufferId, long) - Method in interface io.prestosql.execution.buffer.OutputBuffer
Acknowledges the previously received pages from the output buffer.
acknowledge(OutputBuffers.OutputBufferId, long) - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
acknowledgeAndGetNewDomains(long) - Method in class io.prestosql.execution.DynamicFiltersCollector
 
acknowledgeAndGetNewDynamicFilterDomains(long) - Method in class io.prestosql.execution.SqlTask
 
acknowledgeAndGetNewDynamicFilterDomains(long) - Method in class io.prestosql.operator.TaskContext
 
acknowledgeAndGetNewDynamicFilterDomains(TaskId, long) - Method in class io.prestosql.execution.SqlTaskManager
 
acknowledgeAndGetNewDynamicFilterDomains(TaskId, long) - Method in interface io.prestosql.execution.TaskManager
 
acknowledgeAndGetNewDynamicFilterDomains(TaskId, Long, UriInfo) - Method in class io.prestosql.server.TaskResource
 
acknowledgeResults(TaskId, OutputBuffers.OutputBufferId, long) - Method in class io.prestosql.server.TaskResource
 
acknowledgeTaskResults(OutputBuffers.OutputBufferId, long) - Method in class io.prestosql.execution.SqlTask
 
acknowledgeTaskResults(TaskId, OutputBuffers.OutputBufferId, long) - Method in class io.prestosql.execution.SqlTaskManager
 
acknowledgeTaskResults(TaskId, OutputBuffers.OutputBufferId, long) - Method in interface io.prestosql.execution.TaskManager
Acknowledges previously received results.
acos(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
activateTransaction(Session, boolean, AccessControl) - Method in interface io.prestosql.transaction.TransactionManager
 
ACTIVE - io.prestosql.metadata.NodeState
 
ActualProperties - Class in io.prestosql.sql.planner.optimizations
 
ActualProperties.Builder - Class in io.prestosql.sql.planner.optimizations
 
ActualProperties.Global - Class in io.prestosql.sql.planner.optimizations
 
add(double) - Method in class io.prestosql.operator.aggregation.NumericHistogram
 
add(double, double) - Method in class io.prestosql.operator.aggregation.NumericHistogram
 
add(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
add(int, Block, long) - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
add(int, Block, long) - Method in class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
add(int, Block, long) - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
add(long) - Method in class io.prestosql.type.setdigest.SetDigest
 
add(long, long) - Static method in class io.prestosql.operator.scalar.time.TimeOperators
 
add(long, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.IntervalDayToSecondPlusTimestamp
 
add(long, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.IntervalYearToMonthPlusTimestamp
 
add(long, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampPlusIntervalDayToSecond
 
add(long, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampPlusIntervalYearToMonth
 
add(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.IntervalYearToMonthPlusTimestamp
 
add(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampPlusIntervalYearToMonth
 
add(long, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.IntervalDayToSecondPlusTime
 
add(long, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.TimePlusIntervalDayToSecond
 
add(long, long) - Static method in class io.prestosql.type.BigintOperators
 
add(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
add(long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
add(long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
add(long, long) - Static method in class io.prestosql.type.RealOperators
 
add(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
add(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
add(long, long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.IntervalDayToSecondPlusTimestamp
 
add(long, long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampPlusIntervalDayToSecond
 
add(long, Slice, long, long) - Static method in class io.prestosql.operator.scalar.timestamp.DateAdd
 
add(long, Slice, long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.DateAdd
 
add(long, Slice, long, long) - Static method in class io.prestosql.operator.scalar.timetz.DateAdd
 
add(long, GroupedTopNRowNumberAccumulator.RowReference) - Method in class io.prestosql.operator.GroupedTopNRowNumberAccumulator
Add the specified row to this accumulator.
add(long, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.IntervalDayToSecondPlusTimestamp
 
add(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.IntervalDayToSecondPlusTimestamp
 
add(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.IntervalYearToMonthPlusTimestamp
 
add(long, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.IntervalDayToSecondPlusTime
 
add(Slice) - Method in class io.prestosql.type.setdigest.SetDigest
 
add(Slice, long, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.DateAdd
 
add(Slice, long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.DateAdd
 
add(Slice, long, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.DateAdd
 
add(PageCodecMarker) - Method in class io.prestosql.execution.buffer.PageCodecMarker.MarkerSet
 
add(DoubleHistogramAggregation.State, long, double) - Static method in class io.prestosql.operator.aggregation.DoubleHistogramAggregation
 
add(DoubleHistogramAggregation.State, long, double, double) - Static method in class io.prestosql.operator.aggregation.DoubleHistogramAggregation
 
add(DoubleHistogramAggregation.State, long, long) - Static method in class io.prestosql.operator.aggregation.RealHistogramAggregation
 
add(DoubleHistogramAggregation.State, long, long, double) - Static method in class io.prestosql.operator.aggregation.RealHistogramAggregation
 
add(OperatorStats...) - Method in class io.prestosql.operator.OperatorStats
 
add(Block, int) - Method in interface io.prestosql.operator.aggregation.arrayagg.ArrayAggregationState
 
add(Block, int) - Method in class io.prestosql.operator.aggregation.arrayagg.GroupArrayAggregationState
 
add(Block, int) - Method in class io.prestosql.operator.aggregation.arrayagg.SingleArrayAggregationState
 
add(Block, int) - Method in class io.prestosql.operator.aggregation.TypedHeap
 
add(Block, int) - Method in class io.prestosql.operator.aggregation.TypedSet
 
add(Block, Block, int) - Method in class io.prestosql.operator.aggregation.multimapagg.GroupedMultimapAggregationState
 
add(Block, Block, int) - Method in interface io.prestosql.operator.aggregation.multimapagg.MultimapAggregationState
 
add(Block, Block, int) - Method in class io.prestosql.operator.aggregation.multimapagg.SingleMultimapAggregationState
 
add(Block, Block, int) - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
add(Block, Block, int, int) - Method in class io.prestosql.operator.aggregation.KeyValuePairs
Only add this key value pair if we haven't seen this key before.
add(ConnectorSession, long, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.IntervalYearToMonthPlusTimestamp
 
add(Page) - Method in class io.prestosql.operator.index.PageBuffer
Adds a page to the buffer.
add(Page) - Method in class io.prestosql.operator.PageBuffer
 
add(Page) - Method in class io.prestosql.operator.RowReferencePageManager
 
add(PrestoWarning) - Method in class io.prestosql.execution.warnings.DefaultWarningCollector
 
add(PrestoWarning) - Method in interface io.prestosql.execution.warnings.WarningCollector
 
add(PrestoWarning) - Method in class io.prestosql.testing.TestingWarningCollector
 
add(LongTimestamp, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampPlusIntervalDayToSecond
 
add(LongTimestamp, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampPlusIntervalYearToMonth
 
add(LongTimestampWithTimeZone, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampPlusIntervalDayToSecond
 
add(LongTimestampWithTimeZone, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampPlusIntervalYearToMonth
 
add(LongTimeWithTimeZone, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.TimePlusIntervalDayToSecond
 
add(Iterable<OperatorStats>) - Method in class io.prestosql.operator.OperatorStats
 
add(Object...) - Method in class io.prestosql.metadata.InternalTable.Builder
 
add(K) - Method in class io.prestosql.operator.aggregation.ApproximateMostFrequentHistogram
 
add(K, long) - Method in class io.prestosql.operator.aggregation.ApproximateMostFrequentHistogram
 
ADD_COLUMN - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
addAll(TypedHistogram) - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
addAll(TypedHistogram) - Method in class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
addAll(TypedHistogram) - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
addAll(TypedHeap) - Method in class io.prestosql.operator.aggregation.TypedHeap
 
addAll(TypedKeyValueHeap) - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
addAll(Block) - Method in class io.prestosql.operator.aggregation.TypedHeap
 
addAll(Block, Block) - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
addAndCollapseDistinctValues(StatisticRange) - Method in class io.prestosql.cost.StatisticRange
 
addAndGetPosition(Block, int, long) - Method in class io.prestosql.operator.aggregation.histogram.ValueStore
This will add an item if not already in the system.
addAndMaxDistinctValues(StatisticRange) - Method in class io.prestosql.cost.StatisticRange
 
addAndSumDistinctValues(StatisticRange) - Method in class io.prestosql.cost.StatisticRange
 
addArgument(Type, Expression) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
addArgument(TypeSignature, Expression) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
addAssignedSplit(InternalNode) - Method in class io.prestosql.execution.scheduler.NodeAssignmentStats
 
addBlockEncoding(BlockEncoding) - Method in class io.prestosql.metadata.MetadataManager
 
addCast(Type, Type) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addCastSignature(TypeSignature, TypeSignature) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addCatalogAccessControl(CatalogName, ConnectorAccessControl) - Method in class io.prestosql.security.AccessControlManager
 
addCatalogHandleResolver(String, ConnectorHandleResolver) - Method in class io.prestosql.metadata.HandleResolver
 
addCertificateAuthenticatorFactory(CertificateAuthenticatorFactory) - Method in class io.prestosql.server.security.CertificateAuthenticatorManager
 
addChangeListener(MemoryPoolId, Consumer<MemoryPoolInfo>) - Method in class io.prestosql.memory.ClusterMemoryManager
 
addCoercion(Expression, Type, boolean) - Method in class io.prestosql.sql.analyzer.Analysis
 
addCoercions(Expression, Analysis) - Static method in class io.prestosql.sql.planner.Coercer
 
addCoercions(Expression, Map<NodeRef<Expression>, Type>, Set<NodeRef<Expression>>) - Static method in class io.prestosql.sql.planner.Coercer
 
addCoercions(Map<NodeRef<Expression>, Type>, Set<NodeRef<Expression>>, Map<NodeRef<Expression>, Type>, Map<NodeRef<Expression>, Type>) - Method in class io.prestosql.sql.analyzer.Analysis
 
addColumn(Session, TableHandle, ColumnMetadata) - Method in interface io.prestosql.metadata.Metadata
Add the specified column to the table.
addColumn(Session, TableHandle, ColumnMetadata) - Method in class io.prestosql.metadata.MetadataManager
 
addColumn(ConnectorSession, ConnectorTableHandle, ColumnMetadata) - Method in class io.prestosql.testing.TestingMetadata
 
addColumnMask(Table, String, Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
addColumnReferences(Map<NodeRef<Expression>, ResolvedField>) - Method in class io.prestosql.sql.analyzer.Analysis
 
addColumnStatistic(ColumnStatisticMetadata, T) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.Builder
 
AddColumnTask - Class in io.prestosql.execution
 
AddColumnTask() - Constructor for class io.prestosql.execution.AddColumnTask
 
addCompletedDriverGroup(Lifespan) - Method in class io.prestosql.operator.TaskContext
 
addCompletedDriverGroupsChangedListener(Consumer<Set<Lifespan>>) - Method in class io.prestosql.execution.SqlStageExecution
 
addConfigurationManagerFactory(ResourceGroupConfigurationManagerFactory) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
addConfigurationManagerFactory(ResourceGroupConfigurationManagerFactory) - Method in class io.prestosql.execution.resourcegroups.NoOpResourceGroupManager
 
addConfigurationManagerFactory(ResourceGroupConfigurationManagerFactory) - Method in interface io.prestosql.execution.resourcegroups.ResourceGroupManager
 
addConfigurationManagerFactory(SessionPropertyConfigurationManagerFactory) - Method in class io.prestosql.server.SessionPropertyDefaults
 
addConnectorFactory(ConnectorFactory, Supplier<ClassLoader>) - Method in class io.prestosql.connector.ConnectorManager
 
addConnectorPageSinkProvider(CatalogName, ConnectorPageSinkProvider) - Method in class io.prestosql.split.PageSinkManager
 
addConnectorPageSourceProvider(CatalogName, ConnectorPageSourceProvider) - Method in class io.prestosql.split.PageSourceManager
 
addConnectorSessionProperties(CatalogName, List<PropertyMetadata<?>>) - Method in class io.prestosql.metadata.SessionPropertyManager
 
addConnectorSplitManager(CatalogName, ConnectorSplitManager) - Method in class io.prestosql.split.SplitManager
 
addCurrentNodeConnector(CatalogName) - Method in class io.prestosql.metadata.InMemoryNodeManager
 
addDriverContext() - Method in class io.prestosql.operator.PipelineContext
 
addDriverContext(Lifespan) - Method in class io.prestosql.operator.PipelineContext
 
addEmptyColumnReferencesForTable(AccessControl, Identity, QualifiedObjectName) - Method in class io.prestosql.sql.analyzer.Analysis
 
addEventListener(EventListener) - Method in class io.prestosql.eventlistener.EventListenerManager
 
addEventListener(EventListener) - Method in class io.prestosql.testing.TestingEventListenerManager
 
addEventListenerFactory(EventListenerFactory) - Method in class io.prestosql.eventlistener.EventListenerManager
 
addEventListenerFactory(EventListenerFactory) - Method in class io.prestosql.testing.TestingEventListenerManager
 
addExchangeLocations(PlanFragmentId, Set<RemoteTask>, boolean) - Method in class io.prestosql.execution.SqlStageExecution
 
AddExchanges - Class in io.prestosql.sql.planner.optimizations
 
AddExchanges(Metadata, TypeOperators, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.optimizations.AddExchanges
 
AddExchangesBelowPartialAggregationOverGroupIdRuleSet - Class in io.prestosql.sql.planner.iterative.rule
Transforms
AddExchangesBelowPartialAggregationOverGroupIdRuleSet(Metadata, TypeOperators, TypeAnalyzer, TaskCountEstimator, TaskManagerConfig) - Constructor for class io.prestosql.sql.planner.iterative.rule.AddExchangesBelowPartialAggregationOverGroupIdRuleSet
 
addFieldValueDate(ConnectorSession, Slice, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
addFinalizer(Object, Runnable) - Method in class io.prestosql.util.FinalizerService
When referent is freed by the garbage collector, run cleanup.
addFinalQueryInfoListener(StateMachine.StateChangeListener<QueryInfo>) - Method in class io.prestosql.execution.DataDefinitionExecution
 
addFinalQueryInfoListener(StateMachine.StateChangeListener<QueryInfo>) - Method in interface io.prestosql.execution.QueryExecution
Add a listener for the final query info.
addFinalQueryInfoListener(StateMachine.StateChangeListener<QueryInfo>) - Method in class io.prestosql.execution.SqlQueryExecution
 
addFinalQueryInfoListener(QueryId, StateMachine.StateChangeListener<QueryInfo>) - Method in class io.prestosql.execution.SqlQueryManager
 
addFinalQueryInfoListener(QueryId, StateMachine.StateChangeListener<QueryInfo>) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
addFinalStageInfoListener(StateMachine.StateChangeListener<StageInfo>) - Method in class io.prestosql.execution.SqlStageExecution
Add a listener for the final stage info.
addFinalStageInfoListener(StateMachine.StateChangeListener<StageInfo>) - Method in class io.prestosql.execution.StageStateMachine
Add a listener for the final stage info.
addFinalTaskInfoListener(StateMachine.StateChangeListener<TaskInfo>) - Method in interface io.prestosql.execution.RemoteTask
Add a listener for the final task info.
addFinalTaskInfoListener(StateMachine.StateChangeListener<TaskInfo>) - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
addFinalTaskInfoListener(StateMachine.StateChangeListener<TaskInfo>) - Method in class io.prestosql.server.remotetask.TaskInfoFetcher
Add a listener for the final task info.
addFrameBoundCalculations(Map<NodeRef<Expression>, ResolvedFunction>) - Method in class io.prestosql.sql.analyzer.Analysis
 
addFunction(QualifiedName, List<Type>) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addFunctions(List<? extends SqlFunction>) - Method in class io.prestosql.metadata.FunctionRegistry
 
addFunctions(List<? extends SqlFunction>) - Method in interface io.prestosql.metadata.Metadata
 
addFunctions(List<? extends SqlFunction>) - Method in class io.prestosql.metadata.MetadataManager
 
addFunctions(List<? extends SqlFunction>) - Method in class io.prestosql.testing.LocalQueryRunner
 
addFunctions(List<? extends SqlFunction>) - Method in interface io.prestosql.testing.QueryRunner
 
addFunctionSignature(QualifiedName, List<TypeSignature>) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addGrouping(String, T) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.Builder
 
addGroupProviderFactory(GroupProviderFactory) - Method in class io.prestosql.security.GroupProviderManager
 
addImplementation(T) - Method in class io.prestosql.operator.ParametricImplementationsGroup.Builder
 
addIndexProvider(CatalogName, ConnectorIndexProvider) - Method in class io.prestosql.index.IndexManager
 
addInput(GroupByIdBlock, Page) - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
addInput(WindowIndex, List<Integer>, int, int) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
addInput(Page) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
addInput(Page) - Method in class io.prestosql.operator.AggregationOperator
 
addInput(Page) - Method in class io.prestosql.operator.BasicWorkProcessorOperatorAdapter
 
addInput(Page) - Method in class io.prestosql.operator.DeleteOperator
 
addInput(Page) - Method in class io.prestosql.operator.DevNullOperator
 
addInput(Page) - Method in class io.prestosql.operator.DistinctLimitOperator
 
addInput(Page) - Method in class io.prestosql.operator.DynamicFilterSourceOperator
 
addInput(Page) - Method in class io.prestosql.operator.EnforceSingleRowOperator
 
addInput(Page) - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator
 
addInput(Page) - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator
 
addInput(Page) - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator
 
addInput(Page) - Method in class io.prestosql.operator.ExchangeOperator
 
addInput(Page) - Method in class io.prestosql.operator.ExplainAnalyzeOperator
 
addInput(Page) - Method in class io.prestosql.operator.FinishedOperator
 
addInput(Page) - Method in class io.prestosql.operator.GroupIdOperator
 
addInput(Page) - Method in class io.prestosql.operator.HashAggregationOperator
 
addInput(Page) - Method in class io.prestosql.operator.HashBuilderOperator
 
addInput(Page) - Method in class io.prestosql.operator.index.IndexSourceOperator
 
addInput(Page) - Method in class io.prestosql.operator.index.PageBufferOperator
 
addInput(Page) - Method in class io.prestosql.operator.index.PagesIndexBuilderOperator
 
addInput(Page) - Method in class io.prestosql.operator.LimitOperator
 
addInput(Page) - Method in class io.prestosql.operator.LookupJoinOperator
 
addInput(Page) - Method in class io.prestosql.operator.LookupOuterOperator
 
addInput(Page) - Method in class io.prestosql.operator.MarkDistinctOperator
 
addInput(Page) - Method in class io.prestosql.operator.MergeOperator
 
addInput(Page) - Method in class io.prestosql.operator.NestedLoopBuildOperator
 
addInput(Page) - Method in class io.prestosql.operator.NestedLoopJoinOperator
 
addInput(Page) - Method in interface io.prestosql.operator.Operator
Adds an input page to the operator.
addInput(Page) - Method in class io.prestosql.operator.OrderByOperator
 
addInput(Page) - Method in class io.prestosql.operator.PageSourceOperator
 
addInput(Page) - Method in class io.prestosql.operator.PartitionedOutputOperator
 
addInput(Page) - Method in class io.prestosql.operator.RowNumberOperator
 
addInput(Page) - Method in class io.prestosql.operator.SetBuilderOperator
 
addInput(Page) - Method in class io.prestosql.operator.SpatialIndexBuilderOperator
 
addInput(Page) - Method in class io.prestosql.operator.SpatialJoinOperator
 
addInput(Page) - Method in class io.prestosql.operator.StatisticsWriterOperator
 
addInput(Page) - Method in class io.prestosql.operator.TableDeleteOperator
 
addInput(Page) - Method in class io.prestosql.operator.TableFinishOperator
 
addInput(Page) - Method in class io.prestosql.operator.TableScanOperator
 
addInput(Page) - Method in class io.prestosql.operator.TableWriterOperator
 
addInput(Page) - Method in class io.prestosql.operator.TaskOutputOperator
 
addInput(Page) - Method in class io.prestosql.operator.TopNOperator
 
addInput(Page) - Method in class io.prestosql.operator.TopNProcessor
 
addInput(Page) - Method in class io.prestosql.operator.TopNRowNumberOperator
 
addInput(Page) - Method in class io.prestosql.operator.unnest.UnnestOperator
 
addInput(Page) - Method in class io.prestosql.operator.ValuesOperator
 
addInput(Page) - Method in class io.prestosql.operator.WindowOperator
 
addInput(Page) - Method in interface io.prestosql.operator.WorkProcessorOperatorAdapter.AdapterWorkProcessorOperator
 
addInput(Page) - Method in class io.prestosql.operator.WorkProcessorOperatorAdapter
 
addInput(Page) - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
addInput(Page) - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
addInput(Page) - Method in class io.prestosql.testing.NullOutputOperator
 
addInput(Page) - Method in class io.prestosql.testing.PageConsumerOperator
 
addIntermediate(GroupByIdBlock, Block) - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
addIntermediate(Block) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
AddIntermediateAggregations - Class in io.prestosql.sql.planner.iterative.rule
Adds INTERMEDIATE aggregations between an un-grouped FINAL aggregation and its preceding PARTIAL aggregation.
AddIntermediateAggregations() - Constructor for class io.prestosql.sql.planner.iterative.rule.AddIntermediateAggregations
 
addLambdaArgumentReferences(Map<NodeRef<Identifier>, LambdaArgumentDeclaration>) - Method in class io.prestosql.sql.analyzer.Analysis
 
addListener(MemoryPoolListener) - Method in class io.prestosql.memory.MemoryPool
 
AddLocalExchanges - Class in io.prestosql.sql.planner.optimizations
 
AddLocalExchanges(Metadata, TypeOperators, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.optimizations.AddLocalExchanges
 
addLocation(URI) - Method in class io.prestosql.operator.ExchangeClient
 
addLongLongLong(Slice, Slice, int, boolean) - Static method in class io.prestosql.type.DecimalOperators
 
addLongShortLong(Slice, long, int, boolean) - Static method in class io.prestosql.type.DecimalOperators
 
addMaterializedHandle(TableWriterNode.WriterTarget, TableWriterNode.WriterTarget) - Method in class io.prestosql.sql.planner.optimizations.BeginTableWrite.Context
 
addMemoryUsage(int) - Method in interface io.prestosql.operator.aggregation.state.HyperLogLogState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.GroupedHyperLogLogState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.SingleHyperLogLogState
 
addMemoryUsage(int) - Method in interface io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.GroupedQuantileDigestAndPercentileState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.SingleQuantileDigestAndPercentileState
 
addMemoryUsage(int) - Method in interface io.prestosql.operator.aggregation.state.QuantileDigestState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.GroupedQuantileDigestState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.SingleQuantileDigestState
 
addMemoryUsage(int) - Method in interface io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.GroupedTDigestAndPercentileArrayState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.SingleTDigestAndPercentileArrayState
 
addMemoryUsage(int) - Method in interface io.prestosql.operator.aggregation.state.TDigestAndPercentileState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.GroupedTDigestAndPercentileState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.SingleTDigestAndPercentileState
 
addMemoryUsage(int) - Method in interface io.prestosql.operator.aggregation.state.TDigestState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory.GroupedTDigestState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory.SingleTDigestState
 
addMemoryUsage(long) - Method in class io.prestosql.operator.aggregation.histogram.GroupedHistogramState
 
addMemoryUsage(long) - Method in interface io.prestosql.operator.aggregation.histogram.HistogramState
 
addMemoryUsage(long) - Method in class io.prestosql.operator.aggregation.histogram.SingleHistogramState
 
addMemoryUsage(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.MinMaxByNState
 
addMemoryUsage(long) - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.GroupedMinMaxByNState
 
addMemoryUsage(long) - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.SingleMinMaxByNState
 
addMemoryUsage(long) - Method in interface io.prestosql.operator.aggregation.state.KeyValuePairsState
 
addMemoryUsage(long) - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.GroupedState
 
addMemoryUsage(long) - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.SingleState
 
addMemoryUsage(long) - Method in interface io.prestosql.operator.aggregation.state.MinMaxNState
 
addMemoryUsage(long) - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.GroupedMinMaxNState
 
addMemoryUsage(long) - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.SingleMinMaxNState
 
addNode(CatalogName, InternalNode...) - Method in class io.prestosql.metadata.InMemoryNodeManager
 
addNode(CatalogName, Iterable<InternalNode>) - Method in class io.prestosql.metadata.InMemoryNodeManager
 
addNode(Node) - Method in class io.prestosql.testing.TestingNodeManager
 
addNodeChangeListener(Consumer<AllNodes>) - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
addNodeChangeListener(Consumer<AllNodes>) - Method in class io.prestosql.metadata.InMemoryNodeManager
 
addNodeChangeListener(Consumer<AllNodes>) - Method in interface io.prestosql.metadata.InternalNodeManager
 
addOperator(OperatorType, List<Type>) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addOperatorContext(int, PlanNodeId, String) - Method in class io.prestosql.operator.DriverContext
 
addOperatorSignature(OperatorType, List<TypeSignature>) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addOptionalCast(Type, Type) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addOptionalCastSignature(TypeSignature, TypeSignature) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addOptionalFunction(QualifiedName, List<Type>) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addOptionalFunctionSignature(QualifiedName, List<TypeSignature>) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addOptionalOperator(OperatorType, List<Type>) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addOptionalOperatorSignature(OperatorType, List<TypeSignature>) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addOrUpdate(E, long) - Method in class io.prestosql.execution.resourcegroups.IndexedPriorityQueue
 
addOutputBuffers(List<OutputBuffers.OutputBufferId>, boolean) - Method in class io.prestosql.execution.scheduler.PartitionedOutputBufferManager
 
addOutputBuffers(List<OutputBuffers.OutputBufferId>, boolean) - Method in class io.prestosql.execution.scheduler.ScaledOutputBufferManager
 
addOutputInfoListener(QueryId, Consumer<QueryExecution.QueryOutputInfo>) - Method in interface io.prestosql.execution.QueryManager
Add a listener that fires once the query output locations are known.
addOutputInfoListener(QueryId, Consumer<QueryExecution.QueryOutputInfo>) - Method in class io.prestosql.execution.SqlQueryManager
 
addOutputInfoListener(Consumer<QueryExecution.QueryOutputInfo>) - Method in class io.prestosql.execution.DataDefinitionExecution
 
addOutputInfoListener(Consumer<QueryExecution.QueryOutputInfo>) - Method in interface io.prestosql.execution.QueryExecution
 
addOutputInfoListener(Consumer<QueryExecution.QueryOutputInfo>) - Method in class io.prestosql.execution.QueryStateMachine
 
addOutputInfoListener(Consumer<QueryExecution.QueryOutputInfo>) - Method in class io.prestosql.execution.QueryStateMachine.QueryOutputManager
 
addOutputInfoListener(Consumer<QueryExecution.QueryOutputInfo>) - Method in class io.prestosql.execution.SqlQueryExecution
 
addPage(Page) - Method in class io.prestosql.operator.BigintGroupByHash
 
addPage(Page) - Method in class io.prestosql.operator.ChannelSet.ChannelSetBuilder
 
addPage(Page) - Method in class io.prestosql.operator.exchange.LocalExchangeSink
 
addPage(Page) - Method in interface io.prestosql.operator.GroupByHash
 
addPage(Page) - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
addPage(Page) - Method in class io.prestosql.operator.NestedLoopJoinPagesBuilder
 
addPage(Page) - Method in class io.prestosql.operator.NoChannelGroupByHash
 
addPage(Page) - Method in class io.prestosql.operator.PagesIndex
 
addPage(Page) - Method in class io.prestosql.server.protocol.QueryResultRows.Builder
 
addPages(HttpPageBufferClient, List<SerializedPage>) - Method in interface io.prestosql.operator.HttpPageBufferClient.ClientCallback
 
addPages(List<Page>) - Method in class io.prestosql.server.protocol.QueryResultRows.Builder
 
addParametricType(ParametricType) - Method in class io.prestosql.metadata.MetadataManager
 
addPartialComponents(LocalCostEstimate, LocalCostEstimate, LocalCostEstimate...) - Static method in class io.prestosql.cost.LocalCostEstimate
Sums partial cost estimates of some (single) plan node.
addPartitioningProvider(CatalogName, ConnectorNodePartitioningProvider) - Method in class io.prestosql.sql.planner.NodePartitioningManager
 
addPasswordAuthenticatorFactory(PasswordAuthenticatorFactory) - Method in class io.prestosql.server.security.PasswordAuthenticatorManager
 
addPipelineContext(int, boolean, boolean, boolean) - Method in class io.prestosql.operator.TaskContext
 
addPreparedStatement(String, String) - Method in class io.prestosql.execution.QueryStateMachine
 
addPreparedStatement(String, String) - Method in class io.prestosql.Session.SessionBuilder
 
addProcedures(CatalogName, Collection<Procedure>) - Method in class io.prestosql.metadata.ProcedureRegistry
 
addQuery(T) - Method in class io.prestosql.execution.QueryTracker
 
addQueryInfoStateChangeListener(StateMachine.StateChangeListener<QueryInfo>) - Method in class io.prestosql.execution.QueryStateMachine
Add a listener for the final query info.
addReferencedFields(Multimap<NodeRef<Node>, Field>) - Method in class io.prestosql.sql.analyzer.Analysis
 
addRelationCoercion(Relation, Type[]) - Method in class io.prestosql.sql.analyzer.Analysis
 
addResetSessionProperties(String) - Method in class io.prestosql.execution.QueryStateMachine
 
addResolvedFunction(FunctionCall, ResolvedFunction, String) - Method in class io.prestosql.sql.analyzer.Analysis
 
addRowFilter(Table, Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
addScheduledNanos(long) - Method in class io.prestosql.execution.executor.TaskHandle
 
addSetRole(String, SelectedRole) - Method in class io.prestosql.execution.QueryStateMachine
 
addSetSessionProperties(String, String) - Method in class io.prestosql.execution.QueryStateMachine
 
addShortLongLong(long, Slice, int, boolean) - Static method in class io.prestosql.type.DecimalOperators
 
addShortShortLong(long, long, int, boolean) - Static method in class io.prestosql.type.DecimalOperators
 
addShortShortShort(long, long, long, long) - Static method in class io.prestosql.type.DecimalOperators
 
addSources(List<TaskSource>) - Method in class io.prestosql.execution.SqlTaskExecution
 
addSplit(Split) - Method in class io.prestosql.operator.ExchangeOperator
 
addSplit(Split) - Method in class io.prestosql.operator.index.IndexSourceOperator
 
addSplit(Split) - Method in class io.prestosql.operator.MergeOperator
 
addSplit(Split) - Method in interface io.prestosql.operator.SourceOperator
 
addSplit(Split) - Method in class io.prestosql.operator.TableScanOperator
 
addSplit(Split) - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
addSplit(Split) - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
addSplits(Multimap<PlanNodeId, Split>) - Method in interface io.prestosql.execution.RemoteTask
 
addSplits(Multimap<PlanNodeId, Split>) - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
addStateChangeListener(StateMachine.StateChangeListener<BufferState>) - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
addStateChangeListener(StateMachine.StateChangeListener<BufferState>) - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
addStateChangeListener(StateMachine.StateChangeListener<BufferState>) - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
addStateChangeListener(StateMachine.StateChangeListener<BufferState>) - Method in interface io.prestosql.execution.buffer.OutputBuffer
Add a listener which fires anytime the buffer state changes.
addStateChangeListener(StateMachine.StateChangeListener<BufferState>) - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
addStateChangeListener(StateMachine.StateChangeListener<QueryState>) - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
addStateChangeListener(StateMachine.StateChangeListener<QueryState>) - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
addStateChangeListener(StateMachine.StateChangeListener<QueryState>) - Method in class io.prestosql.execution.DataDefinitionExecution
 
addStateChangeListener(StateMachine.StateChangeListener<QueryState>) - Method in interface io.prestosql.execution.ManagedQueryExecution
Listener is always notified asynchronously using a dedicated notification thread pool so, care should be taken to avoid leaking this when adding a listener in a constructor.
addStateChangeListener(StateMachine.StateChangeListener<QueryState>) - Method in interface io.prestosql.execution.QueryExecution
 
addStateChangeListener(StateMachine.StateChangeListener<QueryState>) - Method in class io.prestosql.execution.QueryStateMachine
Listener is always notified asynchronously using a dedicated notification thread pool so, care should be taken to avoid leaking this when adding a listener in a constructor.
addStateChangeListener(StateMachine.StateChangeListener<QueryState>) - Method in class io.prestosql.execution.SqlQueryExecution
 
addStateChangeListener(StateMachine.StateChangeListener<StageState>) - Method in class io.prestosql.execution.SqlStageExecution
Listener is always notified asynchronously using a dedicated notification thread pool so, care should be taken to avoid leaking this when adding a listener in a constructor.
addStateChangeListener(StateMachine.StateChangeListener<StageState>) - Method in class io.prestosql.execution.StageStateMachine
Listener is always notified asynchronously using a dedicated notification thread pool so, care should be taken to avoid leaking this when adding a listener in a constructor.
addStateChangeListener(StateMachine.StateChangeListener<TaskState>) - Method in class io.prestosql.execution.SqlTask
Listener is always notified asynchronously using a dedicated notification thread pool so, care should be taken to avoid leaking this when adding a listener in a constructor.
addStateChangeListener(StateMachine.StateChangeListener<TaskState>) - Method in class io.prestosql.execution.TaskStateMachine
Listener is always notified asynchronously using a dedicated notification thread pool so, care should be taken to avoid leaking this when adding a listener in a constructor.
addStateChangeListener(StateMachine.StateChangeListener<TaskStatus>) - Method in interface io.prestosql.execution.RemoteTask
Listener is always notified asynchronously using a dedicated notification thread pool so, care should be taken to avoid leaking this when adding a listener in a constructor.
addStateChangeListener(StateMachine.StateChangeListener<TaskStatus>) - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
addStateChangeListener(StateMachine.StateChangeListener<T>) - Method in class io.prestosql.execution.StateMachine
Adds a listener to be notified when the state instance changes according to .equals().
addStateChangeListener(TaskId, StateMachine.StateChangeListener<TaskState>) - Method in class io.prestosql.execution.SqlTaskManager
 
addStateChangeListener(TaskId, StateMachine.StateChangeListener<TaskState>) - Method in interface io.prestosql.execution.TaskManager
Adds a state change listener to the specified task.
addStateChangeListener(QueryId, StateMachine.StateChangeListener<QueryState>) - Method in interface io.prestosql.execution.QueryManager
Add a listener that fires each time the query state changes.
addStateChangeListener(QueryId, StateMachine.StateChangeListener<QueryState>) - Method in class io.prestosql.execution.SqlQueryManager
 
addStatsAndCollapseDistinctValues(PlanNodeStatsEstimate, PlanNodeStatsEstimate) - Static method in class io.prestosql.cost.PlanNodeStatsEstimateMath
 
addStatsAndMaxDistinctValues(PlanNodeStatsEstimate, PlanNodeStatsEstimate) - Static method in class io.prestosql.cost.PlanNodeStatsEstimateMath
 
addStatsAndSumDistinctValues(PlanNodeStatsEstimate, PlanNodeStatsEstimate) - Static method in class io.prestosql.cost.PlanNodeStatsEstimateMath
 
addSymbolStatistics(Symbol, SymbolStatsEstimate) - Method in class io.prestosql.cost.PlanNodeStatsEstimate.Builder
 
addSymbolStatistics(Map<Symbol, SymbolStatsEstimate>) - Method in class io.prestosql.cost.PlanNodeStatsEstimate.Builder
 
addSystemAccessControl(SystemAccessControl) - Method in class io.prestosql.security.AccessControlManager
 
addSystemAccessControlFactory(SystemAccessControlFactory) - Method in class io.prestosql.security.AccessControlManager
 
addSystemSessionProperties(List<PropertyMetadata<?>>) - Method in class io.prestosql.metadata.SessionPropertyManager
 
addSystemSessionProperty(PropertyMetadata<?>) - Method in class io.prestosql.metadata.SessionPropertyManager
 
addTableColumnReferences(AccessControl, Identity, Multimap<QualifiedObjectName, String>) - Method in class io.prestosql.sql.analyzer.Analysis
 
addTableStatistic(TableStatisticType, T) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.Builder
 
addTask(TaskId, DoubleSupplier, int, Duration, OptionalInt) - Method in class io.prestosql.execution.executor.TaskExecutor
 
addTask(InternalNode, RemoteTask) - Method in class io.prestosql.execution.NodeTaskMap
 
addTaskContext(TaskStateMachine, Session, Runnable, boolean, boolean, OptionalInt) - Method in class io.prestosql.memory.QueryContext
 
addTaskDynamicFilters(TaskId, Map<DynamicFilterId, Domain>) - Method in class io.prestosql.server.DynamicFilterService
 
addTo(long, long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
Adds an increment to value currently associated with a key.
addTo(long, long, long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Adds an increment to value currently associated with a key.
addToTotalSpilledBytes(long) - Method in class io.prestosql.spiller.SpillerStats
 
addType(Type) - Method in class io.prestosql.metadata.MetadataManager
 
addType(TypeSignature) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
addTypes(Map<NodeRef<Expression>, Type>) - Method in class io.prestosql.sql.analyzer.Analysis
 
advance() - Method in class io.prestosql.operator.RowReferencePageManager.LoadCursor
 
advanceNextPosition() - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
advanceNextPosition() - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
advanceNextPosition() - Method in class io.prestosql.operator.JoinProbe
 
AesSpillCipher - Class in io.prestosql.spiller
 
AesSpillCipher() - Constructor for class io.prestosql.spiller.AesSpillCipher
 
aggregate(Class<?>) - Method in class io.prestosql.metadata.FunctionListBuilder
 
AGGREGATE - io.prestosql.metadata.FunctionKind
 
aggregateBasicStageStats(Iterable<BasicStageStats>) - Static method in class io.prestosql.execution.BasicStageStats
 
AggregateNativeContainerType(Class<?>, boolean) - Constructor for class io.prestosql.operator.aggregation.AggregationImplementation.AggregateNativeContainerType
 
aggregateRevocableMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
aggregates(Class<?>) - Method in class io.prestosql.metadata.FunctionListBuilder
 
aggregateStageStats(List<StageInfo>) - Static method in class io.prestosql.sql.planner.planprinter.PlanNodeStatsSummarizer
 
aggregateSystemMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
aggregateTaskStats(List<TaskInfo>) - Static method in class io.prestosql.sql.planner.planprinter.PlanNodeStatsSummarizer
 
aggregateUserMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
AggregateWindowFunction - Class in io.prestosql.operator.window
 
aggregation() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
Aggregation() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Aggregation
 
Aggregation(ResolvedFunction, List<Expression>, boolean, Optional<Symbol>, Optional<OrderingScheme>, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
AGGREGATION_OPERATOR_UNSPILL_MEMORY_LIMIT - Static variable in class io.prestosql.SystemSessionProperties
 
aggregationExpressionRewrite() - Method in class io.prestosql.sql.planner.iterative.rule.ExpressionRewriteRuleSet
 
AggregationFromAnnotationsParser - Class in io.prestosql.operator.aggregation
 
AggregationFunctionMetadata - Class in io.prestosql.metadata
 
AggregationFunctionMetadata(boolean, Optional<TypeSignature>) - Constructor for class io.prestosql.metadata.AggregationFunctionMetadata
 
AggregationHeader - Class in io.prestosql.operator.aggregation
 
AggregationHeader(String, Optional<String>, boolean, boolean, boolean) - Constructor for class io.prestosql.operator.aggregation.AggregationHeader
 
AggregationImplementation - Class in io.prestosql.operator.aggregation
 
AggregationImplementation(Signature, Class<?>, Class<?>, MethodHandle, Optional<MethodHandle>, MethodHandle, MethodHandle, List<AggregationImplementation.AggregateNativeContainerType>, List<ImplementationDependency>, List<ImplementationDependency>, List<ImplementationDependency>, List<ImplementationDependency>, List<AggregationMetadata.ParameterMetadata.ParameterType>) - Constructor for class io.prestosql.operator.aggregation.AggregationImplementation
 
AggregationImplementation.AggregateNativeContainerType - Class in io.prestosql.operator.aggregation
 
AggregationImplementation.Parser - Class in io.prestosql.operator.aggregation
 
AggregationMetadata - Class in io.prestosql.operator.aggregation
 
AggregationMetadata(String, List<AggregationMetadata.ParameterMetadata>, MethodHandle, Optional<MethodHandle>, MethodHandle, MethodHandle, List<AggregationMetadata.AccumulatorStateDescriptor>, Type) - Constructor for class io.prestosql.operator.aggregation.AggregationMetadata
 
AggregationMetadata(String, List<AggregationMetadata.ParameterMetadata>, MethodHandle, Optional<MethodHandle>, MethodHandle, MethodHandle, List<AggregationMetadata.AccumulatorStateDescriptor>, Type, List<Class<?>>) - Constructor for class io.prestosql.operator.aggregation.AggregationMetadata
 
AggregationMetadata.AccumulatorStateDescriptor - Class in io.prestosql.operator.aggregation
 
AggregationMetadata.ParameterMetadata - Class in io.prestosql.operator.aggregation
 
AggregationMetadata.ParameterMetadata.ParameterType - Enum in io.prestosql.operator.aggregation
 
AggregationNode - Class in io.prestosql.sql.planner.plan
 
AggregationNode(PlanNodeId, PlanNode, Map<Symbol, AggregationNode.Aggregation>, AggregationNode.GroupingSetDescriptor, List<Symbol>, AggregationNode.Step, Optional<Symbol>, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.AggregationNode
 
AggregationNode.Aggregation - Class in io.prestosql.sql.planner.plan
 
AggregationNode.GroupingSetDescriptor - Class in io.prestosql.sql.planner.plan
 
AggregationNode.Step - Enum in io.prestosql.sql.planner.plan
 
AggregationOperator - Class in io.prestosql.operator
Group input data and produce a single block for each sequence of identical values.
AggregationOperator(OperatorContext, AggregationNode.Step, List<AccumulatorFactory>, boolean) - Constructor for class io.prestosql.operator.AggregationOperator
 
AggregationOperator.AggregationOperatorFactory - Class in io.prestosql.operator
 
AggregationOperatorFactory(int, PlanNodeId, AggregationNode.Step, List<AccumulatorFactory>, boolean) - Constructor for class io.prestosql.operator.AggregationOperator.AggregationOperatorFactory
 
AggregationStatsRule - Class in io.prestosql.cost
 
AggregationStatsRule(StatsNormalizer) - Constructor for class io.prestosql.cost.AggregationStatsRule
 
AggregationUtils - Class in io.prestosql.operator.aggregation
 
ALIVE - io.prestosql.failuredetector.FailureDetector.State
 
AllAtOnceExecutionPolicy - Class in io.prestosql.execution.scheduler
 
AllAtOnceExecutionPolicy() - Constructor for class io.prestosql.execution.scheduler.AllAtOnceExecutionPolicy
 
AllAtOnceExecutionSchedule - Class in io.prestosql.execution.scheduler
 
AllAtOnceExecutionSchedule(Collection<SqlStageExecution>) - Constructor for class io.prestosql.execution.scheduler.AllAtOnceExecutionSchedule
 
AllFunctionsResolved - Class in io.prestosql.sql.planner.sanity
 
AllFunctionsResolved() - Constructor for class io.prestosql.sql.planner.sanity.AllFunctionsResolved
 
allMatchBoolean(Type, Block, BooleanToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayAllMatchFunction
 
allMatchDouble(Type, Block, DoubleToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayAllMatchFunction
 
allMatchLong(Type, Block, LongToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayAllMatchFunction
 
allMatchObject(Type, Block, ObjectToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayAllMatchFunction
 
allNodes() - Method in class io.prestosql.execution.scheduler.DynamicSplitPlacementPolicy
 
allNodes() - Method in class io.prestosql.execution.scheduler.FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy
 
allNodes() - Method in interface io.prestosql.execution.scheduler.NodeSelector
 
allNodes() - Method in interface io.prestosql.execution.scheduler.SplitPlacementPolicy
 
allNodes() - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
allNodes() - Method in class io.prestosql.execution.scheduler.UniformNodeSelector
 
AllNodes - Class in io.prestosql.metadata
 
AllNodes(Set<InternalNode>, Set<InternalNode>, Set<InternalNode>, Set<InternalNode>) - Constructor for class io.prestosql.metadata.AllNodes
 
allocateId(IntFunction<T>) - Method in class io.prestosql.operator.IdRegistry
Provides a new ID referencing the provided object.
allocateRowId() - Method in class io.prestosql.operator.RowReferencePageManager.LoadCursor
 
ALLOW_PUSHDOWN_INTO_CONNECTORS - Static variable in class io.prestosql.SystemSessionProperties
 
AllowAllAccessControl - Class in io.prestosql.security
 
AllowAllAccessControl() - Constructor for class io.prestosql.security.AllowAllAccessControl
 
ALLOWED - io.prestosql.sql.analyzer.CorrelationSupport
 
allTypes() - Method in class io.prestosql.sql.planner.TypeProvider
 
ambiguousAttributeException(Expression, QualifiedName) - Static method in class io.prestosql.sql.analyzer.SemanticExceptions
 
Analysis - Class in io.prestosql.sql.analyzer
 
Analysis(Statement, Map<NodeRef<Parameter>, Expression>, boolean) - Constructor for class io.prestosql.sql.analyzer.Analysis
 
Analysis.AccessControlInfo - Class in io.prestosql.sql.analyzer
 
Analysis.Create - Class in io.prestosql.sql.analyzer
 
Analysis.GroupingSetAnalysis - Class in io.prestosql.sql.analyzer
 
Analysis.Insert - Class in io.prestosql.sql.analyzer
 
Analysis.JoinUsingAnalysis - Class in io.prestosql.sql.analyzer
 
Analysis.RefreshMaterializedViewAnalysis - Class in io.prestosql.sql.analyzer
 
Analysis.SelectExpression - Class in io.prestosql.sql.analyzer
 
Analysis.UnnestAnalysis - Class in io.prestosql.sql.analyzer
 
analyze(Session, Statement, List<Expression>, WarningCollector) - Method in class io.prestosql.sql.analyzer.QueryExplainer
 
analyze(Expression, Scope) - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
analyze(Statement) - Method in class io.prestosql.sql.analyzer.Analyzer
 
analyze(Statement, boolean) - Method in class io.prestosql.sql.analyzer.Analyzer
 
analyzeExpression(Session, Metadata, GroupProvider, AccessControl, SqlParser, Scope, Analysis, Expression, WarningCollector, CorrelationSupport) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
analyzeExpressions(Session, Metadata, GroupProvider, AccessControl, SqlParser, TypeProvider, Iterable<Expression>, Map<NodeRef<Parameter>, Expression>, WarningCollector, boolean) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
AnalyzeMetadata - Class in io.prestosql.metadata
 
AnalyzeMetadata(TableStatisticsMetadata, TableHandle) - Constructor for class io.prestosql.metadata.AnalyzeMetadata
 
AnalyzePropertiesSystemTable - Class in io.prestosql.connector.system
 
AnalyzePropertiesSystemTable(TransactionManager, Metadata) - Constructor for class io.prestosql.connector.system.AnalyzePropertiesSystemTable
 
AnalyzePropertyManager - Class in io.prestosql.metadata
 
AnalyzePropertyManager() - Constructor for class io.prestosql.metadata.AnalyzePropertyManager
 
Analyzer - Class in io.prestosql.sql.analyzer
 
Analyzer(Session, Metadata, SqlParser, GroupProvider, AccessControl, Optional<QueryExplainer>, List<Expression>, Map<NodeRef<Parameter>, Expression>, WarningCollector, StatsCalculator) - Constructor for class io.prestosql.sql.analyzer.Analyzer
 
AnalyzeTableHandle - Class in io.prestosql.metadata
 
AnalyzeTableHandle(CatalogName, ConnectorTransactionHandle, ConnectorTableHandle) - Constructor for class io.prestosql.metadata.AnalyzeTableHandle
 
and(boolean, boolean) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
and(Expression...) - Static method in class io.prestosql.sql.ExpressionUtils
 
and(Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
AND - io.prestosql.sql.relational.SpecialForm.Form
 
AndCodeGenerator - Class in io.prestosql.sql.gen
 
AndCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.AndCodeGenerator
 
AnnotatedResourceAccessTypeLoader - Class in io.prestosql.server.security
 
AnnotatedResourceAccessTypeLoader() - Constructor for class io.prestosql.server.security.AnnotatedResourceAccessTypeLoader
 
anonymous() - Static method in class io.prestosql.sql.analyzer.RelationId
Creates RelationId equal only to itself
any() - Static method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
anyMatchBoolean(Type, Block, BooleanToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayAnyMatchFunction
 
anyMatchDouble(Type, Block, DoubleToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayAnyMatchFunction
 
anyMatchLong(Type, Block, LongToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayAnyMatchFunction
 
anyMatchObject(Type, Block, ObjectToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayAnyMatchFunction
 
anyUserResource(AnnotatedElement) - Method in class io.prestosql.server.security.ResourceSecurityBinder
 
append(JsonParser, BlockBuilder) - Method in interface io.prestosql.util.JsonUtil.BlockBuilderAppender
 
appendAtChannel(int, Block, int) - Method in class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
 
appendDetails(String, Object...) - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
appendDetailsLine(String, Object...) - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
appendElement(Type, Block, boolean) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
appendElement(Type, Block, double) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
appendElement(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
appendElement(Type, Block, Slice) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
appendElement(Type, Block, Object) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
appendNullForBuild(JoinProbe) - Method in class io.prestosql.operator.LookupJoinPageBuilder
append the index for the probe and append nulls for the build
appendRow(JoinProbe, LookupSource, long) - Method in class io.prestosql.operator.LookupJoinPageBuilder
append the index for the probe and copy the row for the build
appendTo(int, int, BlockBuilder) - Method in class io.prestosql.operator.PagesIndex
 
appendTo(int, int, BlockBuilder) - Method in class io.prestosql.operator.window.PagesWindowIndex
 
appendTo(int, int, PageBuilder, int) - Method in interface io.prestosql.operator.PagesHashStrategy
Appends all values at the specified position to the page builder starting at outputChannelOffset.
appendTo(int, int, PageBuilder, int) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
appendTo(int, PageBuilder, int) - Method in class io.prestosql.operator.PagesRTreeIndex
 
appendTo(int, PageBuilder, int) - Method in interface io.prestosql.operator.PagesSpatialIndex
 
appendTo(long, PageBuilder, int) - Method in interface io.prestosql.operator.index.IndexedData
 
appendTo(long, PageBuilder, int) - Method in class io.prestosql.operator.index.IndexLookupSource
 
appendTo(long, PageBuilder, int) - Method in class io.prestosql.operator.index.IndexSnapshot
 
appendTo(long, PageBuilder, int) - Method in class io.prestosql.operator.index.StreamingIndexedData
 
appendTo(long, PageBuilder, int) - Method in class io.prestosql.operator.JoinHash
 
appendTo(long, PageBuilder, int) - Method in interface io.prestosql.operator.LookupSource
 
appendTo(long, PageBuilder, int) - Method in class io.prestosql.operator.OuterLookupSource
 
appendTo(long, PageBuilder, int) - Method in class io.prestosql.operator.PagesHash
 
appendTo(long, PageBuilder, int) - Method in class io.prestosql.operator.PartitionedLookupSource
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.CodePointsType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.FunctionType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.IpAddressType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.JoniRegexpType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.JsonPathType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.JsonType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.LikePatternType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.Re2JRegexpType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.setdigest.SetDigestType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.TDigestType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.UnknownType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.type.UuidType
 
appendTo(PageBuilder, List<Integer>, List<Type>) - Method in class io.prestosql.util.MergeSortedPages.PageWithPosition
 
appendToNext(PageBuilder, int) - Method in interface io.prestosql.operator.OuterPositionIterator
 
appendValuesTo(int, PageBuilder, int) - Method in class io.prestosql.operator.BigintGroupByHash
 
appendValuesTo(int, PageBuilder, int) - Method in interface io.prestosql.operator.GroupByHash
 
appendValuesTo(int, PageBuilder, int) - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
appendValuesTo(int, PageBuilder, int) - Method in class io.prestosql.operator.NoChannelGroupByHash
 
APPLICABLE_ROLES - io.prestosql.connector.informationschema.InformationSchemaTable
 
apply() - Method in interface io.prestosql.operator.scalar.InvokeFunction.InvokeLambda
 
apply() - Method in interface io.prestosql.operator.scalar.TryFunction.TryBooleanLambda
 
apply() - Method in interface io.prestosql.operator.scalar.TryFunction.TryDoubleLambda
 
apply() - Method in interface io.prestosql.operator.scalar.TryFunction.TryLongLambda
 
apply() - Method in interface io.prestosql.operator.scalar.TryFunction.TryObjectLambda
 
apply(OGCGeometry, OGCGeometry, OptionalDouble) - Method in interface io.prestosql.operator.SpatialIndexBuilderOperator.SpatialPredicate
 
apply(Page) - Method in class io.prestosql.operator.exchange.PageChannelSelector
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.AddIntermediateAggregations
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ImplementFilteredAggregations
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MultipleDistinctAggregationToMarkDistinct
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneAggregationSourceColumns
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneCountAggregationOverScalar
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneDistinctAggregation
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneOrderByInAggregation
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushAggregationIntoTableScan
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushAggregationThroughOuterJoin
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushPartialAggregationThroughExchange
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushPartialAggregationThroughJoin
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RewriteSpatialPartitioningAggregation
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.SimplifyCountOverConstant
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.SingleDistinctAggregationToGroupBy
 
apply(ApplyNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneApplyCorrelation
 
apply(ApplyNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneApplySourceColumns
 
apply(ApplyNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantExists
 
apply(ApplyNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveUnreferencedScalarApplyNodes
 
apply(ApplyNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin
 
apply(ApplyNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformExistsApplyToCorrelatedJoin
 
apply(ApplyNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedInPredicateSubqueryToSemiJoin
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneCorrelatedJoinCorrelation
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveUnreferencedScalarSubqueries
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedDistinctAggregationWithoutProjection
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedDistinctAggregationWithProjection
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGlobalAggregationWithoutProjection
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGlobalAggregationWithProjection
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGroupedAggregationWithoutProjection
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGroupedAggregationWithProjection
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedJoinToJoin
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedScalarSubquery
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedSingleRowSubqueryToProject
 
apply(CorrelatedJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedSubqueryToJoin
 
apply(DeleteNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneDeleteSourceColumns
 
apply(DistinctLimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneDistinctLimitSourceColumns
 
apply(DistinctLimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDistinctLimitIntoTableScan
 
apply(DistinctLimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantDistinctLimit
 
apply(EnforceSingleRowNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantEnforceSingleRowNode
 
apply(ExceptNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ImplementExceptAll
 
apply(ExceptNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ImplementExceptDistinctAsUnion
 
apply(ExceptNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MergeExcept
 
apply(ExceptNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneExceptSourceColumns
 
apply(ExchangeNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneExchangeSourceColumns
 
apply(ExchangeNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushRemoteExchangeThroughAssignUniqueId
 
apply(ExplainAnalyzeNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneExplainAnalyzeSourceColumns
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ExtractDereferencesFromFilterAboveScan
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins.ExtractSpatialInnerJoin
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MergeFilters
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushPredicateIntoTableScan
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushPredicateThroughProjectIntoRowNumber
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushPredicateThroughProjectIntoWindow
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantTableScanPredicate
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveTrivialFilters
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformFilteringSemiJoinToInnerJoin
 
apply(GroupIdNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneGroupIdSourceColumns
 
apply(IntersectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ImplementIntersectAll
 
apply(IntersectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ImplementIntersectDistinctAsUnion
 
apply(IntersectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MergeIntersect
 
apply(IntersectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneIntersectSourceColumns
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.DetermineJoinDistributionType
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.EliminateCrossJoins
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins.ExtractSpatialLeftJoin
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneJoinChildrenColumns
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantCrossJoin
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantJoin
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ReorderJoins
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ImplementLimitWithTies
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MergeLimitOverProjectWithSort
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MergeLimits
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MergeLimitWithDistinct
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MergeLimitWithSort
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MergeLimitWithTopN
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitIntoTableScan
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughMarkDistinct
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughOffset
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughOuterJoin
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughProject
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughSemiJoin
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughUnion
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantLimit
 
apply(OffsetNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ImplementOffset
 
apply(OffsetNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushOffsetThroughProject
 
apply(OffsetNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantOffset
 
apply(OutputNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneOutputSourceColumns
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.InlineProjections
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ProjectOffPushDownRule
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughAssignUniqueId
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughLimit
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughMarkDistinct
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughRowNumber
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughSort
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughTopN
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughTopNRowNumber
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughWindow
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughFilter
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughJoin
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughProject
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughSemiJoin
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughUnnest
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushProjectionIntoTableScan
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushProjectionThroughExchange
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushProjectionThroughUnion
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantIdentityProjections
 
apply(SampleNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.EvaluateZeroSample
 
apply(SampleNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ImplementBernoulliSampleAsFilter
 
apply(SampleNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushSampleIntoTableScan
 
apply(SampleNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveFullSample
 
apply(SemiJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.DetermineSemiJoinDistributionType
 
apply(SemiJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneSemiJoinFilteringSourceColumns
 
apply(SemiJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveAggregationInSemiJoin
 
apply(SortNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantSort
 
apply(SpatialJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneSpatialJoinChildrenColumns
 
apply(TableFinishNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushDeleteIntoConnector
 
apply(TableFinishNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveEmptyDelete
 
apply(TableScanNode) - Method in class io.prestosql.sql.planner.planprinter.TableInfoSupplier
 
apply(TableScanNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ApplyTableScanRedirection
 
apply(TableWriterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneTableWriterSourceColumns
 
apply(TableWriterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushTableWriteThroughUnion
 
apply(TopNNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.CreatePartialTopN
 
apply(TopNNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushTopNIntoTableScan
 
apply(TopNNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushTopNThroughOuterJoin
 
apply(TopNNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushTopNThroughProject
 
apply(TopNNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushTopNThroughUnion
 
apply(TopNNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantTopN
 
apply(UnionNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MergeUnion
 
apply(UnionNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneUnionSourceColumns
 
apply(UnnestNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneUnnestSourceColumns
 
apply(Boolean) - Method in interface io.prestosql.operator.scalar.BooleanToBooleanFunction
 
apply(Boolean, Boolean) - Method in interface io.prestosql.operator.scalar.ArraySortComparatorFunction.ComparatorBooleanLambda
 
apply(Double) - Method in interface io.prestosql.operator.scalar.DoubleToBooleanFunction
 
apply(Double, Double) - Method in interface io.prestosql.operator.scalar.ArraySortComparatorFunction.ComparatorDoubleLambda
 
apply(Long) - Method in interface io.prestosql.operator.scalar.LongToBooleanFunction
 
apply(Long, Long) - Method in interface io.prestosql.operator.scalar.ArraySortComparatorFunction.ComparatorLongLambda
 
apply(Object) - Method in interface io.prestosql.operator.scalar.ObjectToBooleanFunction
 
apply(Object) - Method in interface io.prestosql.sql.gen.lambda.UnaryFunctionInterface
 
apply(Object, UnaryFunctionInterface) - Static method in class io.prestosql.operator.scalar.ApplyFunction
 
apply(Object, Object) - Method in interface io.prestosql.operator.scalar.ArraySortComparatorFunction.ComparatorObjectLambda
 
apply(Object, Object) - Method in interface io.prestosql.sql.gen.lambda.BinaryFunctionInterface
 
apply(Object, Object, Object) - Method in interface io.prestosql.operator.scalar.MapZipWithFunction.MapZipWithLambda
 
apply(Object, Supplier<Object>) - Method in class io.prestosql.type.TypeOperatorsCache
 
apply(T, Captures, Rule.Context) - Method in interface io.prestosql.sql.planner.iterative.Rule
 
Apply() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Apply
 
APPLY_FUNCTION - Static variable in class io.prestosql.operator.scalar.ApplyFunction
 
applyAggregation(Session, TableHandle, List<AggregateFunction>, Map<String, ColumnHandle>, List<List<ColumnHandle>>) - Method in interface io.prestosql.metadata.Metadata
 
applyAggregation(Session, TableHandle, List<AggregateFunction>, Map<String, ColumnHandle>, List<List<ColumnHandle>>) - Method in class io.prestosql.metadata.MetadataManager
 
applyBoundVariables(Signature, FunctionBinding, int) - Static method in class io.prestosql.metadata.SignatureBinder
 
applyBoundVariables(TypeSignature, FunctionBinding) - Static method in class io.prestosql.metadata.SignatureBinder
 
applyBoundVariables(List<TypeSignature>, FunctionBinding) - Static method in class io.prestosql.metadata.SignatureBinder
 
applyComparison(Domain) - Method in class io.prestosql.sql.DynamicFilters.Descriptor
 
applyDelete(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Push delete into connector
applyDelete(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
applyFilter(Session, TableHandle, Constraint) - Method in interface io.prestosql.metadata.Metadata
 
applyFilter(Session, TableHandle, Constraint) - Method in class io.prestosql.metadata.MetadataManager
 
applyFilter(ConnectorSession, ConnectorTableHandle, Constraint) - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
applyFilter(ConnectorSession, ConnectorTableHandle, Constraint) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
applyFilter(ConnectorSession, Constraint) - Method in class io.prestosql.connector.system.jdbc.ColumnJdbcTable
 
applyFilter(ConnectorSession, Constraint) - Method in class io.prestosql.connector.system.jdbc.JdbcTable
 
ApplyFunction - Class in io.prestosql.operator.scalar
This scalar function exists primarily to test lambda expression support.
applyLimit(Session, TableHandle, long) - Method in interface io.prestosql.metadata.Metadata
 
applyLimit(Session, TableHandle, long) - Method in class io.prestosql.metadata.MetadataManager
 
applyLimit(ConnectorSession, ConnectorTableHandle, long) - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
applyNode() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
ApplyNode - Class in io.prestosql.sql.planner.plan
 
ApplyNode(PlanNodeId, PlanNode, PlanNode, Assignments, List<Symbol>, Node) - Constructor for class io.prestosql.sql.planner.plan.ApplyNode
 
applyProjection(Session, TableHandle, List<ConnectorExpression>, Map<String, ColumnHandle>) - Method in interface io.prestosql.metadata.Metadata
 
applyProjection(Session, TableHandle, List<ConnectorExpression>, Map<String, ColumnHandle>) - Method in class io.prestosql.metadata.MetadataManager
 
applySample(Session, TableHandle, SampleType, double) - Method in interface io.prestosql.metadata.Metadata
 
applySample(Session, TableHandle, SampleType, double) - Method in class io.prestosql.metadata.MetadataManager
 
applySaturatedCasts(Metadata, TypeOperators, Session, Domain, Type) - Static method in class io.prestosql.sql.planner.DomainCoercer
 
applyTableScanRedirect(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Returns the result of redirecting the table scan on a given table to a different table.
applyTableScanRedirect(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
ApplyTableScanRedirection - Class in io.prestosql.sql.planner.iterative.rule
 
ApplyTableScanRedirection(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.ApplyTableScanRedirection
 
applyTopN(Session, TableHandle, long, List<SortItem>, Map<String, ColumnHandle>) - Method in interface io.prestosql.metadata.Metadata
 
applyTopN(Session, TableHandle, long, List<SortItem>, Map<String, ColumnHandle>) - Method in class io.prestosql.metadata.MetadataManager
 
ApproximateCountDistinctAggregation - Class in io.prestosql.operator.aggregation
 
ApproximateDoublePercentileAggregations - Class in io.prestosql.operator.aggregation
 
ApproximateDoublePercentileArrayAggregations - Class in io.prestosql.operator.aggregation
 
ApproximateLongPercentileAggregations - Class in io.prestosql.operator.aggregation
 
ApproximateLongPercentileArrayAggregations - Class in io.prestosql.operator.aggregation
 
ApproximateMostFrequentBucketDeserializer<K> - Interface in io.prestosql.operator.aggregation
 
ApproximateMostFrequentBucketSerializer<K> - Interface in io.prestosql.operator.aggregation
 
ApproximateMostFrequentHistogram<K> - Class in io.prestosql.operator.aggregation
Calculate the histogram approximately for topk elements based on the Space-Saving algorithm and the Stream-Summary data structure as described in: Efficient Computation of Frequent and Top-k Elements in Data Streams by Metwally, Agrawal, and Abbadi
ApproximateMostFrequentHistogram(int, int, ApproximateMostFrequentBucketSerializer<K>, ApproximateMostFrequentBucketDeserializer<K>) - Constructor for class io.prestosql.operator.aggregation.ApproximateMostFrequentHistogram
 
ApproximateMostFrequentHistogram(Slice, ApproximateMostFrequentBucketSerializer<K>, ApproximateMostFrequentBucketDeserializer<K>) - Constructor for class io.prestosql.operator.aggregation.ApproximateMostFrequentHistogram
 
ApproximateRealPercentileAggregations - Class in io.prestosql.operator.aggregation
 
ApproximateRealPercentileArrayAggregations - Class in io.prestosql.operator.aggregation
 
ApproximateSetAggregation - Class in io.prestosql.operator.aggregation
 
ARBITRARY - io.prestosql.execution.buffer.OutputBuffers.BufferType
 
ARBITRARY_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
ARBITRARY_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
ArbitraryAggregationFunction - Class in io.prestosql.operator.aggregation
 
ArbitraryAggregationFunction() - Constructor for class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
ArbitraryOutputBuffer - Class in io.prestosql.execution.buffer
A buffer that assigns pages to queues based on a first come, first served basis.
ArbitraryOutputBuffer(String, StateMachine<BufferState>, DataSize, Supplier<LocalMemoryContext>, Executor) - Constructor for class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
arbitraryPartition() - Static method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
areExpressionsEquivalent(Session, Expression, Expression, TypeProvider) - Method in class io.prestosql.sql.planner.optimizations.ExpressionEquivalence
 
areTypesAssignable(BoundSignature) - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
args - Variable in class io.prestosql.sql.gen.VarArgsToArrayAdapterGenerator.VarArgsToArrayAdapterState
Array of argument, such as long[], Block[]
ArgumentBinding(Expression, NullableValue) - Constructor for class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
argumentDefinitions(FunctionArgumentDefinition...) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
argumentProperties(InvocationConvention.InvocationArgumentConvention...) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.ChoiceBuilder
 
argumentTypes(TypeSignature...) - Method in class io.prestosql.metadata.SignatureBuilder
 
argumentTypes(List<TypeSignature>) - Method in class io.prestosql.metadata.SignatureBuilder
 
arithmeticFunction(ArithmeticBinaryExpression.Operator, Type, Type) - Method in class io.prestosql.sql.relational.StandardFunctionResolution
 
array - Variable in class io.prestosql.util.LongBigArrayFIFOQueue
The backing array.
ARRAY - Static variable in class io.prestosql.type.ArrayParametricType
 
ARRAY_AGG - Static variable in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
ARRAY_CONCAT_FUNCTION - Static variable in class io.prestosql.operator.scalar.ArrayConcatFunction
 
ARRAY_CONSTRUCTOR - Static variable in class io.prestosql.operator.scalar.ArrayConstructor
 
ARRAY_FLATTEN_FUNCTION - Static variable in class io.prestosql.operator.scalar.ArrayFlattenFunction
 
ARRAY_JOIN - Static variable in class io.prestosql.operator.scalar.ArrayJoin
 
ARRAY_JOIN_WITH_NULL_REPLACEMENT - Static variable in class io.prestosql.operator.scalar.ArrayJoin
 
ARRAY_REDUCE_FUNCTION - Static variable in class io.prestosql.operator.scalar.ArrayReduceFunction
 
ARRAY_SUBSCRIPT - Static variable in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
ARRAY_TO_ARRAY_CAST - Static variable in class io.prestosql.operator.scalar.ArrayToArrayCast
 
ARRAY_TO_ELEMENT_CONCAT_FUNCTION - Static variable in class io.prestosql.operator.scalar.ArrayToElementConcatFunction
 
ARRAY_TO_JSON - Static variable in class io.prestosql.operator.scalar.ArrayToJsonCast
 
ARRAY_TRANSFORM_FUNCTION - Static variable in class io.prestosql.operator.scalar.ArrayTransformFunction
 
ArrayAggregationFunction - Class in io.prestosql.operator.aggregation.arrayagg
 
ArrayAggregationState - Interface in io.prestosql.operator.aggregation.arrayagg
 
ArrayAggregationStateConsumer - Interface in io.prestosql.operator.aggregation.arrayagg
 
ArrayAggregationStateFactory - Class in io.prestosql.operator.aggregation.arrayagg
 
ArrayAggregationStateFactory(Type) - Constructor for class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateFactory
 
ArrayAggregationStateSerializer - Class in io.prestosql.operator.aggregation.arrayagg
 
ArrayAggregationStateSerializer(Type) - Constructor for class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateSerializer
 
ArrayAllMatchFunction - Class in io.prestosql.operator.scalar
 
ArrayAnyMatchFunction - Class in io.prestosql.operator.scalar
 
arrayCardinality(Block) - Static method in class io.prestosql.operator.scalar.ArrayCardinalityFunction
 
ArrayCardinalityFunction - Class in io.prestosql.operator.scalar
 
ArrayCombinationsFunction - Class in io.prestosql.operator.scalar
 
ArrayConcatFunction - Class in io.prestosql.operator.scalar
 
ArrayConcatUtils - Class in io.prestosql.operator.scalar
 
arrayConstructor() - Static method in class io.prestosql.operator.scalar.ArrayFunctions
 
ArrayConstructor - Class in io.prestosql.operator.scalar
 
ArrayConstructor() - Constructor for class io.prestosql.operator.scalar.ArrayConstructor
 
ArrayContains - Class in io.prestosql.operator.scalar
 
ArrayContainsSequence - Class in io.prestosql.operator.scalar
 
ArrayDistinctFunction - Class in io.prestosql.operator.scalar
 
ArrayDistinctFunction(Type) - Constructor for class io.prestosql.operator.scalar.ArrayDistinctFunction
 
ArrayElementAtFunction - Class in io.prestosql.operator.scalar
 
ArrayExceptFunction - Class in io.prestosql.operator.scalar
 
ArrayFilterFunction - Class in io.prestosql.operator.scalar
 
ArrayFlattenFunction - Class in io.prestosql.operator.scalar
 
ArrayFunctions - Class in io.prestosql.operator.scalar
 
ArrayGeneratorUtils - Class in io.prestosql.sql.gen
 
ArrayIntersectFunction - Class in io.prestosql.operator.scalar
 
ArrayIntersectFunction(Type) - Constructor for class io.prestosql.operator.scalar.ArrayIntersectFunction
 
arrayJoin(MethodHandle, Object, ConnectorSession, Block, Slice) - Static method in class io.prestosql.operator.scalar.ArrayJoin
 
arrayJoin(MethodHandle, Object, ConnectorSession, Block, Slice, Slice) - Static method in class io.prestosql.operator.scalar.ArrayJoin
 
ArrayJoin - Class in io.prestosql.operator.scalar
 
ArrayJoin.ArrayJoinWithNullReplacement - Class in io.prestosql.operator.scalar
 
ArrayJoinWithNullReplacement() - Constructor for class io.prestosql.operator.scalar.ArrayJoin.ArrayJoinWithNullReplacement
 
ArrayMapBytecodeExpression - Class in io.prestosql.sql.gen
 
ArrayMapBytecodeExpression(Scope, CallSiteBinder, BytecodeExpression, Type, Type, Function<BytecodeExpression, BytecodeExpression>) - Constructor for class io.prestosql.sql.gen.ArrayMapBytecodeExpression
 
ArrayMaxFunction - Class in io.prestosql.operator.scalar
 
ArrayMinFunction - Class in io.prestosql.operator.scalar
 
ArrayNgramsFunction - Class in io.prestosql.operator.scalar
 
ArrayNoneMatchFunction - Class in io.prestosql.operator.scalar
 
ArrayParametricType - Class in io.prestosql.type
 
arrayPosition(Type, MethodHandle, Block, boolean) - Static method in class io.prestosql.operator.scalar.ArrayPositionFunction
 
arrayPosition(Type, MethodHandle, Block, double) - Static method in class io.prestosql.operator.scalar.ArrayPositionFunction
 
arrayPosition(Type, MethodHandle, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayPositionFunction
 
arrayPosition(Type, MethodHandle, Block, Object) - Static method in class io.prestosql.operator.scalar.ArrayPositionFunction
 
ArrayPositionFunction - Class in io.prestosql.operator.scalar
 
ArrayPositionLinks - Class in io.prestosql.operator
 
ArrayPositionLinks.FactoryBuilder - Class in io.prestosql.operator
 
ArrayReduceFunction - Class in io.prestosql.operator.scalar
 
ArrayRemoveFunction - Class in io.prestosql.operator.scalar
 
ArrayRemoveFunction(Type) - Constructor for class io.prestosql.operator.scalar.ArrayRemoveFunction
 
ArrayReverseFunction - Class in io.prestosql.operator.scalar
 
ArrayReverseFunction(Type) - Constructor for class io.prestosql.operator.scalar.ArrayReverseFunction
 
ArrayShuffleFunction - Class in io.prestosql.operator.scalar
 
ArrayShuffleFunction(Type) - Constructor for class io.prestosql.operator.scalar.ArrayShuffleFunction
 
ArraySliceFunction - Class in io.prestosql.operator.scalar
 
ArraySortComparatorFunction - Class in io.prestosql.operator.scalar
 
ArraySortComparatorFunction(Type) - Constructor for class io.prestosql.operator.scalar.ArraySortComparatorFunction
 
ArraySortComparatorFunction.ComparatorBooleanLambda - Interface in io.prestosql.operator.scalar
 
ArraySortComparatorFunction.ComparatorDoubleLambda - Interface in io.prestosql.operator.scalar
 
ArraySortComparatorFunction.ComparatorLongLambda - Interface in io.prestosql.operator.scalar
 
ArraySortComparatorFunction.ComparatorObjectLambda - Interface in io.prestosql.operator.scalar
 
ArraySortFunction - Class in io.prestosql.operator.scalar
 
ArraySortFunction(Type) - Constructor for class io.prestosql.operator.scalar.ArraySortFunction
 
arraysOverlap(BlockTypeOperators.BlockPositionComparison, Type, Block, Block) - Method in class io.prestosql.operator.scalar.ArraysOverlapFunction
 
ArraysOverlapFunction - Class in io.prestosql.operator.scalar
 
ArraysOverlapFunction(Type) - Constructor for class io.prestosql.operator.scalar.ArraysOverlapFunction
 
ArraysOverlapFunction.LongComparison - Interface in io.prestosql.operator.scalar
 
arraysOverlapInt(ArraysOverlapFunction.LongComparison, Type, Block, Block) - Method in class io.prestosql.operator.scalar.ArraysOverlapFunction
 
ArraySubscriptOperator - Class in io.prestosql.operator.scalar
 
ArraySubscriptOperator() - Constructor for class io.prestosql.operator.scalar.ArraySubscriptOperator
 
ArrayToArrayCast - Class in io.prestosql.operator.scalar
 
ArrayToElementConcatFunction - Class in io.prestosql.operator.scalar
 
ArrayToElementConcatFunction() - Constructor for class io.prestosql.operator.scalar.ArrayToElementConcatFunction
 
ArrayToJsonCast - Class in io.prestosql.operator.scalar
 
ArrayTransformFunction - Class in io.prestosql.operator.scalar
 
ArrayUnionFunction - Class in io.prestosql.operator.scalar
 
asBucketNodeMap() - Method in class io.prestosql.sql.planner.NodePartitionMap
 
asCatalogSchemaRoutineName() - Method in class io.prestosql.metadata.QualifiedObjectName
 
asCatalogSchemaTableName() - Method in class io.prestosql.metadata.QualifiedObjectName
 
asin(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
asQualifiedName(Expression) - Static method in class io.prestosql.sql.analyzer.ExpressionTreeUtils
 
asQualifiedObjectName() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
asQualifiedTablePrefix() - Method in class io.prestosql.metadata.QualifiedObjectName
 
asSchemaRoutineName() - Method in class io.prestosql.metadata.QualifiedObjectName
 
asSchemaTableName() - Method in class io.prestosql.metadata.QualifiedObjectName
 
asSchemaTablePrefix() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
Assert - Class in io.prestosql.testing.assertions
This class provides replacements for TestNG's faulty assertion methods.
assertEquals(Iterable<?>, Iterable<?>) - Static method in class io.prestosql.testing.assertions.Assert
 
assertEquals(Iterable<?>, Iterable<?>, String) - Static method in class io.prestosql.testing.assertions.Assert
 
assertEventually(Duration, Runnable) - Static method in class io.prestosql.testing.assertions.Assert
 
assertPrestoExceptionThrownBy(ThrowableAssert.ThrowingCallable) - Static method in class io.prestosql.testing.assertions.PrestoExceptionAssert
 
assignBucketToNode(int, InternalNode) - Method in class io.prestosql.execution.scheduler.BucketNodeMap
 
assignBucketToNode(int, InternalNode) - Method in class io.prestosql.execution.scheduler.FixedBucketNodeMap
 
assignBucketToNode(int, InternalNode) - Method in class io.prestosql.execution.scheduler.group.DynamicBucketNodeMap
 
Assignments - Class in io.prestosql.sql.planner.plan
 
Assignments(Map<Symbol, Expression>) - Constructor for class io.prestosql.sql.planner.plan.Assignments
 
Assignments.Builder - Class in io.prestosql.sql.planner.plan
 
assignUniqueId() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
AssignUniqueId - Class in io.prestosql.sql.planner.plan
 
AssignUniqueId(PlanNodeId, PlanNode, Symbol) - Constructor for class io.prestosql.sql.planner.plan.AssignUniqueId
 
AssignUniqueIdOperator - Class in io.prestosql.operator
 
AssignUniqueIdStatsRule - Class in io.prestosql.cost
 
AssignUniqueIdStatsRule() - Constructor for class io.prestosql.cost.AssignUniqueIdStatsRule
 
AsteriskedIdentifierChainBasis(Scope.BasisType, Optional<Scope>, Optional<RelationType>) - Constructor for class io.prestosql.sql.analyzer.Scope.AsteriskedIdentifierChainBasis
 
asyncAbort(TransactionId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
asyncAbort(TransactionId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
asyncAbort(TransactionId) - Method in interface io.prestosql.transaction.TransactionManager
 
asyncCommit(TransactionId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
asyncCommit(TransactionId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
asyncCommit(TransactionId) - Method in interface io.prestosql.transaction.TransactionManager
 
AsyncHttpExecutionMBean - Class in io.prestosql.server
 
AsyncHttpExecutionMBean(ExecutorService, ScheduledExecutorService) - Constructor for class io.prestosql.server.AsyncHttpExecutionMBean
 
asyncRefresh() - Method in class io.prestosql.metadata.RemoteNodeState
 
asyncRefresh(MemoryPoolAssignmentsRequest) - Method in class io.prestosql.memory.RemoteNodeMemory
 
atan(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
atan2(double, double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
atLimit(OptionalLong) - Method in class io.prestosql.metadata.InternalTable.Builder
 
atTimeZone(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.AtTimeZoneWithOffset
 
atTimeZone(long, long) - Static method in class io.prestosql.operator.scalar.timetz.AtTimeZoneWithOffset
 
atTimeZone(long, Slice) - Static method in class io.prestosql.operator.scalar.timestamptz.AtTimeZone
 
atTimeZone(ConnectorSession, long, Slice) - Static method in class io.prestosql.operator.scalar.timetz.AtTimeZone
 
atTimeZone(ConnectorSession, LongTimeWithTimeZone, Slice) - Static method in class io.prestosql.operator.scalar.timetz.AtTimeZone
 
atTimeZone(LongTimestampWithTimeZone, long) - Static method in class io.prestosql.operator.scalar.timestamptz.AtTimeZoneWithOffset
 
atTimeZone(LongTimestampWithTimeZone, Slice) - Static method in class io.prestosql.operator.scalar.timestamptz.AtTimeZone
 
atTimeZone(LongTimeWithTimeZone, long) - Static method in class io.prestosql.operator.scalar.timetz.AtTimeZoneWithOffset
 
AtTimeZone - Class in io.prestosql.operator.scalar.timestamptz
 
AtTimeZone - Class in io.prestosql.operator.scalar.timetz
 
AtTimeZoneWithOffset - Class in io.prestosql.operator.scalar.timestamptz
 
AtTimeZoneWithOffset - Class in io.prestosql.operator.scalar.timetz
 
AttributeJdbcTable - Class in io.prestosql.connector.system.jdbc
 
AttributeJdbcTable() - Constructor for class io.prestosql.connector.system.jdbc.AttributeJdbcTable
 
authenticate(ContainerRequestContext) - Method in interface io.prestosql.server.security.Authenticator
 
authenticate(ContainerRequestContext) - Method in class io.prestosql.server.security.CertificateAuthenticator
 
authenticate(ContainerRequestContext) - Method in class io.prestosql.server.security.InsecureAuthenticator
 
authenticate(ContainerRequestContext) - Method in class io.prestosql.server.security.jwt.JwtAuthenticator
 
authenticate(ContainerRequestContext) - Method in class io.prestosql.server.security.KerberosAuthenticator
 
authenticate(ContainerRequestContext) - Method in class io.prestosql.server.security.PasswordAuthenticator
 
AUTHENTICATE_HEADER - Static variable in class io.prestosql.server.security.BasicAuthCredentials
 
AUTHENTICATED_IDENTITY - Static variable in class io.prestosql.server.HttpRequestSessionContext
 
AUTHENTICATED_USER - io.prestosql.server.security.ResourceSecurity.AccessType
 
AuthenticationException - Exception in io.prestosql.server.security
 
AuthenticationException(String) - Constructor for exception io.prestosql.server.security.AuthenticationException
 
AuthenticationException(String, String) - Constructor for exception io.prestosql.server.security.AuthenticationException
 
AuthenticationFilter - Class in io.prestosql.server.security
 
AuthenticationFilter(List<Authenticator>, InternalAuthenticationManager, SecurityConfig, InsecureAuthenticator) - Constructor for class io.prestosql.server.security.AuthenticationFilter
 
Authenticator - Interface in io.prestosql.server.security
 
authenticatorModule(String, Class<? extends Authenticator>, Module) - Static method in class io.prestosql.server.security.ServerSecurityModule
 
AutoCloseableCloser - Class in io.prestosql.util
This class is inspired by com.google.common.io.Closer
AUTOMATIC - io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType
 
AUTOMATIC - io.prestosql.sql.analyzer.FeaturesConfig.JoinReorderingStrategy
 
AVAILABLE_HEAP_MEMORY - Static variable in class io.prestosql.memory.NodeMemoryConfig
 
average(LongDecimalWithOverflowAndLongState, DecimalType) - Static method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
AverageAggregations - Class in io.prestosql.operator.aggregation
 
awaitTermination(long, TimeUnit) - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 

B

Backoff - Class in io.prestosql.server.remotetask
 
Backoff(int, Duration, Ticker, List<Duration>) - Constructor for class io.prestosql.server.remotetask.Backoff
 
Backoff(Duration) - Constructor for class io.prestosql.server.remotetask.Backoff
 
Backoff(Duration, Ticker) - Constructor for class io.prestosql.server.remotetask.Backoff
 
bar(double, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
bar(double, long, long, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
BasicAuthCredentials - Class in io.prestosql.server.security
 
BasicAuthCredentials(String, Optional<String>) - Constructor for class io.prestosql.server.security.BasicAuthCredentials
 
BasicQueryInfo - Class in io.prestosql.server
Lightweight version of QueryInfo.
BasicQueryInfo(QueryInfo) - Constructor for class io.prestosql.server.BasicQueryInfo
 
BasicQueryInfo(QueryId, SessionRepresentation, Optional<ResourceGroupId>, QueryState, MemoryPoolId, boolean, URI, String, Optional<String>, Optional<String>, BasicQueryStats, ErrorType, ErrorCode, Optional<QueryType>) - Constructor for class io.prestosql.server.BasicQueryInfo
 
BasicQueryStats - Class in io.prestosql.server
Lightweight version of QueryStats.
BasicQueryStats(QueryStats) - Constructor for class io.prestosql.server.BasicQueryStats
 
BasicQueryStats(DateTime, DateTime, Duration, Duration, Duration, int, int, int, int, DataSize, long, DataSize, double, DataSize, DataSize, DataSize, DataSize, Duration, Duration, boolean, Set<BlockedReason>, OptionalDouble) - Constructor for class io.prestosql.server.BasicQueryStats
 
BasicStageStats - Class in io.prestosql.execution
 
BasicStageStats(boolean, int, int, int, int, DataSize, long, Duration, DataSize, long, DataSize, long, long, DataSize, DataSize, Duration, Duration, boolean, Set<BlockedReason>, OptionalDouble) - Constructor for class io.prestosql.execution.BasicStageStats
 
BasicWorkProcessorOperatorAdapter - Class in io.prestosql.operator
This WorkProcessorOperator adapter allows to adapt WorkProcessor operators that do not require special input handling (e.g streaming operators).
BasicWorkProcessorOperatorAdapter.BasicAdapterWorkProcessorOperatorFactory - Interface in io.prestosql.operator
 
begin(String, Optional<String>, Session, URI, ResourceGroupId, boolean, TransactionManager, AccessControl, Executor, Metadata, WarningCollector, Optional<QueryType>) - Static method in class io.prestosql.execution.QueryStateMachine
Created QueryStateMachines must be transitioned to terminal states to clean up resources.
beginAnalysis() - Method in class io.prestosql.execution.QueryStateMachine
 
beginCreateTable(Session, String, ConnectorTableMetadata, Optional<NewTableLayout>) - Method in interface io.prestosql.metadata.Metadata
Begin the atomic creation of a table with data.
beginCreateTable(Session, String, ConnectorTableMetadata, Optional<NewTableLayout>) - Method in class io.prestosql.metadata.MetadataManager
 
beginCreateTable(ConnectorSession, ConnectorTableMetadata, Optional<ConnectorNewTableLayout>) - Method in class io.prestosql.testing.TestingMetadata
 
beginDelete(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Begin delete query
beginDelete(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
beginInsert(Session, TableHandle, List<ColumnHandle>) - Method in interface io.prestosql.metadata.Metadata
Begin insert query
beginInsert(Session, TableHandle, List<ColumnHandle>) - Method in class io.prestosql.metadata.MetadataManager
 
beginInsert(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.testing.TestingMetadata
 
beginRefreshMaterializedView(Session, TableHandle, List<TableHandle>) - Method in interface io.prestosql.metadata.Metadata
Begin refresh materialized view query
beginRefreshMaterializedView(Session, TableHandle, List<TableHandle>) - Method in class io.prestosql.metadata.MetadataManager
 
beginScheduling() - Method in class io.prestosql.execution.SqlStageExecution
 
beginStatisticsCollection(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Begin statistics collection
beginStatisticsCollection(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
BeginTableWrite - Class in io.prestosql.sql.planner.optimizations
 
BeginTableWrite(Metadata) - Constructor for class io.prestosql.sql.planner.optimizations.BeginTableWrite
 
BeginTableWrite.Context - Class in io.prestosql.sql.planner.optimizations
 
beginTransaction(boolean) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
beginTransaction(boolean) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
beginTransaction(boolean) - Method in interface io.prestosql.transaction.TransactionManager
 
beginTransaction(IsolationLevel, boolean) - Method in interface io.prestosql.transaction.InternalConnector
 
beginTransaction(IsolationLevel, boolean, boolean) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
beginTransaction(IsolationLevel, boolean, boolean) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
beginTransaction(IsolationLevel, boolean, boolean) - Method in interface io.prestosql.transaction.TransactionManager
 
beginTransaction(TransactionId, IsolationLevel, boolean) - Method in class io.prestosql.connector.informationschema.InformationSchemaConnector
 
beginTransaction(TransactionId, IsolationLevel, boolean) - Method in class io.prestosql.connector.system.GlobalSystemConnector
 
beginTransaction(TransactionId, IsolationLevel, boolean) - Method in class io.prestosql.connector.system.SystemConnector
 
beginTransaction(TransactionId, IsolationLevel, boolean) - Method in interface io.prestosql.transaction.InternalConnector
 
beginTransactionId(TransactionId, TransactionManager, AccessControl) - Method in class io.prestosql.Session
 
BERNOULLI - io.prestosql.sql.planner.plan.SampleNode.Type
 
betaCdf(double, double, double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
BETWEEN - io.prestosql.sql.relational.SpecialForm.Form
 
BetweenCodeGenerator - Class in io.prestosql.sql.gen
 
BetweenCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.BetweenCodeGenerator
 
BIGINT_TO_DECIMAL_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
BIGINT_TO_DECIMAL_SATURATED_FLOOR_CAST - Static variable in class io.prestosql.type.DecimalSaturatedFloorCasts
 
BigintApproximateMostFrequent - Class in io.prestosql.operator.aggregation
Aggregation function that approximates the frequency of the top-K elements.
BigintApproximateMostFrequent.State - Interface in io.prestosql.operator.aggregation
 
bigintDistinct(Block) - Method in class io.prestosql.operator.scalar.ArrayDistinctFunction
 
BigintGroupByHash - Class in io.prestosql.operator
 
BigintGroupByHash(int, boolean, int, UpdateMemory) - Constructor for class io.prestosql.operator.BigintGroupByHash
 
bigintInput(CentralMomentsState, long) - Static method in class io.prestosql.operator.aggregation.CentralMomentsAggregation
 
bigintInput(VarianceState, long) - Static method in class io.prestosql.operator.aggregation.VarianceAggregation
 
bigintMultiply(long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
bigintMultiply(long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
BigintOperators - Class in io.prestosql.type
 
bigintToLongDecimal(long, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
bigintToShortDecimal(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
bigintUnion(Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayUnionFunction
 
binaryExpression(LogicalBinaryExpression.Operator, Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
BinaryFunctionInterface - Interface in io.prestosql.sql.gen.lambda
 
bind(MethodHandle) - Method in class io.prestosql.sql.gen.CallSiteBinder
 
bind(Object, Class<?>) - Method in class io.prestosql.sql.gen.CallSiteBinder
 
bind(List<? extends TypeSignatureProvider>) - Method in class io.prestosql.metadata.SignatureBinder
 
bind(List<? extends TypeSignatureProvider>, Type) - Method in class io.prestosql.metadata.SignatureBinder
 
bind(List<Integer>, Optional<Integer>) - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
bind(List<Integer>, Optional<Integer>, List<Type>, List<Integer>, List<SortOrder>, PagesIndex.Factory, boolean, JoinCompiler, BlockTypeOperators, List<LambdaProvider>, Session) - Method in interface io.prestosql.operator.aggregation.AccumulatorFactoryBinder
 
bind(List<Integer>, Optional<Integer>, List<Type>, List<Integer>, List<SortOrder>, PagesIndex.Factory, boolean, JoinCompiler, BlockTypeOperators, List<LambdaProvider>, Session) - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactoryBinder
 
bind(List<Integer>, Optional<Integer>, List<Type>, List<Integer>, List<SortOrder>, PagesIndex.Factory, boolean, JoinCompiler, BlockTypeOperators, List<LambdaProvider>, Session) - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
bind(List<Integer>, Optional<Integer>, List<Type>, List<Integer>, List<SortOrder>, PagesIndex.Factory, boolean, JoinCompiler, BlockTypeOperators, List<LambdaProvider>, Session) - Method in class io.prestosql.operator.aggregation.LazyAccumulatorFactoryBinder
 
BIND - io.prestosql.sql.relational.SpecialForm.Form
 
BindCodeGenerator - Class in io.prestosql.sql.gen
 
BindCodeGenerator(SpecialForm, Map<LambdaDefinitionExpression, LambdaBytecodeGenerator.CompiledLambda>, Class<?>) - Constructor for class io.prestosql.sql.gen.BindCodeGenerator
 
bindDependencies(MethodHandle, List<ImplementationDependency>, FunctionBinding, FunctionDependencies) - Static method in class io.prestosql.operator.ParametricFunctionHelpers
 
bindFunction(FunctionId, Signature, BoundSignature) - Static method in class io.prestosql.metadata.SignatureBinder
 
Binding - Class in io.prestosql.sql.gen
 
Binding(long, MethodType) - Constructor for class io.prestosql.sql.gen.Binding
 
bitAnd(NullableLongState, long) - Static method in class io.prestosql.operator.aggregation.BitwiseAndAggregation
 
bitCount(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitOr(NullableLongState, long) - Static method in class io.prestosql.operator.aggregation.BitwiseOrAggregation
 
bitwiseAnd(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
BitwiseAndAggregation - Class in io.prestosql.operator.aggregation
 
BitwiseFunctions - Class in io.prestosql.operator.scalar
 
bitwiseLeftShiftBigint(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseLeftShiftInteger(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseLeftShiftSmallint(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseLeftShiftTinyint(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseNot(long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseOr(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
BitwiseOrAggregation - Class in io.prestosql.operator.aggregation
 
bitwiseRightShiftArithmeticBigint(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseRightShiftArithmeticInteger(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseRightShiftArithmeticSmallint(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseRightShiftArithmeticTinyint(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseRightShiftBigint(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseRightShiftInteger(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseRightShiftSmallint(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseRightShiftTinyint(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
bitwiseXor(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
BLACK - io.prestosql.operator.scalar.ColorFunctions.SystemColor
 
BLOCK_INDEX - io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata.ParameterType
 
BLOCK_INPUT_CHANNEL - io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata.ParameterType
 
blocked(ListenableFuture<?>) - Static method in class io.prestosql.operator.WorkProcessor.ProcessState
Signals that process is blocked.
blocked(ListenableFuture<?>) - Static method in class io.prestosql.operator.WorkProcessor.TransformationState
Signals that transformation is blocked.
BLOCKED - io.prestosql.operator.WorkProcessor.ProcessState.Type
 
BlockedReason - Enum in io.prestosql.operator
 
BlockJsonSerde - Class in io.prestosql.block
 
BlockJsonSerde.Deserializer - Class in io.prestosql.block
 
BlockJsonSerde.Serializer - Class in io.prestosql.block
 
BlockPositionState - Interface in io.prestosql.operator.aggregation.state
 
BlockPositionStateSerializer - Class in io.prestosql.operator.aggregation.state
 
BlockPositionStateSerializer(Type) - Constructor for class io.prestosql.operator.aggregation.state.BlockPositionStateSerializer
 
BlockSerdeUtil - Class in io.prestosql.block
 
BlockState - Interface in io.prestosql.operator.aggregation.state
 
BlockStateSerializer - Class in io.prestosql.operator.aggregation.state
 
BlockStateSerializer(Type) - Constructor for class io.prestosql.operator.aggregation.state.BlockStateSerializer
 
BlockTypeOperators - Class in io.prestosql.type
 
BlockTypeOperators() - Constructor for class io.prestosql.type.BlockTypeOperators
 
BlockTypeOperators(TypeOperators) - Constructor for class io.prestosql.type.BlockTypeOperators
 
BlockTypeOperators.BlockPositionComparison - Interface in io.prestosql.type
 
BlockTypeOperators.BlockPositionEqual - Interface in io.prestosql.type
 
BlockTypeOperators.BlockPositionHashCode - Interface in io.prestosql.type
 
BlockTypeOperators.BlockPositionIsDistinctFrom - Interface in io.prestosql.type
 
BlockTypeOperators.BlockPositionLessThan - Interface in io.prestosql.type
 
BlockTypeOperators.BlockPositionOrdering - Interface in io.prestosql.type
 
BlockTypeOperators.BlockPositionXxHash64 - Interface in io.prestosql.type
 
BLUE - io.prestosql.operator.scalar.ColorFunctions.SystemColor
 
BodyCompiler - Interface in io.prestosql.sql.gen
 
BOOLEAN_TO_DECIMAL_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
booleanAnd(TriStateBooleanState, boolean) - Static method in class io.prestosql.operator.aggregation.BooleanAndAggregation
 
BooleanAndAggregation - Class in io.prestosql.operator.aggregation
 
BooleanAndBlockPositionValueState - Interface in io.prestosql.operator.aggregation.minmaxby
 
booleanArrayMax(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMaxFunction
 
booleanArrayMin(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMinFunction
 
BooleanBooleanState - Interface in io.prestosql.operator.aggregation.minmaxby
 
BooleanDistinctState - Interface in io.prestosql.operator.aggregation.state
 
BooleanDoubleState - Interface in io.prestosql.operator.aggregation.minmaxby
 
booleanElementAt(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayElementAtFunction
 
BooleanLongState - Interface in io.prestosql.operator.aggregation.minmaxby
 
BooleanOperators - Class in io.prestosql.type
 
booleanOr(TriStateBooleanState, boolean) - Static method in class io.prestosql.operator.aggregation.BooleanOrAggregation
 
BooleanOrAggregation - Class in io.prestosql.operator.aggregation
 
booleanSubscript(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
BooleanToBooleanFunction - Interface in io.prestosql.operator.scalar
 
booleanToLongDecimal(boolean, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
booleanToShortDecimal(boolean, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
bootstrap(MethodHandles.Lookup, String, MethodType, long) - Static method in class io.prestosql.sql.gen.Bootstrap
 
Bootstrap - Class in io.prestosql.sql.gen
 
BOOTSTRAP_METHOD - Static variable in class io.prestosql.sql.gen.Bootstrap
 
BoundSignature - Class in io.prestosql.metadata
 
BoundSignature(String, Type, List<Type>) - Constructor for class io.prestosql.metadata.BoundSignature
 
boxPrimitive(Class<?>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
boxPrimitiveIfNecessary(Scope, Class<?>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
BROADCAST - io.prestosql.execution.buffer.OutputBuffers.BufferType
 
BROADCAST - io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType
 
BROADCAST - io.prestosql.sql.planner.SystemPartitioningHandle.SystemPartitionFunction
 
BROADCAST_PARTITION_ID - Static variable in class io.prestosql.execution.buffer.OutputBuffers
 
BroadcastOutputBuffer - Class in io.prestosql.execution.buffer
 
BroadcastOutputBuffer(String, StateMachine<BufferState>, DataSize, Supplier<LocalMemoryContext>, Executor, Runnable) - Constructor for class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
BucketConsumer<K> - Interface in io.prestosql.operator.aggregation
 
BucketedSplitPlacementPolicy(NodeSelector, List<InternalNode>, BucketNodeMap, Supplier<? extends List<RemoteTask>>) - Constructor for class io.prestosql.execution.scheduler.FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy
 
BucketNodeMap - Class in io.prestosql.execution.scheduler
 
BucketNodeMap(ToIntFunction<Split>) - Constructor for class io.prestosql.execution.scheduler.BucketNodeMap
 
BucketPartitionFunction - Class in io.prestosql.operator
 
BucketPartitionFunction(BucketFunction, int[]) - Constructor for class io.prestosql.operator.BucketPartitionFunction
 
BufferInfo - Class in io.prestosql.execution.buffer
 
BufferInfo(OutputBuffers.OutputBufferId, boolean, int, long, PageBufferInfo) - Constructor for class io.prestosql.execution.buffer.BufferInfo
 
BufferingSplitSource - Class in io.prestosql.split
 
BufferingSplitSource(SplitSource, int) - Constructor for class io.prestosql.split.BufferingSplitSource
 
BufferResult - Class in io.prestosql.execution.buffer
 
BufferResult(String, long, long, boolean, List<SerializedPage>) - Constructor for class io.prestosql.execution.buffer.BufferResult
 
BufferState - Enum in io.prestosql.execution.buffer
 
build() - Method in class io.prestosql.cost.PlanNodeStatsEstimate.Builder
 
build() - Method in class io.prestosql.cost.SymbolStatsEstimate.Builder
 
build() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder
 
build() - Method in class io.prestosql.metadata.InternalTable.Builder
 
build() - Method in class io.prestosql.metadata.MetadataUtil.TableMetadataBuilder
 
build() - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
build() - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.ChoiceBuilder
 
build() - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.MethodsGroupBuilder
 
build() - Method in class io.prestosql.metadata.SignatureBuilder
 
build() - Method in class io.prestosql.operator.ArrayPositionLinks.FactoryBuilder
 
build() - Method in class io.prestosql.operator.ChannelSet.ChannelSetBuilder
 
build() - Method in class io.prestosql.operator.NestedLoopJoinPagesBuilder
 
build() - Method in class io.prestosql.operator.ParametricImplementationsGroup.Builder
 
build() - Method in interface io.prestosql.operator.PositionLinks.FactoryBuilder
 
build() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.Builder
 
build() - Method in class io.prestosql.operator.SortedPositionLinks.FactoryBuilder
 
build() - Method in class io.prestosql.server.protocol.QueryResultRows.Builder
 
build() - Method in class io.prestosql.server.testing.TestingPrestoServer.Builder
 
build() - Method in class io.prestosql.Session.ResourceEstimateBuilder
 
build() - Method in class io.prestosql.Session.SessionBuilder
 
build() - Method in class io.prestosql.sql.analyzer.Scope.Builder
 
build() - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
build() - Method in class io.prestosql.sql.planner.iterative.RuleIndex.Builder
 
build() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
build() - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper.Builder
 
build() - Method in class io.prestosql.sql.planner.plan.Assignments.Builder
 
build() - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.Builder
 
build() - Method in class io.prestosql.testing.LocalQueryRunner.Builder
 
build() - Method in class io.prestosql.testing.MaterializedResult.Builder
 
build() - Method in class io.prestosql.testing.TestingConnectorSession.Builder
 
build() - Method in class io.prestosql.testing.TestingTaskContext.Builder
 
build(JoinProbe) - Method in class io.prestosql.operator.LookupJoinPageBuilder
 
builder() - Static method in class io.prestosql.cost.PlanNodeStatsEstimate
 
builder() - Static method in class io.prestosql.cost.SymbolStatsEstimate
 
builder() - Static method in class io.prestosql.metadata.FunctionDependencyDeclaration
 
builder() - Static method in class io.prestosql.metadata.Signature
 
builder() - Static method in class io.prestosql.operator.ParametricImplementationsGroup
 
builder() - Static method in class io.prestosql.server.testing.TestingPrestoServer
 
builder() - Static method in class io.prestosql.sql.analyzer.Scope
 
builder() - Static method in class io.prestosql.sql.planner.iterative.RuleIndex
 
builder() - Static method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
builder() - Static method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
builder() - Static method in class io.prestosql.sql.planner.plan.Assignments
 
builder() - Static method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
builder() - Static method in class io.prestosql.testing.TestingConnectorSession
 
builder(int) - Static method in class io.prestosql.operator.ArrayPositionLinks
 
builder(int, PagesHashStrategy, LongArrayList) - Static method in class io.prestosql.operator.SortedPositionLinks
 
builder(SessionPropertyManager) - Static method in class io.prestosql.Session
 
builder(Session) - Static method in class io.prestosql.Session
 
builder(Session) - Static method in class io.prestosql.testing.LocalQueryRunner
 
builder(ColumnMetadata...) - Static method in class io.prestosql.metadata.InternalTable
 
builder(Executor, ScheduledExecutorService, Session) - Static method in class io.prestosql.testing.TestingTaskContext
 
builder(List<ColumnMetadata>) - Static method in class io.prestosql.metadata.InternalTable
 
Builder() - Constructor for class io.prestosql.cost.PlanNodeStatsEstimate.Builder
 
Builder() - Constructor for class io.prestosql.cost.SymbolStatsEstimate.Builder
 
Builder() - Constructor for class io.prestosql.server.testing.TestingPrestoServer.Builder
 
Builder() - Constructor for class io.prestosql.sql.analyzer.Scope.Builder
 
Builder() - Constructor for class io.prestosql.sql.planner.iterative.RuleIndex.Builder
 
Builder() - Constructor for class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
Builder() - Constructor for class io.prestosql.sql.planner.optimizations.SymbolMapper.Builder
 
Builder() - Constructor for class io.prestosql.sql.planner.plan.Assignments.Builder
 
Builder() - Constructor for class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.Builder
 
Builder() - Constructor for class io.prestosql.testing.TestingConnectorSession.Builder
 
Builder(Signature, List<Optional<Class<?>>>, Map<String, Class<?>>, Class<?>) - Constructor for class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.Builder
 
Builder(Session) - Constructor for class io.prestosql.server.protocol.QueryResultRows.Builder
 
Builder(ActualProperties.Global, List<LocalProperty<Symbol>>, Map<Symbol, NullableValue>) - Constructor for class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
Builder(List<String>, List<Type>) - Constructor for class io.prestosql.metadata.InternalTable.Builder
 
builderFrom(ActualProperties) - Static method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
buildFrom(PlanNodeStatsEstimate) - Static method in class io.prestosql.cost.PlanNodeStatsEstimate
 
buildFrom(SymbolStatsEstimate) - Static method in class io.prestosql.cost.SymbolStatsEstimate
 
buildFrom(Metadata, PlanNode, Lookup, PlanNodeIdAllocator) - Static method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
Builds JoinGraph containing plan node.
buildHashSortedResult() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
buildIntermediateTypes() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
buildJoinTree(List<Symbol>, JoinGraph, List<Integer>, PlanNodeIdAllocator) - Static method in class io.prestosql.sql.planner.iterative.rule.EliminateCrossJoins
 
buildPage(int, int[], PageBuilder) - Method in class io.prestosql.operator.PagesIndex
 
buildResult() - Method in interface io.prestosql.operator.aggregation.builder.HashAggregationBuilder
 
buildResult() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
buildResult() - Method in class io.prestosql.operator.aggregation.builder.MergingHashAggregationBuilder
 
buildResult() - Method in class io.prestosql.operator.aggregation.builder.SpillableHashAggregationBuilder
 
buildResult() - Method in class io.prestosql.operator.GroupedTopNBuilder
 
BuildSetDigestAggregation - Class in io.prestosql.type.setdigest
 
buildTypes() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
byName() - Static method in class io.prestosql.server.ThreadResource.Info
 
BytecodeGenerator - Interface in io.prestosql.sql.gen
 
BytecodeGeneratorContext - Class in io.prestosql.sql.gen
 
BytecodeGeneratorContext(RowExpressionCompiler, Scope, CallSiteBinder, CachedInstanceBinder, Metadata) - Constructor for class io.prestosql.sql.gen.BytecodeGeneratorContext
 
BytecodeUtils - Class in io.prestosql.sql.gen
 
bytesCompare(int, int, int, Slice, int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
bytesEqual(int, int, Slice, int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
byteValue() - Method in class io.prestosql.execution.buffer.PageCodecMarker.MarkerSet
 

C

CachedInstanceBinder - Class in io.prestosql.sql.gen
 
CachedInstanceBinder(ClassDefinition, CallSiteBinder) - Constructor for class io.prestosql.sql.gen.CachedInstanceBinder
 
cacheReset() - Method in class io.prestosql.type.BlockTypeOperators
 
cacheReset() - Method in class io.prestosql.type.TypeOperatorsCache
 
cacheSize() - Method in class io.prestosql.type.BlockTypeOperators
 
cacheSize() - Method in class io.prestosql.type.TypeOperatorsCache
 
CachingCostProvider - Class in io.prestosql.cost
 
CachingCostProvider(CostCalculator, StatsProvider, Session, TypeProvider) - Constructor for class io.prestosql.cost.CachingCostProvider
 
CachingCostProvider(CostCalculator, StatsProvider, Optional<Memo>, Session, TypeProvider) - Constructor for class io.prestosql.cost.CachingCostProvider
 
CachingStatsProvider - Class in io.prestosql.cost
 
CachingStatsProvider(StatsCalculator, Session, TypeProvider) - Constructor for class io.prestosql.cost.CachingStatsProvider
 
CachingStatsProvider(StatsCalculator, Optional<Memo>, Lookup, Session, TypeProvider) - Constructor for class io.prestosql.cost.CachingStatsProvider
 
calculate(AssignUniqueId, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.AssignUniqueIdStatsRule
 
calculate(OutputNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.OutputStatsRule
 
calculate(SemiJoinNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.SemiJoinStatsRule
 
calculate(SortNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.SortStatsRule
 
calculate(ValuesNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.ValuesStatsRule
 
calculate(Expression, PlanNodeStatsEstimate, Session, TypeProvider) - Method in class io.prestosql.cost.ScalarStatsCalculator
 
calculate(T, StatsProvider, Lookup, Session, TypeProvider) - Method in interface io.prestosql.cost.ComposableStatsCalculator.Rule
 
calculate(T, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.SimpleStatsRule
 
calculateChecksum(List<SerializedPage>) - Static method in class io.prestosql.execution.buffer.PagesSerdeUtil
 
calculateCost(PlanNode, StatsProvider, CostProvider, Session, TypeProvider) - Method in interface io.prestosql.cost.CostCalculator
Calculates cumulative cost of a node.
calculateCost(PlanNode, StatsProvider, CostProvider, Session, TypeProvider) - Method in class io.prestosql.cost.CostCalculatorUsingExchanges
 
calculateCost(PlanNode, StatsProvider, CostProvider, Session, TypeProvider) - Method in class io.prestosql.cost.CostCalculatorWithEstimatedExchanges
 
calculateJoinCostWithoutOutput(PlanNode, PlanNode, StatsProvider, TypeProvider, boolean, int) - Static method in class io.prestosql.cost.CostCalculatorWithEstimatedExchanges
 
calculateJoinInputCost(PlanNode, PlanNode, StatsProvider, TypeProvider, boolean, int) - Static method in class io.prestosql.cost.CostCalculatorWithEstimatedExchanges
 
calculateLocalRepartitionCost(double) - Static method in class io.prestosql.cost.CostCalculatorWithEstimatedExchanges
 
calculateLowWatermark(int) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
calculateMaxFill(int, float) - Static method in class io.prestosql.operator.aggregation.histogram.HashUtil
 
calculateOffsetMinutes(int, int, int) - Static method in class io.prestosql.type.DateTimes
 
calculateRemoteGatherCost(double) - Static method in class io.prestosql.cost.CostCalculatorWithEstimatedExchanges
 
calculateRemoteRepartitionCost(double) - Static method in class io.prestosql.cost.CostCalculatorWithEstimatedExchanges
 
calculateRemoteReplicateCost(double, int) - Static method in class io.prestosql.cost.CostCalculatorWithEstimatedExchanges
 
calculateStats(PlanNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.ComposableStatsCalculator
 
calculateStats(PlanNode, StatsProvider, Lookup, Session, TypeProvider) - Method in interface io.prestosql.cost.StatsCalculator
Calculate stats for the node.
call(ResolvedFunction, RowExpression...) - Static method in class io.prestosql.sql.relational.Expressions
 
call(ResolvedFunction, List<RowExpression>) - Static method in class io.prestosql.sql.relational.Expressions
 
callback(String, String, String, String, String, UriInfo, SecurityContext) - Method in class io.prestosql.server.security.oauth2.OAuth2CallbackResource
 
CALLBACK_ENDPOINT - Static variable in class io.prestosql.server.security.oauth2.OAuth2CallbackResource
 
CallExpression - Class in io.prestosql.sql.relational
 
CallExpression(ResolvedFunction, List<RowExpression>) - Constructor for class io.prestosql.sql.relational.CallExpression
 
CallSiteBinder - Class in io.prestosql.sql.gen
 
CallSiteBinder() - Constructor for class io.prestosql.sql.gen.CallSiteBinder
 
CallTask - Class in io.prestosql.execution
 
CallTask() - Constructor for class io.prestosql.execution.CallTask
 
canAddBuffers() - Method in enum io.prestosql.execution.buffer.BufferState
 
canAddPages() - Method in enum io.prestosql.execution.buffer.BufferState
 
canBind(List<? extends TypeSignatureProvider>) - Method in class io.prestosql.metadata.SignatureBinder
 
canBind(List<? extends TypeSignatureProvider>, TypeSignature) - Method in class io.prestosql.metadata.SignatureBinder
 
canCastFromJson(Type) - Static method in class io.prestosql.util.JsonUtil
 
canCastToJson(Type) - Static method in class io.prestosql.util.JsonUtil
 
cancel() - Method in interface io.prestosql.dispatcher.DispatchQuery
 
cancel() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
cancel() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
cancel() - Method in interface io.prestosql.execution.RemoteTask
 
cancel() - Method in class io.prestosql.execution.SqlStageExecution
 
cancel() - Method in class io.prestosql.execution.SqlTask
 
cancel() - Method in class io.prestosql.execution.TaskStateMachine
 
cancel() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
CANCELED - io.prestosql.execution.StageState
Stage was canceled by a user.
CANCELED - io.prestosql.execution.TaskState
Task was canceled by a user.
cancelQuery() - Method in class io.prestosql.execution.DataDefinitionExecution
 
cancelQuery() - Method in interface io.prestosql.execution.QueryExecution
 
cancelQuery() - Method in class io.prestosql.execution.SqlQueryExecution
 
cancelQuery(QueryId) - Method in class io.prestosql.dispatcher.DispatchManager
 
cancelQuery(QueryId) - Method in interface io.prestosql.execution.QueryManager
Attempts to fail the query due to a user cancellation.
cancelQuery(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
cancelQuery(QueryId, String, long) - Method in class io.prestosql.dispatcher.QueuedStatementResource
 
cancelQuery(QueryId, String, long) - Method in class io.prestosql.server.protocol.ExecutingStatementResource
 
cancelQuery(QueryId, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.QueryResource
 
cancelStage(StageId) - Method in class io.prestosql.execution.DataDefinitionExecution
 
cancelStage(StageId) - Method in interface io.prestosql.execution.QueryExecution
 
cancelStage(StageId) - Method in interface io.prestosql.execution.QueryManager
Attempts to cancel the stage and continue the query.
cancelStage(StageId) - Method in class io.prestosql.execution.scheduler.SqlQueryScheduler
 
cancelStage(StageId) - Method in class io.prestosql.execution.SqlQueryExecution
 
cancelStage(StageId) - Method in class io.prestosql.execution.SqlQueryManager
 
cancelTask(TaskId) - Method in class io.prestosql.execution.SqlTaskManager
 
cancelTask(TaskId) - Method in interface io.prestosql.execution.TaskManager
Cancels a task.
canCoerce(Type, Type) - Method in class io.prestosql.type.TypeCoercion
 
CanonicalizationAware<T extends Node> - Class in io.prestosql.sql.analyzer
 
canonicalizationAwareComparison(Node, Node) - Static method in class io.prestosql.sql.analyzer.CanonicalizationAware
 
canonicalizationAwareHash(Node) - Static method in class io.prestosql.sql.analyzer.CanonicalizationAware
 
canonicalizationAwareKey(T) - Static method in class io.prestosql.sql.analyzer.CanonicalizationAware
 
canonicalize(Identifier) - Static method in class io.prestosql.sql.analyzer.CanonicalizationAware
 
canonicalizeExpression(Expression, Map<NodeRef<Expression>, Type>, Metadata) - Static method in class io.prestosql.sql.planner.iterative.rule.CanonicalizeExpressionRewriter
 
CanonicalizeExpressionRewriter - Class in io.prestosql.sql.planner.iterative.rule
 
CanonicalizeExpressions - Class in io.prestosql.sql.planner.iterative.rule
 
CanonicalizeExpressions(Metadata, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.CanonicalizeExpressions
 
canPartition() - Method in enum io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType
 
canReplicate() - Method in enum io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType
 
canReplicate(JoinNode, Rule.Context) - Static method in class io.prestosql.sql.planner.iterative.rule.DetermineJoinDistributionType
 
canResolve(QualifiedName) - Method in class io.prestosql.sql.analyzer.Field
 
canResolve(QualifiedName) - Method in class io.prestosql.sql.analyzer.RelationType
 
canScheduleMoreTasks() - Method in enum io.prestosql.execution.StageState
 
capStats(PlanNodeStatsEstimate, PlanNodeStatsEstimate) - Static method in class io.prestosql.cost.PlanNodeStatsEstimateMath
 
cardinality() - Method in class io.prestosql.type.setdigest.SetDigest
 
cardinality(Slice) - Static method in class io.prestosql.operator.scalar.HyperLogLogFunctions
 
cardinality(Slice) - Static method in class io.prestosql.type.setdigest.SetDigestFunctions
 
cast(long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToDateCast
 
cast(long, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToVarcharCast
 
cast(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimeCast
 
cast(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToVarcharCast
 
cast(long, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToTimeCast
 
cast(long, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToVarcharCast
 
cast(long, long, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimeCast
 
cast(long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToJsonCast
 
cast(long, ConnectorSession, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToJsonCast
 
cast(long, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimeCast
 
cast(long, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToVarcharCast
 
cast(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimeCast
 
cast(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToVarcharCast
 
cast(long, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToTimeCast
 
cast(long, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToVarcharCast
 
cast(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToDateCast
 
cast(ConnectorSession, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToDateCast
 
cast(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToDateCast
 
CAST_FROM_UNKNOWN - Static variable in class io.prestosql.operator.scalar.CastFromUnknownOperator
 
castableFromTypeParameter(String, TypeSignature...) - Static method in class io.prestosql.metadata.Signature
 
castableFromTypeParameter(String, Set<TypeSignature>) - Static method in class io.prestosql.metadata.Signature
 
castableToTypeParameter(String, TypeSignature...) - Static method in class io.prestosql.metadata.Signature
 
castableToTypeParameter(String, Set<TypeSignature>) - Static method in class io.prestosql.metadata.Signature
 
castCharToCodePoints(Long, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
castCharToJoniRegexp(Long, Slice) - Static method in class io.prestosql.operator.scalar.JoniRegexpCasts
 
castCharToJsonPath(Long, Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
castCharToRe2JRegexp(int, int) - Static method in class io.prestosql.operator.scalar.Re2JCastToRegexpFunction
 
castFromBigint(long) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castFromBinary(Slice) - Static method in class io.prestosql.type.setdigest.SetDigestOperators
 
castFromBoolean(boolean) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castFromDate(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castFromDouble(double) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castFromInteger(long) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castFromIpAddressToVarbinary(Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
castFromIpAddressToVarchar(Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
castFromP4Hll(Slice) - Static method in class io.prestosql.type.HyperLogLogOperators
 
castFromReal(long) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castFromSlice(Slice) - Static method in class io.prestosql.type.DateOperators
 
castFromSmallInt(long) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castFromTinyInt(long) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
CastFromUnknownOperator - Class in io.prestosql.operator.scalar
 
CastFromUnknownOperator() - Constructor for class io.prestosql.operator.scalar.CastFromUnknownOperator
 
castFromUuidToVarbinary(Slice) - Static method in class io.prestosql.type.UuidOperators
 
castFromUuidToVarchar(Slice) - Static method in class io.prestosql.type.UuidOperators
 
castFromVarbinary(Slice) - Static method in class io.prestosql.type.HyperLogLogOperators
 
castFromVarbinary(Slice) - Static method in class io.prestosql.type.TDigestOperators
 
castFromVarbinaryBigint(Slice) - Static method in class io.prestosql.type.QuantileDigestOperators
 
castFromVarbinaryDouble(Slice) - Static method in class io.prestosql.type.QuantileDigestOperators
 
castFromVarbinaryReal(Slice) - Static method in class io.prestosql.type.QuantileDigestOperators
 
castFromVarbinaryToIpAddress(Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
castFromVarbinaryToUuid(Slice) - Static method in class io.prestosql.type.UuidOperators
 
castFromVarchar(long, Slice) - Static method in class io.prestosql.operator.scalar.time.TimeOperators
 
castFromVarchar(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castFromVarcharToIpAddress(Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
castFromVarcharToUuid(Slice) - Static method in class io.prestosql.type.UuidOperators
 
CastImplementationDependency - Class in io.prestosql.operator.annotations
 
CastImplementationDependency(TypeSignature, TypeSignature, InvocationConvention, Class<?>) - Constructor for class io.prestosql.operator.annotations.CastImplementationDependency
 
castToBigint(boolean) - Static method in class io.prestosql.type.BooleanOperators
 
castToBigint(long) - Static method in class io.prestosql.type.IntegerOperators
 
castToBigint(long) - Static method in class io.prestosql.type.SmallintOperators
 
castToBigint(long) - Static method in class io.prestosql.type.TinyintOperators
 
castToBigint(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToBigint(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
castToBinary(Slice) - Static method in class io.prestosql.type.HyperLogLogOperators
 
castToBinary(Slice) - Static method in class io.prestosql.type.setdigest.SetDigestOperators
 
castToBinary(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
castToBinary(TDigest) - Static method in class io.prestosql.type.TDigestOperators
 
castToBinaryBigint(Slice) - Static method in class io.prestosql.type.QuantileDigestOperators
 
castToBinaryDouble(Slice) - Static method in class io.prestosql.type.QuantileDigestOperators
 
castToBinaryReal(Slice) - Static method in class io.prestosql.type.QuantileDigestOperators
 
castToBoolean(double) - Static method in class io.prestosql.type.DoubleOperators
 
castToBoolean(long) - Static method in class io.prestosql.type.BigintOperators
 
castToBoolean(long) - Static method in class io.prestosql.type.IntegerOperators
 
castToBoolean(long) - Static method in class io.prestosql.type.RealOperators
 
castToBoolean(long) - Static method in class io.prestosql.type.SmallintOperators
 
castToBoolean(long) - Static method in class io.prestosql.type.TinyintOperators
 
castToBoolean(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToBoolean(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
castToDouble(boolean) - Static method in class io.prestosql.type.BooleanOperators
 
castToDouble(long) - Static method in class io.prestosql.type.BigintOperators
 
castToDouble(long) - Static method in class io.prestosql.type.IntegerOperators
 
castToDouble(long) - Static method in class io.prestosql.type.RealOperators
 
castToDouble(long) - Static method in class io.prestosql.type.SmallintOperators
 
castToDouble(long) - Static method in class io.prestosql.type.TinyintOperators
 
castToDouble(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToDouble(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
castToFloat(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
castToHyperLogLog(Slice) - Static method in class io.prestosql.type.setdigest.SetDigestOperators
 
castToInteger(boolean) - Static method in class io.prestosql.type.BooleanOperators
 
castToInteger(double) - Static method in class io.prestosql.type.DoubleOperators
 
castToInteger(long) - Static method in class io.prestosql.type.BigintOperators
 
castToInteger(long) - Static method in class io.prestosql.type.RealOperators
 
castToInteger(long) - Static method in class io.prestosql.type.SmallintOperators
 
castToInteger(long) - Static method in class io.prestosql.type.TinyintOperators
 
castToInteger(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToInteger(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
castToLong(double) - Static method in class io.prestosql.type.DoubleOperators
 
castToLong(long) - Static method in class io.prestosql.operator.scalar.timestamp.DateToTimestampCast
 
castToLong(long) - Static method in class io.prestosql.type.RealOperators
 
castToLong(long, long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.time.TimeToTimestampCast
 
castToLong(long, long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.time.TimeToTimestampWithTimeZoneCast
 
castToLong(long, Slice) - Static method in class io.prestosql.operator.scalar.timestamp.VarcharToTimestampCast
 
castToLong(long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.time.TimeToTimeWithTimeZoneCast
 
castToLong(long, ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.timestamptz.VarcharToTimestampWithTimeZoneCast
 
castToLong(long, ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.timetz.VarcharToTimeWithTimeZoneCast
 
castToLong(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timestamptz.DateToTimestampWithTimeZoneCast
 
castToLongTimestamp(int, String) - Static method in class io.prestosql.operator.scalar.timestamp.VarcharToTimestampCast
 
castToP4Hll(Slice) - Static method in class io.prestosql.type.HyperLogLogOperators
 
castToReal(boolean) - Static method in class io.prestosql.type.BooleanOperators
 
castToReal(double) - Static method in class io.prestosql.type.DoubleOperators
 
castToReal(long) - Static method in class io.prestosql.type.BigintOperators
 
castToReal(long) - Static method in class io.prestosql.type.IntegerOperators
 
castToReal(long) - Static method in class io.prestosql.type.SmallintOperators
 
castToReal(long) - Static method in class io.prestosql.type.TinyintOperators
 
castToReal(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToRegexp(int, int, boolean, long, Slice) - Static method in class io.prestosql.operator.scalar.Re2JCastToRegexpFunction
 
castToShort(long) - Static method in class io.prestosql.operator.scalar.timestamp.DateToTimestampCast
 
castToShort(long, long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.time.TimeToTimestampCast
 
castToShort(long, long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.time.TimeToTimestampWithTimeZoneCast
 
castToShort(long, Slice) - Static method in class io.prestosql.operator.scalar.timestamp.VarcharToTimestampCast
 
castToShort(long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.time.TimeToTimeWithTimeZoneCast
 
castToShort(long, ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.timestamptz.VarcharToTimestampWithTimeZoneCast
 
castToShort(long, ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.timetz.VarcharToTimeWithTimeZoneCast
 
castToShort(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timestamptz.DateToTimestampWithTimeZoneCast
 
castToShortTimestamp(int, String) - Static method in class io.prestosql.operator.scalar.timestamp.VarcharToTimestampCast
 
castToSlice(long) - Static method in class io.prestosql.type.DateOperators
 
castToSlice(long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
castToSlice(long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
castToSmallint(boolean) - Static method in class io.prestosql.type.BooleanOperators
 
castToSmallint(double) - Static method in class io.prestosql.type.DoubleOperators
 
castToSmallint(long) - Static method in class io.prestosql.type.BigintOperators
 
castToSmallint(long) - Static method in class io.prestosql.type.IntegerOperators
 
castToSmallint(long) - Static method in class io.prestosql.type.RealOperators
 
castToSmallint(long) - Static method in class io.prestosql.type.TinyintOperators
 
castToSmallint(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToSmallint(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
castToTime(long, long, long) - Static method in class io.prestosql.operator.scalar.time.TimeOperators
 
castToTinyint(boolean) - Static method in class io.prestosql.type.BooleanOperators
 
castToTinyint(double) - Static method in class io.prestosql.type.DoubleOperators
 
castToTinyint(long) - Static method in class io.prestosql.type.BigintOperators
 
castToTinyint(long) - Static method in class io.prestosql.type.IntegerOperators
 
castToTinyint(long) - Static method in class io.prestosql.type.RealOperators
 
castToTinyint(long) - Static method in class io.prestosql.type.SmallintOperators
 
castToTinyint(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToTinyint(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
castToVarchar(boolean) - Static method in class io.prestosql.type.BooleanOperators
 
castToVarchar(double) - Static method in class io.prestosql.type.DoubleOperators
 
castToVarchar(long) - Static method in class io.prestosql.type.BigintOperators
 
castToVarchar(long) - Static method in class io.prestosql.type.IntegerOperators
 
castToVarchar(long) - Static method in class io.prestosql.type.RealOperators
 
castToVarchar(long) - Static method in class io.prestosql.type.SmallintOperators
 
castToVarchar(long) - Static method in class io.prestosql.type.TinyintOperators
 
castToVarchar(long, long) - Static method in class io.prestosql.operator.scalar.time.TimeOperators
 
castToVarchar(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToVarchar(Type, Object) - Method in class io.prestosql.sql.planner.planprinter.ValuePrinter
 
castToVarcharOrFail(Type, Object) - Method in class io.prestosql.sql.planner.planprinter.ValuePrinter
 
castVarcharToCodePoints(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
castVarcharToJoniRegexp(Slice) - Static method in class io.prestosql.operator.scalar.JoniRegexpCasts
 
castVarcharToJsonPath(Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
castVarcharToRe2JRegexp(int, int) - Static method in class io.prestosql.operator.scalar.Re2JCastToRegexpFunction
 
Catalog - Class in io.prestosql.metadata
 
Catalog(String, CatalogName, Connector, CatalogName, Connector, CatalogName, Connector) - Constructor for class io.prestosql.metadata.Catalog
 
CATALOG_TABLE - Static variable in class io.prestosql.connector.system.CatalogSystemTable
 
CATALOG_TABLE_NAME - Static variable in class io.prestosql.connector.system.CatalogSystemTable
 
catalogExists(Session, String) - Method in interface io.prestosql.metadata.Metadata
 
catalogExists(Session, String) - Method in class io.prestosql.metadata.MetadataManager
 
CatalogJdbcTable - Class in io.prestosql.connector.system.jdbc
 
CatalogJdbcTable(Metadata, AccessControl) - Constructor for class io.prestosql.connector.system.jdbc.CatalogJdbcTable
 
CatalogManager - Class in io.prestosql.metadata
 
CatalogManager() - Constructor for class io.prestosql.metadata.CatalogManager
 
CatalogMetadata - Class in io.prestosql.metadata
 
CatalogMetadata(CatalogName, ConnectorMetadata, ConnectorTransactionHandle, CatalogName, ConnectorMetadata, ConnectorTransactionHandle, CatalogName, ConnectorMetadata, ConnectorTransactionHandle, Set<ConnectorCapabilities>) - Constructor for class io.prestosql.metadata.CatalogMetadata
 
CatalogName - Class in io.prestosql.connector
 
CatalogName(String) - Constructor for class io.prestosql.connector.CatalogName
 
CatalogSystemTable - Class in io.prestosql.connector.system
 
CatalogSystemTable(Metadata, AccessControl) - Constructor for class io.prestosql.connector.system.CatalogSystemTable
 
cbrt(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
ceiling(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
ceiling(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
ceilingFloat(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
ceilingInteger(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
ceilingLong(long, Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Ceiling
 
ceilingLongShort(long, Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Ceiling
 
ceilingShort(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions.Ceiling
 
ceilingSmallint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
ceilingTinyint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
CentralMomentsAggregation - Class in io.prestosql.operator.aggregation
 
CentralMomentsState - Interface in io.prestosql.operator.aggregation.state
 
CertificateAuthenticator - Class in io.prestosql.server.security
 
CertificateAuthenticator(CertificateAuthenticatorManager, CertificateConfig) - Constructor for class io.prestosql.server.security.CertificateAuthenticator
 
CertificateAuthenticatorManager - Class in io.prestosql.server.security
 
CertificateAuthenticatorManager() - Constructor for class io.prestosql.server.security.CertificateAuthenticatorManager
 
CertificateConfig - Class in io.prestosql.server.security
 
CertificateConfig() - Constructor for class io.prestosql.server.security.CertificateConfig
 
ChallengeFailedException - Exception in io.prestosql.server.security.oauth2
 
ChallengeFailedException(String) - Constructor for exception io.prestosql.server.security.oauth2.ChallengeFailedException
 
ChallengeFailedException(String, Throwable) - Constructor for exception io.prestosql.server.security.oauth2.ChallengeFailedException
 
Channel(DynamicFilterId, Type, int) - Constructor for class io.prestosql.operator.DynamicFilterSourceOperator.Channel
 
ChannelSet - Class in io.prestosql.operator
 
ChannelSet(GroupByHash, boolean, int[]) - Constructor for class io.prestosql.operator.ChannelSet
 
ChannelSet.ChannelSetBuilder - Class in io.prestosql.operator
 
ChannelSetBuilder(Type, Optional<Integer>, int, OperatorContext, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.ChannelSet.ChannelSetBuilder
 
channelsToPages(List<List<Block>>) - Static method in class io.prestosql.operator.JoinUtils
 
CHAR - Static variable in class io.prestosql.type.CharParametricType
 
CharacterStringCasts - Class in io.prestosql.operator.scalar
 
charLeftTrim(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
charLeftTrim(Slice, int[]) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
charLength(long, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
charLower(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
CharParametricType - Class in io.prestosql.type
 
CharParametricType() - Constructor for class io.prestosql.type.CharParametricType
 
charRightTrim(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
charRightTrim(Slice, int[]) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
charSubstr(Long, Slice, long, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
charSubstring(Long, Slice, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
charToCharCast(Long, Long, Slice) - Static method in class io.prestosql.operator.scalar.CharacterStringCasts
 
charToVarcharCast(Long, Long, Slice) - Static method in class io.prestosql.operator.scalar.CharacterStringCasts
 
charTrim(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
charTrim(Slice, int[]) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
charUpper(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
checkAndSetActive(TransactionId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
checkAndSetActive(TransactionId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
checkAndSetActive(TransactionId) - Method in interface io.prestosql.transaction.TransactionManager
 
checkArrayIndex(long) - Static method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
checkBlockIsNotNull(Block) - Static method in class io.prestosql.operator.scalar.MapToMapCast
 
checkBooleanIsNotNull(Boolean) - Static method in class io.prestosql.operator.scalar.MapToMapCast
 
checkCanAddColumn(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanAddColumns(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to add columns to the specified table.
checkCanAddColumns(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanAddColumns(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanAddColumns(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanAddColumns(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanAddColumns(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanCreateRole(SecurityContext, String, Optional<PrestoPrincipal>, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to create the specified role.
checkCanCreateRole(SecurityContext, String, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanCreateRole(SecurityContext, String, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanCreateRole(SecurityContext, String, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanCreateRole(SecurityContext, String, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanCreateRole(ConnectorSecurityContext, String, Optional<PrestoPrincipal>) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanCreateSchema(SecurityContext, CatalogSchemaName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to create the specified schema.
checkCanCreateSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanCreateSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanCreateSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanCreateSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanCreateSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanCreateSchema(ConnectorSecurityContext, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanCreateTable(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to create the specified table.
checkCanCreateTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanCreateTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanCreateTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanCreateTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanCreateTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanCreateTable(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanCreateView(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to create the specified view.
checkCanCreateView(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanCreateView(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanCreateView(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanCreateView(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanCreateView(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanCreateView(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanCreateViewWithSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to create a view that selects from the specified columns.
checkCanCreateViewWithSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.AccessControlManager
 
checkCanCreateViewWithSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanCreateViewWithSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanCreateViewWithSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanCreateViewWithSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.ViewAccessControl
 
checkCanCreateViewWithSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanCreateViewWithSelectFromColumns(ConnectorSecurityContext, SchemaTableName, Set<String>) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanDeleteFromTable(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to delete from the specified table.
checkCanDeleteFromTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDeleteFromTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDeleteFromTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDeleteFromTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanDeleteFromTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanDeleteFromTable(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanDropColumn(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to drop columns from the specified table.
checkCanDropColumn(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDropColumn(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDropColumn(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDropColumn(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanDropColumn(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanDropColumn(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanDropRole(SecurityContext, String, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to drop the specified role.
checkCanDropRole(SecurityContext, String, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDropRole(SecurityContext, String, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDropRole(SecurityContext, String, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDropRole(SecurityContext, String, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanDropRole(ConnectorSecurityContext, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanDropSchema(SecurityContext, CatalogSchemaName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to drop the specified schema.
checkCanDropSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDropSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDropSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDropSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanDropSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanDropSchema(ConnectorSecurityContext, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanDropTable(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to drop the specified table.
checkCanDropTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDropTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDropTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDropTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanDropTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanDropTable(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanDropView(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to drop the specified view.
checkCanDropView(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDropView(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDropView(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDropView(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanDropView(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanDropView(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanExecuteFunction(SecurityContext, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to execute function
checkCanExecuteFunction(SecurityContext, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanExecuteFunction(SecurityContext, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanExecuteFunction(SecurityContext, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanExecuteFunction(SecurityContext, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanExecuteFunction(SecurityContext, String) - Method in class io.prestosql.security.ViewAccessControl
 
checkCanExecuteFunction(SecurityContext, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanExecuteProcedure(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to execute procedure
checkCanExecuteProcedure(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanExecuteProcedure(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanExecuteProcedure(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanExecuteProcedure(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanExecuteProcedure(ConnectorSecurityContext, SchemaRoutineName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanExecuteQuery(Identity) - Method in interface io.prestosql.security.AccessControl
Checks if identity can execute a query.
checkCanExecuteQuery(Identity) - Method in class io.prestosql.security.AccessControlManager
 
checkCanExecuteQuery(Identity) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanExecuteQuery(Identity) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanExecuteQuery(Identity) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanExecuteQuery(Identity) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanGrantExecuteFunctionPrivilege(SecurityContext, String, Identity, boolean) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to create a view that executes the function.
checkCanGrantExecuteFunctionPrivilege(SecurityContext, String, Identity, boolean) - Method in class io.prestosql.security.AccessControlManager
 
checkCanGrantExecuteFunctionPrivilege(SecurityContext, String, Identity, boolean) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanGrantExecuteFunctionPrivilege(SecurityContext, String, Identity, boolean) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanGrantExecuteFunctionPrivilege(SecurityContext, String, Identity, boolean) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanGrantExecuteFunctionPrivilege(SecurityContext, String, Identity, boolean) - Method in class io.prestosql.security.ViewAccessControl
 
checkCanGrantExecuteFunctionPrivilege(SecurityContext, String, Identity, boolean) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanGrantRoles(SecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to grant the specified roles to the specified principals.
checkCanGrantRoles(SecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanGrantRoles(SecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanGrantRoles(SecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanGrantRoles(SecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanGrantRoles(ConnectorSecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanGrantSchemaPrivilege(SecurityContext, Privilege, CatalogSchemaName, PrestoPrincipal, boolean) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to grant a privilege to the grantee on the specified schema.
checkCanGrantSchemaPrivilege(SecurityContext, Privilege, CatalogSchemaName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AccessControlManager
 
checkCanGrantSchemaPrivilege(SecurityContext, Privilege, CatalogSchemaName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanGrantSchemaPrivilege(SecurityContext, Privilege, CatalogSchemaName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanGrantSchemaPrivilege(SecurityContext, Privilege, CatalogSchemaName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanGrantSchemaPrivilege(ConnectorSecurityContext, Privilege, String, PrestoPrincipal, boolean) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanGrantTablePrivilege(SecurityContext, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to grant a privilege to the grantee on the specified table.
checkCanGrantTablePrivilege(SecurityContext, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AccessControlManager
 
checkCanGrantTablePrivilege(SecurityContext, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanGrantTablePrivilege(SecurityContext, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanGrantTablePrivilege(SecurityContext, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanGrantTablePrivilege(ConnectorSecurityContext, Privilege, SchemaTableName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanImpersonateUser(Identity, String) - Method in interface io.prestosql.security.AccessControl
Check if the identity is allowed impersonate the specified user.
checkCanImpersonateUser(Identity, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanImpersonateUser(Identity, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanImpersonateUser(Identity, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanImpersonateUser(Identity, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanImpersonateUser(Identity, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanInsertIntoTable(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to insert into the specified table.
checkCanInsertIntoTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanInsertIntoTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanInsertIntoTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanInsertIntoTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanInsertIntoTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanInsertIntoTable(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanKillQueryOwnedBy(Identity, String) - Method in interface io.prestosql.security.AccessControl
Checks if identity can kill a query owned by the specified user.
checkCanKillQueryOwnedBy(Identity, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanKillQueryOwnedBy(Identity, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanKillQueryOwnedBy(Identity, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanKillQueryOwnedBy(Identity, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanKillQueryOwnedBy(Identity, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanKillQueryOwnedBy(Identity, String, AccessControl) - Static method in class io.prestosql.security.AccessControlUtil
 
checkCanReadSystemInformation(Identity) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to read system information such as statistics, service registry, thread stacks, etc.
checkCanReadSystemInformation(Identity) - Method in class io.prestosql.security.AccessControlManager
 
checkCanReadSystemInformation(Identity) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanReadSystemInformation(Identity) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanReadSystemInformation(Identity) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanRenameColumn(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to rename a column in the specified table.
checkCanRenameColumn(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRenameColumn(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRenameColumn(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRenameColumn(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanRenameColumn(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanRenameColumn(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanRenameSchema(SecurityContext, CatalogSchemaName, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to rename the specified schema.
checkCanRenameSchema(SecurityContext, CatalogSchemaName, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRenameSchema(SecurityContext, CatalogSchemaName, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRenameSchema(SecurityContext, CatalogSchemaName, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRenameSchema(SecurityContext, CatalogSchemaName, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanRenameSchema(SecurityContext, CatalogSchemaName, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanRenameSchema(ConnectorSecurityContext, String, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanRenameTable(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to rename the specified table.
checkCanRenameTable(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRenameTable(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRenameTable(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRenameTable(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanRenameTable(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanRenameTable(ConnectorSecurityContext, SchemaTableName, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanRenameView(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to rename the specified view.
checkCanRenameView(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRenameView(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRenameView(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRenameView(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanRenameView(SecurityContext, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanRenameView(ConnectorSecurityContext, SchemaTableName, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanRevokeRoles(SecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to revoke the specified roles from the specified principals.
checkCanRevokeRoles(SecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRevokeRoles(SecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRevokeRoles(SecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRevokeRoles(SecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanRevokeRoles(ConnectorSecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanRevokeSchemaPrivilege(SecurityContext, Privilege, CatalogSchemaName, PrestoPrincipal, boolean) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to revoke a privilege from the revokee on the specified schema.
checkCanRevokeSchemaPrivilege(SecurityContext, Privilege, CatalogSchemaName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRevokeSchemaPrivilege(SecurityContext, Privilege, CatalogSchemaName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRevokeSchemaPrivilege(SecurityContext, Privilege, CatalogSchemaName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRevokeSchemaPrivilege(SecurityContext, Privilege, CatalogSchemaName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanRevokeSchemaPrivilege(ConnectorSecurityContext, Privilege, String, PrestoPrincipal, boolean) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanRevokeTablePrivilege(SecurityContext, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to revoke a privilege from the revokee on the specified table.
checkCanRevokeTablePrivilege(SecurityContext, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRevokeTablePrivilege(SecurityContext, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRevokeTablePrivilege(SecurityContext, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRevokeTablePrivilege(SecurityContext, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanRevokeTablePrivilege(ConnectorSecurityContext, Privilege, SchemaTableName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to select from the specified columns.
checkCanSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.ViewAccessControl
 
checkCanSelectFromColumns(SecurityContext, QualifiedObjectName, Set<String>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanSelectFromColumns(ConnectorSecurityContext, SchemaTableName, Set<String>) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanSetCatalogSessionProperty(SecurityContext, String, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to set the specified catalog property.
checkCanSetCatalogSessionProperty(SecurityContext, String, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetCatalogSessionProperty(SecurityContext, String, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetCatalogSessionProperty(SecurityContext, String, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetCatalogSessionProperty(SecurityContext, String, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanSetCatalogSessionProperty(SecurityContext, String, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanSetCatalogSessionProperty(ConnectorSecurityContext, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanSetColumnComment(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to comment the specified column.
checkCanSetColumnComment(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetColumnComment(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetColumnComment(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetColumnComment(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanSetColumnComment(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanSetColumnComment(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanSetRole(SecurityContext, String, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to set role for specified catalog.
checkCanSetRole(SecurityContext, String, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetRole(SecurityContext, String, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetRole(SecurityContext, String, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetRole(SecurityContext, String, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanSetRole(ConnectorSecurityContext, String, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanSetSchemaAuthorization(SecurityContext, CatalogSchemaName, PrestoPrincipal) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to change the specified schema's user/role.
checkCanSetSchemaAuthorization(SecurityContext, CatalogSchemaName, PrestoPrincipal) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetSchemaAuthorization(SecurityContext, CatalogSchemaName, PrestoPrincipal) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetSchemaAuthorization(SecurityContext, CatalogSchemaName, PrestoPrincipal) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetSchemaAuthorization(SecurityContext, CatalogSchemaName, PrestoPrincipal) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanSetSchemaAuthorization(ConnectorSecurityContext, String, PrestoPrincipal) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanSetSystemSessionProperty(Identity, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to set the specified system property.
checkCanSetSystemSessionProperty(Identity, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetSystemSessionProperty(Identity, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetSystemSessionProperty(Identity, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetSystemSessionProperty(Identity, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanSetSystemSessionProperty(Identity, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanSetTableAuthorization(SecurityContext, QualifiedObjectName, PrestoPrincipal) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to change the specified table's user/role.
checkCanSetTableAuthorization(SecurityContext, QualifiedObjectName, PrestoPrincipal) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetTableAuthorization(SecurityContext, QualifiedObjectName, PrestoPrincipal) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetTableAuthorization(SecurityContext, QualifiedObjectName, PrestoPrincipal) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetTableAuthorization(SecurityContext, QualifiedObjectName, PrestoPrincipal) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanSetTableAuthorization(ConnectorSecurityContext, SchemaTableName, PrestoPrincipal) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanSetTableComment(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to comment the specified table.
checkCanSetTableComment(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetTableComment(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetTableComment(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetTableComment(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanSetTableComment(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanSetTableComment(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanSetUser(Optional<Principal>, String) - Method in interface io.prestosql.security.AccessControl
Deprecated.
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.security.AccessControlManager
Deprecated.
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.security.ForwardingAccessControl
Deprecated.
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.testing.TestingAccessControlManager
Deprecated.
checkCanSetViewAuthorization(SecurityContext, QualifiedObjectName, PrestoPrincipal) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to change the specified view's user/role.
checkCanSetViewAuthorization(SecurityContext, QualifiedObjectName, PrestoPrincipal) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetViewAuthorization(SecurityContext, QualifiedObjectName, PrestoPrincipal) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetViewAuthorization(SecurityContext, QualifiedObjectName, PrestoPrincipal) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetViewAuthorization(SecurityContext, QualifiedObjectName, PrestoPrincipal) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanSetViewAuthorization(ConnectorSecurityContext, SchemaTableName, PrestoPrincipal) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanShowColumns(SecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to show columns of tables by executing SHOW COLUMNS, DESCRIBE etc.
checkCanShowColumns(SecurityContext, CatalogSchemaTableName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowColumns(SecurityContext, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowColumns(SecurityContext, CatalogSchemaTableName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowColumns(SecurityContext, CatalogSchemaTableName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanShowColumns(SecurityContext, CatalogSchemaTableName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanShowColumns(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanShowCreateSchema(SecurityContext, CatalogSchemaName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to execute SHOW CREATE SCHEMA.
checkCanShowCreateSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowCreateSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowCreateSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowCreateSchema(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanShowCreateSchema(ConnectorSecurityContext, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanShowCreateTable(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to execute SHOW CREATE TABLE, SHOW CREATE VIEW or SHOW CREATE MATERIALIZED VIEW
checkCanShowCreateTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowCreateTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowCreateTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowCreateTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanShowCreateTable(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanShowCreateTable(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanShowCurrentRoles(SecurityContext, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to show current roles on the specified catalog.
checkCanShowCurrentRoles(SecurityContext, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowCurrentRoles(SecurityContext, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowCurrentRoles(SecurityContext, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowCurrentRoles(SecurityContext, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanShowCurrentRoles(ConnectorSecurityContext, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanShowRoleAuthorizationDescriptors(SecurityContext, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to show role authorization descriptors (i.e.
checkCanShowRoleAuthorizationDescriptors(SecurityContext, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowRoleAuthorizationDescriptors(SecurityContext, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowRoleAuthorizationDescriptors(SecurityContext, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowRoleAuthorizationDescriptors(SecurityContext, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanShowRoleAuthorizationDescriptors(ConnectorSecurityContext, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanShowRoleGrants(SecurityContext, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to show its own role grants on the specified catalog.
checkCanShowRoleGrants(SecurityContext, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowRoleGrants(SecurityContext, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowRoleGrants(SecurityContext, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowRoleGrants(SecurityContext, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanShowRoleGrants(ConnectorSecurityContext, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanShowRoles(SecurityContext, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to show roles on the specified catalog.
checkCanShowRoles(SecurityContext, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowRoles(SecurityContext, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowRoles(SecurityContext, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowRoles(SecurityContext, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanShowRoles(ConnectorSecurityContext, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanShowSchemas(SecurityContext, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to execute SHOW SCHEMAS in a catalog.
checkCanShowSchemas(SecurityContext, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowSchemas(SecurityContext, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowSchemas(SecurityContext, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowSchemas(SecurityContext, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanShowSchemas(ConnectorSecurityContext) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanShowTables(SecurityContext, CatalogSchemaName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to show tables by executing SHOW TABLES, SHOW GRANTS etc.
checkCanShowTables(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowTables(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowTables(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowTables(SecurityContext, CatalogSchemaName) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanShowTables(ConnectorSecurityContext, String) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
checkCanViewQueryOwnedBy(Identity, String) - Method in interface io.prestosql.security.AccessControl
Checks if identity can view a query owned by the specified user.
checkCanViewQueryOwnedBy(Identity, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanViewQueryOwnedBy(Identity, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanViewQueryOwnedBy(Identity, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanViewQueryOwnedBy(Identity, String) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCanViewQueryOwnedBy(Identity, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanViewQueryOwnedBy(Identity, String, AccessControl) - Static method in class io.prestosql.security.AccessControlUtil
 
checkCanWriteSystemInformation(Identity) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to write system information such as marking nodes offline, or changing runtime flags.
checkCanWriteSystemInformation(Identity) - Method in class io.prestosql.security.AccessControlManager
 
checkCanWriteSystemInformation(Identity) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanWriteSystemInformation(Identity) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanWriteSystemInformation(Identity) - Method in class io.prestosql.security.ForwardingAccessControl
 
checkCatalogName(String) - Static method in class io.prestosql.metadata.MetadataUtil
 
checkCondition(boolean, ErrorCodeSupplier, String, Object...) - Static method in class io.prestosql.util.Failures
 
checkDependencies() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
checkDoubleIsNotNull(Double) - Static method in class io.prestosql.operator.scalar.MapToMapCast
 
checkElementNotNull(boolean, String) - Static method in class io.prestosql.type.TypeUtils
 
checkIndex(Block, long) - Static method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
checkLoginCredentials(String, String, boolean) - Method in class io.prestosql.server.ui.FormWebUiAuthenticationFilter
 
checkLongIsNotNull(Long) - Static method in class io.prestosql.operator.scalar.MapToMapCast
 
checkLowerCase(String, String) - Static method in class io.prestosql.metadata.MetadataUtil
 
checkMaxEntry(int) - Static method in class io.prestosql.operator.scalar.SequenceFunction
 
checkMergeable(PlanNodeStats) - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
checkObjectName(String, String, String) - Static method in class io.prestosql.metadata.MetadataUtil
 
checkSchemaName(String) - Static method in class io.prestosql.metadata.MetadataUtil
 
checkSliceIsNotNull(Slice) - Static method in class io.prestosql.operator.scalar.MapToMapCast
 
CheckSubqueryNodesAreRewritten - Class in io.prestosql.sql.planner.optimizations
 
CheckSubqueryNodesAreRewritten() - Constructor for class io.prestosql.sql.planner.optimizations.CheckSubqueryNodesAreRewritten
 
checksum() - Method in class io.prestosql.operator.JoinHashSupplier
 
checksum() - Method in interface io.prestosql.operator.LookupSourceSupplier
 
checksum() - Method in interface io.prestosql.operator.PositionLinks.Factory
 
ChecksumAggregationFunction - Class in io.prestosql.operator.aggregation
 
ChecksumAggregationFunction(BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
checkTableName(String) - Static method in class io.prestosql.metadata.MetadataUtil
 
checkTableName(String, Optional<String>, Optional<String>) - Static method in class io.prestosql.metadata.MetadataUtil
 
checkTimeoutNotExhausted() - Method in interface io.prestosql.sql.planner.iterative.Rule.Context
 
checkTypeParameters(TypeSignature, Set<String>, AnnotatedElement) - Static method in interface io.prestosql.operator.annotations.ImplementationDependency
 
checkValidStep(long, long, long) - Static method in class io.prestosql.operator.scalar.SequenceFunction
 
checkValidTransition(OutputBuffers) - Method in class io.prestosql.execution.buffer.OutputBuffers
 
ChildReplacer - Class in io.prestosql.sql.planner.plan
 
choice(Function<PolymorphicScalarFunctionBuilder.ChoiceBuilder, PolymorphicScalarFunctionBuilder.ChoiceBuilder>) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
ChoicesScalarFunctionImplementation - Class in io.prestosql.operator.scalar
 
ChoicesScalarFunctionImplementation(FunctionBinding, InvocationConvention.InvocationReturnConvention, List<InvocationConvention.InvocationArgumentConvention>, MethodHandle) - Constructor for class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation
 
ChoicesScalarFunctionImplementation(FunctionBinding, InvocationConvention.InvocationReturnConvention, List<InvocationConvention.InvocationArgumentConvention>, MethodHandle, Optional<MethodHandle>) - Constructor for class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation
 
ChoicesScalarFunctionImplementation(FunctionBinding, InvocationConvention.InvocationReturnConvention, List<InvocationConvention.InvocationArgumentConvention>, List<Class<?>>, MethodHandle, Optional<MethodHandle>) - Constructor for class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation
 
ChoicesScalarFunctionImplementation(FunctionBinding, List<ChoicesScalarFunctionImplementation.ScalarImplementationChoice>) - Constructor for class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation
Creates a ScalarFunctionImplementation consisting of one or more choices.
ChoicesScalarFunctionImplementation.ScalarImplementationChoice - Class in io.prestosql.operator.scalar
 
chooseQueryToKill(List<LowMemoryKiller.QueryMemoryInfo>, List<MemoryInfo>) - Method in interface io.prestosql.memory.LowMemoryKiller
 
chooseQueryToKill(List<LowMemoryKiller.QueryMemoryInfo>, List<MemoryInfo>) - Method in class io.prestosql.memory.NoneLowMemoryKiller
 
chooseQueryToKill(List<LowMemoryKiller.QueryMemoryInfo>, List<MemoryInfo>) - Method in class io.prestosql.memory.TotalReservationLowMemoryKiller
 
chooseQueryToKill(List<LowMemoryKiller.QueryMemoryInfo>, List<MemoryInfo>) - Method in class io.prestosql.memory.TotalReservationOnBlockedNodesLowMemoryKiller
 
chr(long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
cleanupOldSpillFiles() - Method in class io.prestosql.spiller.FileSingleStreamSpillerFactory
 
cleanupQuery(Session) - Method in interface io.prestosql.metadata.Metadata
Cleanup after a query.
cleanupQuery(Session) - Method in class io.prestosql.metadata.MetadataManager
 
clear() - Method in class io.prestosql.operator.PagesIndex
 
clear() - Method in class io.prestosql.testing.TestingMetadata
 
clear() - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
clear() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
 
clear() - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
clearTransactionId() - Method in class io.prestosql.execution.QueryStateMachine
 
clientFailed(HttpPageBufferClient, Throwable) - Method in interface io.prestosql.operator.HttpPageBufferClient.ClientCallback
 
clientFinished(HttpPageBufferClient) - Method in interface io.prestosql.operator.HttpPageBufferClient.ClientCallback
 
close() - Method in class io.prestosql.connector.informationschema.InformationSchemaPageSource
 
close() - Method in class io.prestosql.execution.buffer.PagesSerde.PagesSerdeContext
 
close() - Method in class io.prestosql.execution.scheduler.FixedSourcePartitionedScheduler
 
close() - Method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
 
close() - Method in interface io.prestosql.execution.scheduler.SourceScheduler
 
close() - Method in interface io.prestosql.execution.scheduler.StageScheduler
 
close() - Method in interface io.prestosql.execution.SplitRunner
 
close() - Method in class io.prestosql.execution.SqlTaskManager
 
close() - Method in class io.prestosql.execution.TaskManagementExecutor
 
close() - Method in interface io.prestosql.operator.aggregation.builder.HashAggregationBuilder
 
close() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
close() - Method in class io.prestosql.operator.aggregation.builder.MergingHashAggregationBuilder
 
close() - Method in class io.prestosql.operator.aggregation.builder.SpillableHashAggregationBuilder
 
close() - Method in class io.prestosql.operator.AggregationOperator
 
close() - Method in class io.prestosql.operator.BasicWorkProcessorOperatorAdapter
 
close() - Method in class io.prestosql.operator.DeleteOperator
 
close() - Method in class io.prestosql.operator.Driver
 
close() - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeSinkFactory
 
close() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator
 
close() - Method in class io.prestosql.operator.exchange.LocalExchangeSource
 
close() - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator
 
close() - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator
 
close() - Method in class io.prestosql.operator.ExchangeClient
 
close() - Method in class io.prestosql.operator.ExchangeOperator
 
close() - Method in class io.prestosql.operator.HashAggregationOperator
 
close() - Method in class io.prestosql.operator.HashBuilderOperator
 
close() - Method in class io.prestosql.operator.HttpPageBufferClient
 
close() - Method in interface io.prestosql.operator.index.IndexedData
 
close() - Method in class io.prestosql.operator.index.IndexLookupSource
 
close() - Method in class io.prestosql.operator.index.IndexSnapshot
 
close() - Method in class io.prestosql.operator.index.IndexSourceOperator
 
close() - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
close() - Method in class io.prestosql.operator.index.StreamingIndexedData
 
close() - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
close() - Method in class io.prestosql.operator.JoinHash
 
close() - Method in class io.prestosql.operator.LookupJoinOperator
 
close() - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
close() - Method in class io.prestosql.operator.LookupOuterOperator
 
close() - Method in interface io.prestosql.operator.LookupSource
 
close() - Method in interface io.prestosql.operator.LookupSourceProvider
 
close() - Method in class io.prestosql.operator.MergeHashSort
 
close() - Method in class io.prestosql.operator.MergeOperator
 
close() - Method in class io.prestosql.operator.NestedLoopJoinOperator
 
close() - Method in interface io.prestosql.operator.Operator
This method will always be called before releasing the Operator reference.
close() - Method in class io.prestosql.operator.OrderByOperator
 
close() - Method in class io.prestosql.operator.OuterLookupSource
 
close() - Method in class io.prestosql.operator.PageSourceOperator
 
close() - Method in class io.prestosql.operator.PartitionedLookupSource
 
close() - Method in class io.prestosql.operator.RowReferencePageManager.LoadCursor
 
close() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
close() - Method in class io.prestosql.operator.SpatialIndexBuilderOperator
 
close() - Method in class io.prestosql.operator.SpatialJoinOperator
 
close() - Method in interface io.prestosql.operator.SpillContext
 
close() - Method in class io.prestosql.operator.StaticLookupSourceProvider
 
close() - Method in class io.prestosql.operator.TableFinishOperator
 
close() - Method in class io.prestosql.operator.TableScanOperator
 
close() - Method in class io.prestosql.operator.TableScanWorkProcessorOperator
 
close() - Method in class io.prestosql.operator.TableWriterOperator
 
close() - Method in class io.prestosql.operator.WindowOperator
 
close() - Method in interface io.prestosql.operator.WorkProcessorOperator
 
close() - Method in class io.prestosql.operator.WorkProcessorOperatorAdapter
 
close() - Method in interface io.prestosql.operator.WorkProcessorOperatorFactory
 
close() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
close() - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
close() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
close() - Method in class io.prestosql.spiller.AesSpillCipher
 
close() - Method in class io.prestosql.spiller.FileSingleStreamSpiller
 
close() - Method in class io.prestosql.spiller.GenericPartitioningSpiller
 
close() - Method in class io.prestosql.spiller.GenericSpiller
 
close() - Method in class io.prestosql.spiller.LocalSpillContext
 
close() - Method in interface io.prestosql.spiller.PartitioningSpiller
Closes and removes all underlying resources used during spilling.
close() - Method in interface io.prestosql.spiller.SingleStreamSpiller
Close releases/removes all underlying resources used during spilling like for example all created temporary files.
close() - Method in interface io.prestosql.spiller.SpillCipher
Destroys the cipher, preventing future use.
close() - Method in interface io.prestosql.spiller.Spiller
Close releases/removes all underlying resources used during spilling like for example all created temporary files.
close() - Method in class io.prestosql.split.BufferingSplitSource
 
close() - Method in class io.prestosql.split.ConnectorAwareSplitSource
 
close() - Method in class io.prestosql.split.MappedPageSource
 
close() - Method in class io.prestosql.split.SampledSplitSource
 
close() - Method in interface io.prestosql.split.SplitSource
 
close() - Method in class io.prestosql.testing.LocalQueryRunner
 
close() - Method in class io.prestosql.testing.PageConsumerOperator
 
close() - Method in interface io.prestosql.testing.QueryRunner
 
close() - Method in class io.prestosql.util.AutoCloseableCloser
 
CLOSED - io.prestosql.operator.HashBuilderOperator.State
No longer needed
closeSinks(LocalExchange.LocalExchangeSinkFactoryId) - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeFactory
 
ClusterInfo(NodeVersion, String, Duration) - Constructor for class io.prestosql.server.ui.ClusterResource.ClusterInfo
 
ClusterMemoryLeakDetector - Class in io.prestosql.memory
 
ClusterMemoryLeakDetector() - Constructor for class io.prestosql.memory.ClusterMemoryLeakDetector
 
ClusterMemoryManager - Class in io.prestosql.memory
 
ClusterMemoryManager(HttpClient, InternalNodeManager, LocationFactory, MBeanExporter, JsonCodec<MemoryInfo>, JsonCodec<MemoryPoolAssignmentsRequest>, QueryIdGenerator, LowMemoryKiller, ServerConfig, MemoryManagerConfig, NodeMemoryConfig, NodeSchedulerConfig) - Constructor for class io.prestosql.memory.ClusterMemoryManager
 
ClusterMemoryPool - Class in io.prestosql.memory
 
ClusterMemoryPool(MemoryPoolId) - Constructor for class io.prestosql.memory.ClusterMemoryPool
 
ClusterResource - Class in io.prestosql.server.ui
 
ClusterResource(NodeVersion, NodeInfo) - Constructor for class io.prestosql.server.ui.ClusterResource
 
ClusterResource.ClusterInfo - Class in io.prestosql.server.ui
 
ClusterSizeMonitor - Class in io.prestosql.execution
 
ClusterSizeMonitor(InternalNodeManager, boolean) - Constructor for class io.prestosql.execution.ClusterSizeMonitor
 
ClusterSizeMonitor(InternalNodeManager, NodeSchedulerConfig) - Constructor for class io.prestosql.execution.ClusterSizeMonitor
 
ClusterStats(long, long, long, long, long, long, long, double, long, long, long) - Constructor for class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
ClusterStatsResource - Class in io.prestosql.server.ui
 
ClusterStatsResource(NodeSchedulerConfig, InternalNodeManager, DispatchManager, ClusterMemoryManager) - Constructor for class io.prestosql.server.ui.ClusterStatsResource
 
ClusterStatsResource.ClusterStats - Class in io.prestosql.server.ui
 
COALESCE - io.prestosql.sql.relational.SpecialForm.Form
 
CoalesceCodeGenerator - Class in io.prestosql.sql.gen
 
CoalesceCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.CoalesceCodeGenerator
 
CODE_POINTS - Static variable in class io.prestosql.type.CodePointsType
 
codepoint(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
codePointsToSliceUtf8(List<Integer>) - Static method in class io.prestosql.operator.scalar.CharacterStringCasts
 
CodePointsType - Class in io.prestosql.type
 
Coercer - Class in io.prestosql.sql.planner
 
coerceTypeBase(Type, String) - Method in class io.prestosql.type.TypeCoercion
coerceTypeBase and isCovariantParametrizedType defines all hand-coded rules for type coercion.
COLLECT_PLAN_STATISTICS_FOR_ALL_QUERIES - Static variable in class io.prestosql.SystemSessionProperties
 
COLOCATED_JOIN - Static variable in class io.prestosql.SystemSessionProperties
 
color(double, double, double, long, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
Interpolate a color between lowColor and highColor based the provided value
color(double, long, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
Interpolate a color between lowColor and highColor based on the provided value
color(Slice) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
COLOR - Static variable in class io.prestosql.type.ColorType
 
ColorFunctions - Class in io.prestosql.operator.scalar
 
ColorFunctions.SystemColor - Enum in io.prestosql.operator.scalar
 
ColorType - Class in io.prestosql.type
 
column(String, Type) - Method in class io.prestosql.metadata.MetadataUtil.TableMetadataBuilder
 
Column - Class in io.prestosql.execution
 
Column(String, String) - Constructor for class io.prestosql.execution.Column
 
ColumnConstraint(String, Type, IoPlanPrinter.FormattedDomain) - Constructor for class io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint
 
columnHandleModule(HandleResolver) - Static method in class io.prestosql.metadata.HandleJsonModule
 
ColumnJdbcTable - Class in io.prestosql.connector.system.jdbc
 
ColumnJdbcTable(Metadata, AccessControl) - Constructor for class io.prestosql.connector.system.jdbc.ColumnJdbcTable
 
columnMask(QualifiedObjectName, String, String, ViewExpression) - Method in class io.prestosql.testing.TestingAccessControlManager
 
ColumnPropertiesSystemTable - Class in io.prestosql.connector.system
 
ColumnPropertiesSystemTable(TransactionManager, Metadata) - Constructor for class io.prestosql.connector.system.ColumnPropertiesSystemTable
 
ColumnPropertyManager - Class in io.prestosql.metadata
 
ColumnPropertyManager() - Constructor for class io.prestosql.metadata.ColumnPropertyManager
 
COLUMNS - io.prestosql.connector.informationschema.InformationSchemaTable
 
ColumnStatisticMetadataKeyDeserializer() - Constructor for class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.ColumnStatisticMetadataKeyDeserializer
 
ColumnStatisticMetadataKeySerializer() - Constructor for class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.ColumnStatisticMetadataKeySerializer
 
combinations(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayCombinationsFunction
 
combine(BigintApproximateMostFrequent.State, BigintApproximateMostFrequent.State) - Static method in class io.prestosql.operator.aggregation.BigintApproximateMostFrequent
 
combine(HistogramState, HistogramState) - Static method in class io.prestosql.operator.aggregation.histogram.Histogram
 
combine(LongDoubleState, LongDoubleState) - Static method in class io.prestosql.operator.aggregation.DoubleSumAggregation
 
combine(LongLongState, LongLongState) - Static method in class io.prestosql.operator.aggregation.LongSumAggregation
 
combine(MinMaxByNState, MinMaxByNState) - Static method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
combine(MultimapAggregationState, MultimapAggregationState) - Static method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
combine(BlockPositionState, BlockPositionState) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
combine(CentralMomentsState, CentralMomentsState) - Static method in class io.prestosql.operator.aggregation.CentralMomentsAggregation
 
combine(CorrelationState, CorrelationState) - Static method in class io.prestosql.operator.aggregation.DoubleCorrelationAggregation
 
combine(CorrelationState, CorrelationState) - Static method in class io.prestosql.operator.aggregation.RealCorrelationAggregation
 
combine(CovarianceState, CovarianceState) - Static method in class io.prestosql.operator.aggregation.DoubleCovarianceAggregation
 
combine(CovarianceState, CovarianceState) - Static method in class io.prestosql.operator.aggregation.RealCovarianceAggregation
 
combine(HyperLogLogState, HyperLogLogState) - Static method in class io.prestosql.operator.aggregation.MergeHyperLogLogAggregation
 
combine(KeyValuePairsState, KeyValuePairsState) - Static method in class io.prestosql.operator.aggregation.MapAggregationFunction
 
combine(KeyValuePairsState, KeyValuePairsState) - Static method in class io.prestosql.operator.aggregation.MapUnionAggregation
 
combine(LongAndDoubleState, LongAndDoubleState) - Static method in class io.prestosql.operator.aggregation.AverageAggregations
 
combine(LongAndDoubleState, LongAndDoubleState) - Static method in class io.prestosql.operator.aggregation.GeometricMeanAggregations
 
combine(LongAndDoubleState, LongAndDoubleState) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondAverageAggregation
 
combine(LongAndDoubleState, LongAndDoubleState) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthAverageAggregation
 
combine(LongAndDoubleState, LongAndDoubleState) - Static method in class io.prestosql.operator.aggregation.RealGeometricMeanAggregations
 
combine(LongDecimalWithOverflowAndLongState, LongDecimalWithOverflowAndLongState) - Static method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
combine(LongDecimalWithOverflowState, LongDecimalWithOverflowState) - Static method in class io.prestosql.operator.aggregation.DecimalSumAggregation
 
combine(LongState, DoubleState, LongState, DoubleState) - Static method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
combine(LongState, LongState) - Static method in class io.prestosql.operator.aggregation.CountAggregation
 
combine(LongState, LongState) - Static method in class io.prestosql.operator.aggregation.CountColumn
 
combine(LongState, LongState) - Static method in class io.prestosql.operator.aggregation.CountIfAggregation
 
combine(MinMaxNState, MinMaxNState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
combine(NullableBooleanState, NullableBooleanState) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
combine(NullableBooleanState, NullableBooleanState, BinaryFunctionInterface, BinaryFunctionInterface) - Static method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
combine(NullableDoubleState, NullableDoubleState) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
combine(NullableDoubleState, NullableDoubleState) - Static method in class io.prestosql.operator.aggregation.RealSumAggregation
 
combine(NullableDoubleState, NullableDoubleState, BinaryFunctionInterface, BinaryFunctionInterface) - Static method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.BitwiseAndAggregation
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.BitwiseOrAggregation
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondSumAggregation
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthSumAggregation
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.MaxDataSizeForStats
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.SumDataSizeForStats
 
combine(NullableLongState, NullableLongState, BinaryFunctionInterface, BinaryFunctionInterface) - Static method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
combine(QuantileDigestAndPercentileState, QuantileDigestAndPercentileState) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
combine(QuantileDigestAndPercentileState, QuantileDigestAndPercentileState) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
combine(QuantileDigestAndPercentileState, QuantileDigestAndPercentileState) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
combine(QuantileDigestState, QuantileDigestState) - Static method in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
combine(RegressionState, RegressionState) - Static method in class io.prestosql.operator.aggregation.DoubleRegressionAggregation
 
combine(RegressionState, RegressionState) - Static method in class io.prestosql.operator.aggregation.RealRegressionAggregation
 
combine(TDigestAndPercentileArrayState, TDigestAndPercentileArrayState) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileArrayAggregations
 
combine(TDigestAndPercentileArrayState, TDigestAndPercentileArrayState) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileArrayAggregations
 
combine(TDigestAndPercentileArrayState, TDigestAndPercentileArrayState) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileArrayAggregations
 
combine(TDigestAndPercentileState, TDigestAndPercentileState) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
combine(TDigestAndPercentileState, TDigestAndPercentileState) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
combine(TDigestAndPercentileState, TDigestAndPercentileState) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
combine(TDigestState, TDigestState) - Static method in class io.prestosql.operator.aggregation.MergeTDigestAggregation
 
combine(TDigestState, TDigestState) - Static method in class io.prestosql.operator.aggregation.TDigestAggregationFunction
 
combine(TriStateBooleanState, TriStateBooleanState) - Static method in class io.prestosql.operator.aggregation.BooleanAndAggregation
 
combine(TriStateBooleanState, TriStateBooleanState) - Static method in class io.prestosql.operator.aggregation.BooleanOrAggregation
 
combine(VarianceState, VarianceState) - Static method in class io.prestosql.operator.aggregation.VarianceAggregation
 
combine(VarcharApproximateMostFrequent.State, VarcharApproximateMostFrequent.State) - Static method in class io.prestosql.operator.aggregation.VarcharApproximateMostFrequent
 
combine(Type, ArrayAggregationState, ArrayAggregationState) - Static method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
combine(SetDigestState, SetDigestState) - Static method in class io.prestosql.type.setdigest.BuildSetDigestAggregation
 
combine(SetDigestState, SetDigestState) - Static method in class io.prestosql.type.setdigest.MergeSetDigestAggregation
 
combine(MethodHandle, BlockPositionState, BlockPositionState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
combine(MethodHandle, NullableBooleanState, NullableBooleanState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
combine(MethodHandle, NullableDoubleState, NullableDoubleState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
combine(MethodHandle, NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
combine(Optional<T>, Optional<T>, BinaryOperator<T>) - Static method in class io.prestosql.util.Optionals
 
combineConjuncts(Metadata, Expression...) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineConjuncts(Metadata, Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineConjunctsWithDuplicates(Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineDisjuncts(Metadata, Expression...) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineDisjuncts(Metadata, Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineDisjunctsWithDefault(Metadata, Collection<Expression>, Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
CombineHashFunction - Class in io.prestosql.operator.scalar
 
combinePredicates(Metadata, LogicalBinaryExpression.Operator, Expression...) - Static method in class io.prestosql.sql.ExpressionUtils
 
combinePredicates(Metadata, LogicalBinaryExpression.Operator, Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineState(BooleanDistinctState, BooleanDistinctState) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
combineState(BooleanDistinctState, BooleanDistinctState) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
combineState(HyperLogLogState, HyperLogLogState) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
combineState(HyperLogLogState, HyperLogLogState) - Static method in class io.prestosql.operator.aggregation.ApproximateSetAggregation
 
combineState(HyperLogLogState, HyperLogLogState) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
combineState(QuantileDigestState, QuantileDigestState) - Static method in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
combineWith(ScheduleResult.BlockedReason) - Method in enum io.prestosql.execution.scheduler.ScheduleResult.BlockedReason
 
COMMENT_COLUMN - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
COMMENT_TABLE - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
CommentTask - Class in io.prestosql.execution
 
CommentTask() - Constructor for class io.prestosql.execution.CommentTask
 
CommitTask - Class in io.prestosql.execution
 
CommitTask() - Constructor for class io.prestosql.execution.CommitTask
 
compact() - Method in class io.prestosql.operator.NestedLoopJoinPagesBuilder
 
compact() - Method in class io.prestosql.operator.PagesIndex
 
compactIfNeeded() - Method in class io.prestosql.operator.RowReferencePageManager
 
comparableTypeParameter(String) - Static method in class io.prestosql.metadata.Signature
 
comparableWithVariadicBound(String, String) - Static method in class io.prestosql.metadata.Signature
 
comparator() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
compare(long, long) - Method in interface io.prestosql.operator.scalar.ArraysOverlapFunction.LongComparison
 
compare(Session, PlanCostEstimate, PlanCostEstimate) - Method in class io.prestosql.cost.CostComparator
 
compare(Block, int, Block, int) - Method in interface io.prestosql.type.BlockTypeOperators.BlockPositionComparison
 
compareAndSet(T, T) - Method in class io.prestosql.execution.StateMachine
Sets the state if the current state .equals() the specified expected state.
compareSortChannelPositions(int, int, int, int) - Method in interface io.prestosql.operator.PagesHashStrategy
Compares sort channel (if applicable) values at the specified positions.
compareSortChannelPositions(int, int, int, int) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
compareTo(int, int, int, Block, int, int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
compareTo(PrioritizedSplitRunner) - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
compareTo(PagesIndex, int, int) - Method in interface io.prestosql.operator.PagesIndexComparator
 
compareTo(PagesIndex, int, int) - Method in class io.prestosql.operator.SimpleChannelComparator
 
compareTo(PagesIndex, int, int) - Method in class io.prestosql.operator.SimplePagesIndexComparator
 
compareTo(ParametricScalarImplementation.ParametricScalarImplementationChoice) - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
compareTo(Page, int, Page, int) - Method in interface io.prestosql.operator.PageWithPositionComparator
 
compareTo(Page, int, Page, int) - Method in class io.prestosql.operator.SimplePageWithPositionComparator
 
compareTo(Symbol) - Method in class io.prestosql.sql.planner.Symbol
 
compareTo(LongComparator, long) - Method in interface io.prestosql.operator.GroupedTopNRowNumberAccumulator.RowReference
Compares the referenced row to the specified row ID using the provided row ID comparator.
compareTo(LongComparator, long) - Method in class io.prestosql.operator.RowReferencePageManager.LoadCursor
 
comparisonFunction(ComparisonExpression.Operator, Type, Type) - Method in class io.prestosql.sql.relational.StandardFunctionResolution
 
ComparisonStatsCalculator - Class in io.prestosql.cost
 
compile(RowExpression, Scope) - Method in class io.prestosql.sql.gen.RowExpressionCompiler
 
compile(RowExpression, Scope, Optional<Class<?>>) - Method in class io.prestosql.sql.gen.RowExpressionCompiler
 
compileCursorProcessor(Optional<RowExpression>, List<? extends RowExpression>, Object) - Method in class io.prestosql.sql.gen.ExpressionCompiler
 
compileFilter(RowExpression, Optional<String>) - Method in class io.prestosql.sql.gen.PageFunctionCompiler
 
compileJoinFilterFunction(RowExpression, int) - Method in class io.prestosql.sql.gen.JoinFilterFunctionCompiler
 
compileLambdaProvider(LambdaDefinitionExpression, Metadata, Class<?>) - Static method in class io.prestosql.sql.gen.LambdaBytecodeGenerator
 
compileLikePattern(Slice) - Static method in class io.prestosql.type.LikeFunctions
 
compileLookupSourceFactory(List<? extends Type>, List<Integer>, Optional<Integer>, Optional<List<Integer>>) - Method in class io.prestosql.sql.gen.JoinCompiler
 
compilePageProcessor(Optional<RowExpression>, List<? extends RowExpression>) - Method in class io.prestosql.sql.gen.ExpressionCompiler
 
compilePageProcessor(Optional<RowExpression>, List<? extends RowExpression>, int) - Method in class io.prestosql.sql.gen.ExpressionCompiler
 
compilePageProcessor(Optional<RowExpression>, List<? extends RowExpression>, Optional<String>) - Method in class io.prestosql.sql.gen.ExpressionCompiler
 
compilePagesHashStrategyFactory(List<Type>, List<Integer>) - Method in class io.prestosql.sql.gen.JoinCompiler
 
compilePagesHashStrategyFactory(List<Type>, List<Integer>, Optional<List<Integer>>) - Method in class io.prestosql.sql.gen.JoinCompiler
 
compilePagesIndexOrdering(List<Type>, List<Integer>, List<SortOrder>) - Method in class io.prestosql.sql.gen.OrderingCompiler
 
compilePageWithPositionComparator(List<Type>, List<Integer>, List<SortOrder>) - Method in class io.prestosql.sql.gen.OrderingCompiler
 
compileProjection(RowExpression, Optional<String>) - Method in class io.prestosql.sql.gen.PageFunctionCompiler
 
CompilerConfig - Class in io.prestosql.sql.planner
 
CompilerConfig() - Constructor for class io.prestosql.sql.planner.CompilerConfig
 
CompilerOperations - Class in io.prestosql.sql.gen
 
CompilerUtils - Class in io.prestosql.util
 
complete(T) - Method in class io.prestosql.execution.FutureStateChange
 
complete(T, Executor) - Method in class io.prestosql.execution.FutureStateChange
 
CompletedWork<T> - Class in io.prestosql.operator
 
CompletedWork(T) - Constructor for class io.prestosql.operator.CompletedWork
 
ComposableStatsCalculator - Class in io.prestosql.cost
 
ComposableStatsCalculator(List<ComposableStatsCalculator.Rule<?>>) - Constructor for class io.prestosql.cost.ComposableStatsCalculator
 
ComposableStatsCalculator.Rule<T extends PlanNode> - Interface in io.prestosql.cost
 
COMPRESSED - io.prestosql.execution.buffer.PageCodecMarker
 
compute(long, BiFunction<? super Long, ? super Long, ? extends Long>) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
computeAntiJoin(PlanNodeStatsEstimate, PlanNodeStatsEstimate, Symbol, Symbol) - Static method in class io.prestosql.cost.SemiJoinStatsCalculator
 
computeAssignments(Set<Split>) - Method in class io.prestosql.execution.scheduler.DynamicSplitPlacementPolicy
 
computeAssignments(Set<Split>) - Method in class io.prestosql.execution.scheduler.FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy
 
computeAssignments(Set<Split>) - Method in interface io.prestosql.execution.scheduler.SplitPlacementPolicy
 
computeAssignments(Set<Split>, List<RemoteTask>) - Method in interface io.prestosql.execution.scheduler.NodeSelector
Identifies the nodes for running the specified splits.
computeAssignments(Set<Split>, List<RemoteTask>) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
computeAssignments(Set<Split>, List<RemoteTask>) - Method in class io.prestosql.execution.scheduler.UniformNodeSelector
 
computeAssignments(Set<Split>, List<RemoteTask>, BucketNodeMap) - Method in interface io.prestosql.execution.scheduler.NodeSelector
Identifies the nodes for running the specified splits based on a precomputed fixed partitioning.
computeAssignments(Set<Split>, List<RemoteTask>, BucketNodeMap) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
computeAssignments(Set<Split>, List<RemoteTask>, BucketNodeMap) - Method in class io.prestosql.execution.scheduler.UniformNodeSelector
 
computeBucketCount(int, float) - Static method in class io.prestosql.operator.aggregation.histogram.HashUtil
uses HashCommon.arraySize() which does this calculation.
computeEnforced(TupleDomain<ColumnHandle>, TupleDomain<ColumnHandle>) - Static method in class io.prestosql.metadata.TableLayoutResult
Deprecated.
 
computeIfAbsent(long, long, LongBinaryOperator) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
computeIfAbsent(long, LongUnaryOperator) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
computeIfAbsentNullable(long, LongFunction<? extends Long>) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
computeIfPresent(long, BiFunction<? super Long, ? super Long, ? extends Long>) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
computeLevel(long) - Static method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
computeNext() - Method in class io.prestosql.operator.scalar.JsonPathTokenizer
 
computeNext() - Method in class io.prestosql.server.protocol.QueryResultRows
 
computeSemiJoin(PlanNodeStatsEstimate, PlanNodeStatsEstimate, Symbol, Symbol) - Static method in class io.prestosql.cost.SemiJoinStatsCalculator
 
concat(Slice[]) - Static method in class io.prestosql.operator.scalar.ConcatFunction
 
concat(Type, Object, Block[]) - Static method in class io.prestosql.operator.scalar.ArrayConcatFunction
 
concat(Long, Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
concat(Function<PolymorphicScalarFunctionBuilder.SpecializeContext, List<Object>>...) - Static method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
CONCAT_WS - Static variable in class io.prestosql.operator.scalar.ConcatWsFunction
 
ConcatArrayWs() - Constructor for class io.prestosql.operator.scalar.ConcatWsFunction.ConcatArrayWs
 
ConcatFunction - Class in io.prestosql.operator.scalar
 
concatWs(Slice, Slice[]) - Static method in class io.prestosql.operator.scalar.ConcatWsFunction
 
concatWsArray(Slice, Block) - Static method in class io.prestosql.operator.scalar.ConcatWsFunction.ConcatArrayWs
 
ConcatWsFunction - Class in io.prestosql.operator.scalar
Concatenate all but the first argument with separators.
ConcatWsFunction() - Constructor for class io.prestosql.operator.scalar.ConcatWsFunction
 
ConcatWsFunction.ConcatArrayWs - Class in io.prestosql.operator.scalar
 
concurrencyController - Variable in class io.prestosql.execution.executor.TaskHandle
 
CONCURRENT_LIFESPANS_PER_NODE - Static variable in class io.prestosql.SystemSessionProperties
 
configure(Binder) - Method in class io.prestosql.connector.system.SystemConnectorModule
 
configure(Binder) - Method in class io.prestosql.cost.StatsCalculatorModule
 
configure(Binder) - Method in class io.prestosql.eventlistener.EventListenerModule
 
configure(Binder) - Method in class io.prestosql.execution.scheduler.UniformNodeSelectorModule
 
configure(Binder) - Method in class io.prestosql.execution.warnings.WarningCollectorModule
 
configure(Binder) - Method in class io.prestosql.failuredetector.FailureDetectorModule
 
configure(Binder) - Method in class io.prestosql.metadata.HandleJsonModule
 
configure(Binder) - Method in class io.prestosql.security.AccessControlModule
 
configure(Binder) - Method in class io.prestosql.server.PrefixObjectNameGeneratorModule
 
configure(Binder) - Method in class io.prestosql.server.QueryExecutionFactoryModule
 
configure(Binder) - Method in class io.prestosql.server.ui.FixedUiAuthenticatorModule
 
configure(Binder) - Method in class io.prestosql.server.ui.FormUiAuthenticatorModule
 
configure(Binder) - Method in class io.prestosql.server.WorkerModule
 
configure(Binder) - Method in class io.prestosql.testing.TestingWarningCollectorModule
 
configure(ResourceGroup, SelectionContext<LegacyResourceGroupConfigurationManager.VoidContext>) - Method in class io.prestosql.execution.resourcegroups.LegacyResourceGroupConfigurationManager
 
configure(ResourceInfo, FeatureContext) - Method in class io.prestosql.server.security.ResourceSecurityDynamicFeature
 
ConnectorAwareNodeManager - Class in io.prestosql.connector
 
ConnectorAwareNodeManager(InternalNodeManager, String, CatalogName) - Constructor for class io.prestosql.connector.ConnectorAwareNodeManager
 
ConnectorAwareSplitSource - Class in io.prestosql.split
 
ConnectorAwareSplitSource(CatalogName, ConnectorSplitSource) - Constructor for class io.prestosql.split.ConnectorAwareSplitSource
 
ConnectorContextInstance - Class in io.prestosql.connector
 
ConnectorContextInstance(NodeManager, VersionEmbedder, TypeManager, PageSorter, PageIndexerFactory, Supplier<ClassLoader>) - Constructor for class io.prestosql.connector.ConnectorContextInstance
 
ConnectorExpressions - Class in io.prestosql.sql.planner
 
ConnectorExpressionTranslator - Class in io.prestosql.sql.planner
 
ConnectorManager - Class in io.prestosql.connector
 
ConnectorManager(MetadataManager, CatalogManager, AccessControlManager, SplitManager, PageSourceManager, IndexManager, NodePartitioningManager, PageSinkManager, HandleResolver, InternalNodeManager, NodeInfo, EmbedVersion, PageSorter, PageIndexerFactory, TransactionManager, EventListenerManager, TypeOperators) - Constructor for class io.prestosql.connector.ConnectorManager
 
constant(Object, Type) - Static method in class io.prestosql.sql.relational.Expressions
 
constant(T) - Static method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
constantBinding(NullableValue) - Static method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
ConstantExpression - Class in io.prestosql.sql.relational
 
ConstantExpression(Object, Type) - Constructor for class io.prestosql.sql.relational.ConstantExpression
 
ConstantExpressionVerifier - Class in io.prestosql.sql.analyzer
 
constantNull(Type) - Static method in class io.prestosql.sql.relational.Expressions
 
ConstantPageProjection - Class in io.prestosql.operator.project
 
ConstantPageProjection(Object, Type) - Constructor for class io.prestosql.operator.project.ConstantPageProjection
 
constants(Map<Symbol, NullableValue>) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
constantType(CallSiteBinder, Type) - Static method in class io.prestosql.sql.gen.SqlTypeBytecodeExpression
 
Constraint - Annotation Type in io.prestosql.type
 
constrainTo(Iterable<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
Constraints - Annotation Type in io.prestosql.type
 
constructorMethodHandle(StandardErrorCode, Class<?>, Class<?>...) - Static method in class io.prestosql.util.Reflection
Returns a MethodHandle corresponding to the specified constructor.
constructorMethodHandle(StandardErrorCode, Constructor<?>) - Static method in class io.prestosql.util.Reflection
Returns a MethodHandle corresponding to the specified constructor.
constructorMethodHandle(Class<?>, Class<?>...) - Static method in class io.prestosql.util.Reflection
Returns a MethodHandle corresponding to the specified constructor.
CONSUMING_INPUT - io.prestosql.operator.HashBuilderOperator.State
Operator accepts input
contains(int, Page) - Method in class io.prestosql.operator.ChannelSet
 
contains(int, Page, int[]) - Method in class io.prestosql.operator.BigintGroupByHash
 
contains(int, Page, int[]) - Method in interface io.prestosql.operator.GroupByHash
 
contains(int, Page, int[]) - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
contains(int, Page, int[]) - Method in class io.prestosql.operator.NoChannelGroupByHash
 
contains(int, Page, int[], long) - Method in interface io.prestosql.operator.GroupByHash
 
contains(int, Page, int[], long) - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
contains(int, Page, long) - Method in class io.prestosql.operator.ChannelSet
 
contains(E) - Method in class io.prestosql.execution.resourcegroups.IndexedPriorityQueue
 
contains(PageCodecMarker) - Method in class io.prestosql.execution.buffer.PageCodecMarker.MarkerSet
 
contains(Block, int) - Method in class io.prestosql.operator.aggregation.TypedSet
 
contains(MethodHandle, Block, boolean) - Static method in class io.prestosql.operator.scalar.ArrayContains
 
contains(MethodHandle, Block, double) - Static method in class io.prestosql.operator.scalar.ArrayContains
 
contains(MethodHandle, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayContains
 
contains(MethodHandle, Block, Object) - Static method in class io.prestosql.operator.scalar.ArrayContains
 
containsAnnotation(Annotation[], Predicate<Annotation>) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
containsImplementationDependencyAnnotation(Annotation[]) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
containsKey(long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
containsKey(long, long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
containsLegacyNullable(Annotation[]) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
containsLongVariable(String) - Method in class io.prestosql.metadata.FunctionBinding
 
containsNamedQuery(String) - Method in class io.prestosql.sql.analyzer.Scope.Builder
 
containsNull() - Method in class io.prestosql.operator.ChannelSet
 
containsNullKey - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
Whether this map contains the key zero.
containsNullKey - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Whether this map contains the key zero.
containsSequence(MethodHandle, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayContainsSequence
 
containsTypeVariable(String) - Method in class io.prestosql.metadata.FunctionBinding
 
containsValue(long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
containsValue(long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
Context() - Constructor for class io.prestosql.sql.planner.optimizations.BeginTableWrite.Context
 
convertFromSchemaTableName(String) - Static method in class io.prestosql.metadata.QualifiedObjectName
 
convertOperators(int, List<OperatorFactory>) - Static method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
convertToTimestampWithTimeZone(TimeZoneKey, String) - Static method in class io.prestosql.util.DateTimeUtils
Parse a string (optionally containing a zone) as a value of TIMESTAMP WITH TIME ZONE type.
COORDINATOR_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
CoordinatorLocation - Interface in io.prestosql.dispatcher
 
CoordinatorModule - Class in io.prestosql.server
 
CoordinatorModule() - Constructor for class io.prestosql.server.CoordinatorModule
 
CoordinatorModule.ExecutorCleanup - Class in io.prestosql.server
 
coordinatorSingleStreamPartition() - Static method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
CoordinatorSystemTablesProvider - Class in io.prestosql.connector.system
 
CoordinatorSystemTablesProvider(TransactionManager, Metadata, String, StaticSystemTablesProvider) - Constructor for class io.prestosql.connector.system.CoordinatorSystemTablesProvider
 
copyOf(Map<Symbol, Type>) - Static method in class io.prestosql.sql.planner.TypeProvider
 
copyOf(Map<Symbol, Expression>) - Static method in class io.prestosql.sql.planner.plan.Assignments
 
copyPlan(PlanNode, List<Symbol>, Metadata, SymbolAllocator, PlanNodeIdAllocator) - Static method in class io.prestosql.sql.planner.PlanCopier
 
copyPositions(int[], int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
copyRegion(int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
corr(CorrelationState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DoubleCorrelationAggregation
 
corr(CorrelationState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealCorrelationAggregation
 
correlatedJoin() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
CorrelatedJoin() - Constructor for class io.prestosql.sql.planner.plan.Patterns.CorrelatedJoin
 
CorrelatedJoinNode - Class in io.prestosql.sql.planner.plan
For every row from CorrelatedJoinNode.input a CorrelatedJoinNode.subquery relation is calculated.
CorrelatedJoinNode(PlanNodeId, PlanNode, PlanNode, List<Symbol>, CorrelatedJoinNode.Type, Expression, Node) - Constructor for class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
CorrelatedJoinNode.Type - Enum in io.prestosql.sql.planner.plan
 
correlation() - Static method in class io.prestosql.sql.planner.plan.Patterns.Apply
 
correlation() - Static method in class io.prestosql.sql.planner.plan.Patterns.CorrelatedJoin
 
CorrelationState - Interface in io.prestosql.operator.aggregation.state
 
CorrelationSupport - Enum in io.prestosql.sql.analyzer
 
cos(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
cosh(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
cosineSimilarity(BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, Block, Block) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
COST_ESTIMATION_WORKER_COUNT - Static variable in class io.prestosql.SystemSessionProperties
 
CostCalculator - Interface in io.prestosql.cost
 
CostCalculator.EstimatedExchanges - Annotation Type in io.prestosql.cost
 
CostCalculatorUsingExchanges - Class in io.prestosql.cost
Simple implementation of CostCalculator.
CostCalculatorUsingExchanges(TaskCountEstimator) - Constructor for class io.prestosql.cost.CostCalculatorUsingExchanges
 
CostCalculatorWithEstimatedExchanges - Class in io.prestosql.cost
A wrapper around CostCalculator that estimates ExchangeNodes cost.
CostCalculatorWithEstimatedExchanges(CostCalculator, TaskCountEstimator) - Constructor for class io.prestosql.cost.CostCalculatorWithEstimatedExchanges
 
CostComparator - Class in io.prestosql.cost
 
CostComparator(double, double, double) - Constructor for class io.prestosql.cost.CostComparator
 
CostComparator(FeaturesConfig) - Constructor for class io.prestosql.cost.CostComparator
 
CostProvider - Interface in io.prestosql.cost
 
count() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
count() - Static method in class io.prestosql.sql.planner.plan.Patterns.Limit
 
count() - Static method in class io.prestosql.sql.planner.plan.Patterns.TopN
 
COUNT_COLUMN - Static variable in class io.prestosql.operator.aggregation.CountColumn
 
CountAggregation - Class in io.prestosql.operator.aggregation
 
CountColumn - Class in io.prestosql.operator.aggregation
 
CountColumn() - Constructor for class io.prestosql.operator.aggregation.CountColumn
 
CountIfAggregation - Class in io.prestosql.operator.aggregation
 
countInputChannels(List<AggregationMetadata.ParameterMetadata>) - Static method in class io.prestosql.operator.aggregation.AggregationMetadata
 
countSources(List<PlanNode>) - Static method in class io.prestosql.sql.planner.FragmentTableScanCounter
 
CovarianceState - Interface in io.prestosql.operator.aggregation.state
 
covarPop(CovarianceState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DoubleCovarianceAggregation
 
covarPop(CovarianceState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealCovarianceAggregation
 
covarSamp(CovarianceState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DoubleCovarianceAggregation
 
covarSamp(CovarianceState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealCovarianceAggregation
 
crc32(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
create() - Method in interface io.prestosql.execution.warnings.WarningCollectorFactory
 
create() - Static method in class io.prestosql.server.testing.TestingPrestoServer
 
create() - Static method in class io.prestosql.sql.analyzer.Scope
 
create() - Static method in class io.prestosql.testing.TestingTransactionHandle
 
create() - Method in class io.prestosql.testing.TestingWarningCollectorFactory
 
create() - Static method in class io.prestosql.transaction.TransactionId
 
create() - Static method in class io.prestosql.util.AutoCloseableCloser
 
create(StageInfo) - Static method in class io.prestosql.cost.StatsAndCosts
 
create(ProcessorContext, WorkProcessor<Page>) - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
create(ProcessorContext, WorkProcessor<Page>) - Method in interface io.prestosql.operator.WorkProcessorOperatorFactory
 
create(WorkProcessor.Process<T>) - Static method in interface io.prestosql.operator.WorkProcessor
create(Session) - Static method in class io.prestosql.testing.LocalQueryRunner
 
create(Session, MemoryTrackingContext, DriverYieldSignal, WorkProcessor<Split>) - Method in class io.prestosql.operator.ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory
 
create(Session, MemoryTrackingContext, DriverYieldSignal, WorkProcessor<Split>) - Method in class io.prestosql.operator.TableScanOperator.TableScanOperatorFactory
 
create(Session, MemoryTrackingContext, DriverYieldSignal, WorkProcessor<Split>) - Method in interface io.prestosql.operator.WorkProcessorSourceOperatorFactory
 
create(Session, QueryContext, TaskStateMachine, OutputBuffer, PlanFragment, List<TaskSource>, Runnable, OptionalInt) - Method in class io.prestosql.execution.SqlTaskExecutionFactory
 
create(ConnectorSession, LongArrayList, List<Page>) - Method in interface io.prestosql.sql.gen.JoinFilterFunctionCompiler.JoinFilterFunctionFactory
 
create(Analysis, Session, Metadata, SqlParser, GroupProvider, AccessControl, TypeProvider, WarningCollector) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
create(Analysis, Session, Metadata, SqlParser, GroupProvider, AccessControl, TypeProvider, WarningCollector, CorrelationSupport) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
create(PartitioningHandle, List<Symbol>) - Static method in class io.prestosql.sql.planner.Partitioning
 
create(JoinNode, List<Type>, int, Set<DynamicFilterId>) - Static method in class io.prestosql.sql.planner.LocalDynamicFilterConsumer
 
create(PlanNode, StatsProvider, CostProvider) - Static method in class io.prestosql.cost.StatsAndCosts
 
create(TransactionManagerConfig, ScheduledExecutorService, CatalogManager, Executor) - Static method in class io.prestosql.transaction.InMemoryTransactionManager
 
create(String, Instant, boolean) - Static method in class io.prestosql.server.ui.OAuthWebUiCookie
 
create(String, Map<String, String>, ConnectorContext) - Method in class io.prestosql.connector.system.GlobalSystemConnectorFactory
 
create(List<JoinFilterFunction>) - Method in interface io.prestosql.operator.PositionLinks.Factory
Separate JoinFilterFunctions have to be created and supplied for each thread using PositionLinks since JoinFilterFunction is not thread safe...
create(List<Type>, PartitionFunction, SpillContext, AggregatedMemoryContext) - Method in class io.prestosql.spiller.GenericPartitioningSpillerFactory
 
create(List<Type>, PartitionFunction, SpillContext, AggregatedMemoryContext) - Method in interface io.prestosql.spiller.PartitioningSpillerFactory
 
create(List<Type>, SpillContext, AggregatedMemoryContext) - Method in class io.prestosql.spiller.GenericSpillerFactory
 
create(List<Type>, SpillContext, AggregatedMemoryContext) - Method in interface io.prestosql.spiller.SpillerFactory
 
create(List<Type>, SpillContext, LocalMemoryContext) - Method in class io.prestosql.spiller.FileSingleStreamSpillerFactory
 
create(List<Type>, SpillContext, LocalMemoryContext) - Method in interface io.prestosql.spiller.SingleStreamSpillerFactory
 
Create(Optional<QualifiedObjectName>, Optional<ConnectorTableMetadata>, Optional<NewTableLayout>, boolean, boolean) - Constructor for class io.prestosql.sql.analyzer.Analysis.Create
 
CREATE_SCHEMA - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
CREATE_TABLE - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
CREATE_VIEW - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
CREATE_VIEW_WITH_SELECT_COLUMNS - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
createAccessControl(AccessControlManager) - Method in class io.prestosql.security.AccessControlModule
 
createAccumulator() - Method in interface io.prestosql.operator.aggregation.AccumulatorFactory
 
createAccumulator() - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
createAdapterOperator(ProcessorContext) - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
createAdapterOperator(ProcessorContext) - Method in interface io.prestosql.operator.WorkProcessorOperatorAdapter.AdapterWorkProcessorOperatorFactory
 
createAdapterOperator(ProcessorContext, WorkProcessor<Page>) - Method in interface io.prestosql.operator.BasicWorkProcessorOperatorAdapter.BasicAdapterWorkProcessorOperatorFactory
 
createAdapterOperator(Session, MemoryTrackingContext, DriverYieldSignal, WorkProcessor<Split>) - Method in class io.prestosql.operator.ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory
 
createAdapterOperator(Session, MemoryTrackingContext, DriverYieldSignal, WorkProcessor<Split>) - Method in interface io.prestosql.operator.WorkProcessorSourceOperatorAdapter.AdapterWorkProcessorSourceOperatorFactory
 
createAdapterOperatorFactory(BasicWorkProcessorOperatorAdapter.BasicAdapterWorkProcessorOperatorFactory) - Static method in class io.prestosql.operator.BasicWorkProcessorOperatorAdapter
 
createAdapterOperatorFactory(WorkProcessorOperatorAdapter.AdapterWorkProcessorOperatorFactory) - Static method in class io.prestosql.operator.WorkProcessorOperatorAdapter
 
createAsyncHttpResponseCoreExecutor() - Static method in class io.prestosql.server.ServerMainModule
 
createAsyncHttpResponseExecutor(ExecutorService, TaskManagerConfig) - Static method in class io.prestosql.server.ServerMainModule
 
createAsyncHttpTimeoutExecutor(TaskManagerConfig) - Static method in class io.prestosql.server.ServerMainModule
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.type.FunctionType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.type.IpAddressType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.type.UnknownType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.type.UuidType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.type.FunctionType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.type.IpAddressType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.type.UnknownType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.type.UuidType
 
createBlockBuilderAppender(Type) - Static method in interface io.prestosql.util.JsonUtil.BlockBuilderAppender
 
createBlockEncodingSerde(Metadata) - Static method in class io.prestosql.server.ServerMainModule
 
createBogusTestingCatalog(String) - Static method in class io.prestosql.testing.TestingSession
 
createBucketFunction(List<Type>, boolean, int, BlockTypeOperators) - Method in enum io.prestosql.sql.planner.SystemPartitioningHandle.SystemPartitionFunction
 
createCatalog(String, ConnectorFactory, Map<String, String>) - Method in class io.prestosql.testing.LocalQueryRunner
 
createCatalog(String, String) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
createCatalog(String, String, Map<String, String>) - Method in class io.prestosql.connector.ConnectorManager
 
createCatalog(String, String, Map<String, String>) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
createCatalog(String, String, Map<String, String>) - Method in class io.prestosql.testing.LocalQueryRunner
 
createCatalog(String, String, Map<String, String>) - Method in interface io.prestosql.testing.QueryRunner
 
createCatalogSchemaName(Session, Node, Optional<QualifiedName>) - Static method in class io.prestosql.metadata.MetadataUtil
 
createChannelComparator(int, int) - Method in class io.prestosql.operator.PagesIndex
 
createConstantAnalyzer(Metadata, AccessControl, Session, Map<NodeRef<Parameter>, Expression>, WarningCollector) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
createConstantAnalyzer(Metadata, AccessControl, Session, Map<NodeRef<Parameter>, Expression>, WarningCollector, boolean) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
CREATED - io.prestosql.sql.planner.LogicalPlanner.Stage
 
createDateTimeFormatter(Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
createDependency(Annotation, Set<String>, Class<?>) - Static method in class io.prestosql.operator.annotations.ImplementationDependency.Factory
 
createDispatchQuery(Session, String, QueryPreparer.PreparedQuery, Slug, ResourceGroupId) - Method in interface io.prestosql.dispatcher.DispatchQueryFactory
 
createDispatchQuery(Session, String, QueryPreparer.PreparedQuery, Slug, ResourceGroupId) - Method in class io.prestosql.dispatcher.LocalDispatchQueryFactory
 
createDistinctTypedSet(Type, BlockTypeOperators.BlockPositionIsDistinctFrom, BlockTypeOperators.BlockPositionHashCode, int, String) - Static method in class io.prestosql.operator.aggregation.TypedSet
 
createDistinctTypedSet(Type, BlockTypeOperators.BlockPositionIsDistinctFrom, BlockTypeOperators.BlockPositionHashCode, BlockBuilder, int, String) - Static method in class io.prestosql.operator.aggregation.TypedSet
 
createDriver(DriverContext) - Method in class io.prestosql.operator.DriverFactory
 
createDriver(DriverContext, Operator, Operator...) - Static method in class io.prestosql.operator.Driver
 
createDriver(DriverContext, List<Operator>) - Static method in class io.prestosql.operator.Driver
 
createDrivers(Session, String, OutputFactory, TaskContext) - Method in class io.prestosql.testing.LocalQueryRunner
 
createDrivers(String, OutputFactory, TaskContext) - Method in class io.prestosql.testing.LocalQueryRunner
 
createDynamicFilter(QueryId, List<DynamicFilters.Descriptor>, Map<Symbol, ColumnHandle>, TypeProvider) - Method in class io.prestosql.server.DynamicFilterService
 
createDynamicFilterExpression(Metadata, DynamicFilterId, Type, Expression) - Static method in class io.prestosql.sql.DynamicFilters
 
createDynamicFilterExpression(Metadata, DynamicFilterId, Type, Expression, ComparisonExpression.Operator) - Static method in class io.prestosql.sql.DynamicFilters
 
createDynamicFilterExpression(Metadata, DynamicFilterId, Type, SymbolReference, ComparisonExpression.Operator) - Static method in class io.prestosql.sql.DynamicFilters
 
createEmptyPagesResponse(String, long, long, boolean) - Static method in class io.prestosql.operator.HttpPageBufferClient.PagesResponse
 
createEmptySplit() - Static method in class io.prestosql.testing.TestingSplit
 
createEqualityTypedSet(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, int, String) - Static method in class io.prestosql.operator.aggregation.TypedSet
 
createEqualityTypedSet(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, BlockBuilder, int, String, boolean) - Static method in class io.prestosql.operator.aggregation.TypedSet
 
createExchangeExecutor(ExchangeClientConfig) - Static method in class io.prestosql.server.ServerMainModule
 
createExecutionSchedule(Collection<SqlStageExecution>) - Method in class io.prestosql.execution.scheduler.AllAtOnceExecutionPolicy
 
createExecutionSchedule(Collection<SqlStageExecution>) - Method in interface io.prestosql.execution.scheduler.ExecutionPolicy
 
createExecutionSchedule(Collection<SqlStageExecution>) - Method in class io.prestosql.execution.scheduler.PhasedExecutionPolicy
 
createFailedDispatchQuery(Session, String, Optional<String>, Optional<ResourceGroupId>, Throwable) - Method in class io.prestosql.dispatcher.FailedDispatchQueryFactory
 
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.type.IpAddressType
 
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.type.UnknownType
 
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.type.UuidType
 
createFunctionByAnnotations(Class<?>) - Static method in class io.prestosql.metadata.SqlAggregationFunction
 
createFunctionsByAnnotations(Class<?>) - Static method in class io.prestosql.metadata.SqlAggregationFunction
 
createGroupByHash(Session, List<? extends Type>, int[], Optional<Integer>, int, JoinCompiler, BlockTypeOperators) - Static method in interface io.prestosql.operator.GroupByHash
 
createGroupByHash(List<? extends Type>, int[], Optional<Integer>, int, boolean, JoinCompiler, BlockTypeOperators, UpdateMemory) - Static method in interface io.prestosql.operator.GroupByHash
 
createGroupedAccumulator() - Method in interface io.prestosql.operator.aggregation.AccumulatorFactory
 
createGroupedAccumulator() - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
createGroupedIntermediateAccumulator() - Method in interface io.prestosql.operator.aggregation.AccumulatorFactory
 
createGroupedIntermediateAccumulator() - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.histogram.HistogramStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory
 
createGroupedState() - Method in class io.prestosql.type.setdigest.SetDigestStateFactory
 
createHashCollisionsInfo(long, double, double) - Static method in class io.prestosql.operator.HashCollisionsInfo
 
createIndexSnapshot(UnloadedIndexKeyRecordSet) - Method in class io.prestosql.operator.index.IndexSnapshotBuilder
 
createInformationSchemaCatalogName(CatalogName) - Static method in class io.prestosql.connector.CatalogName
 
createInitialEmptyOutputBuffers(OutputBuffers.BufferType) - Static method in class io.prestosql.execution.buffer.OutputBuffers
 
createInitialEmptyOutputBuffers(PartitioningHandle) - Static method in class io.prestosql.execution.buffer.OutputBuffers
 
createInitialTask(TaskId, URI, String, List<BufferInfo>, TaskStats) - Static method in class io.prestosql.execution.TaskInfo
 
createIntermediateAccumulator() - Method in interface io.prestosql.operator.aggregation.AccumulatorFactory
 
createIntermediateAccumulator() - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
createJoinOperatorInfo(LookupJoinOperators.JoinType, long[], Optional<Long>) - Static method in class io.prestosql.operator.JoinOperatorInfo
 
createJoinProbe(Page) - Method in class io.prestosql.operator.JoinProbe.JoinProbeFactory
 
createJsonGenerator(JsonFactory, SliceOutput) - Static method in class io.prestosql.util.JsonUtil
 
createJsonGeneratorWriter(Type) - Static method in interface io.prestosql.util.JsonUtil.JsonGeneratorWriter
 
createJsonParser(JsonFactory, Slice) - Static method in class io.prestosql.util.JsonUtil
 
createKillQueryException(String) - Static method in class io.prestosql.connector.system.KillQueryProcedure
 
createLocalSplit() - Static method in class io.prestosql.testing.TestingSplit
 
createLocalTaskLocation(TaskId) - Method in interface io.prestosql.execution.LocationFactory
 
createLocalTaskLocation(TaskId) - Method in class io.prestosql.server.remotetask.HttpLocationFactory
 
createLookupSourceProvider() - Method in class io.prestosql.operator.index.IndexLookupSourceFactory
 
createLookupSourceProvider() - Method in interface io.prestosql.operator.LookupSourceFactory
 
createLookupSourceProvider() - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
createLookupSourceSupplier(Session, LongArrayList, List<List<Block>>, OptionalInt, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, Optional<Integer>, List<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>) - Method in class io.prestosql.sql.gen.JoinCompiler.LookupSourceSupplierFactory
 
createLookupSourceSupplier(Session, List<Integer>) - Method in class io.prestosql.operator.PagesIndex
 
createLookupSourceSupplier(Session, List<Integer>, OptionalInt, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, Optional<Integer>, List<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>) - Method in class io.prestosql.operator.PagesIndex
 
createLookupSourceSupplier(Session, List<Integer>, OptionalInt, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, Optional<Integer>, List<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, Optional<List<Integer>>) - Method in class io.prestosql.operator.PagesIndex
 
createMap(MapType, MethodHandle, MapConstructor.State, ConnectorSession, Block, Block) - Static method in class io.prestosql.operator.scalar.MapConstructor
 
createMapState(MapType) - Static method in class io.prestosql.operator.scalar.MapConcatFunction
 
createMaterializedView(Session, QualifiedObjectName, ConnectorMaterializedViewDefinition, boolean, boolean) - Method in interface io.prestosql.metadata.Metadata
Creates the specified materialized view with the specified view definition.
createMaterializedView(Session, QualifiedObjectName, ConnectorMaterializedViewDefinition, boolean, boolean) - Method in class io.prestosql.metadata.MetadataManager
 
CreateMaterializedViewTask - Class in io.prestosql.execution
 
CreateMaterializedViewTask(SqlParser, GroupProvider, StatsCalculator) - Constructor for class io.prestosql.execution.CreateMaterializedViewTask
 
createMemoryInfoLocation(InternalNode) - Method in interface io.prestosql.execution.LocationFactory
 
createMemoryInfoLocation(InternalNode) - Method in class io.prestosql.server.remotetask.HttpLocationFactory
 
createNew() - Static method in class io.prestosql.server.protocol.Slug
 
createNewListener() - Method in class io.prestosql.execution.FutureStateChange
 
createNewStatsCalculator(Metadata, TypeAnalyzer) - Static method in class io.prestosql.cost.StatsCalculatorModule
 
createNextQueryId() - Method in class io.prestosql.execution.QueryIdGenerator
Generate next queryId using the following format: YYYYMMdd_HHmmss_index_coordId
createNodeSelector(Optional<CatalogName>) - Method in class io.prestosql.execution.scheduler.NodeScheduler
 
createNodeSelector(Optional<CatalogName>) - Method in interface io.prestosql.execution.scheduler.NodeSelectorFactory
 
createNodeSelector(Optional<CatalogName>) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorFactory
 
createNodeSelector(Optional<CatalogName>) - Method in class io.prestosql.execution.scheduler.UniformNodeSelectorFactory
 
createObjectKeyProvider(Type) - Static method in interface io.prestosql.util.JsonUtil.ObjectKeyProvider
 
createOperator(DriverContext) - Method in class io.prestosql.operator.AggregationOperator.AggregationOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.DeleteOperator.DeleteOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.DevNullOperator.DevNullOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.DistinctLimitOperator.DistinctLimitOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.DynamicFilterSourceOperator.DynamicFilterSourceOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.EnforceSingleRowOperator.EnforceSingleRowOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator.LocalExchangeSinkOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator.LocalExchangeSourceOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator.LocalMergeSourceOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.ExchangeOperator.ExchangeOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.ExplainAnalyzeOperator.ExplainAnalyzeOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.GroupIdOperator.GroupIdOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.HashAggregationOperator.HashAggregationOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.HashBuilderOperator.HashBuilderOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.index.IndexSourceOperator.IndexSourceOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.index.PageBufferOperator.PageBufferOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.index.PagesIndexBuilderOperator.PagesIndexBuilderOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.LimitOperator.LimitOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.LookupOuterOperator.LookupOuterOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.MarkDistinctOperator.MarkDistinctOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.MergeOperator.MergeOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.NestedLoopBuildOperator.NestedLoopBuildOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.NestedLoopJoinOperator.NestedLoopJoinOperatorFactory
 
createOperator(DriverContext) - Method in interface io.prestosql.operator.OperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.OrderByOperator.OrderByOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.RowNumberOperator.RowNumberOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.SetBuilderOperator.SetBuilderOperatorFactory
 
createOperator(DriverContext) - Method in interface io.prestosql.operator.SourceOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.SpatialIndexBuilderOperator.SpatialIndexBuilderOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.SpatialJoinOperator.SpatialJoinOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.StatisticsWriterOperator.StatisticsWriterOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.TableDeleteOperator.TableDeleteOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.TableFinishOperator.TableFinishOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.TableScanOperator.TableScanOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.TableWriterOperator.TableWriterOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.TaskOutputOperator.TaskOutputOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.TopNRowNumberOperator.TopNRowNumberOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.unnest.UnnestOperator.UnnestOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.ValuesOperator.ValuesOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.WindowOperator.WindowOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator.WorkProcessorPipelineSourceOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.testing.NullOutputOperator.NullOutputOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.testing.PageConsumerOperator.PageConsumerOperatorFactory
 
createOperatorFactory(int, PlanNodeId) - Static method in class io.prestosql.operator.AssignUniqueIdOperator
 
createOperatorFactory(int, PlanNodeId, SetBuilderOperator.SetSupplier, List<? extends Type>, int, Optional<Integer>) - Static method in class io.prestosql.operator.HashSemiJoinOperator
 
createOperatorFactory(int, PlanNodeId, Supplier<PageProcessor>, List<Type>, DataSize, int) - Static method in class io.prestosql.operator.FilterAndProjectOperator
 
createOperatorFactory(int, PlanNodeId, List<? extends Type>, int, List<Integer>, List<SortOrder>, TypeOperators) - Static method in class io.prestosql.operator.TopNOperator
 
createOperatorFactory(int, PlanNodeId, List<Type>, List<Type>, List<Integer>, AggregationNode.Step, List<AccumulatorFactory>, JoinCompiler) - Static method in class io.prestosql.operator.StreamingAggregationOperator
 
createOrUpdateTask(TaskId, TaskUpdateRequest, UriInfo) - Method in class io.prestosql.server.TaskResource
 
createOuterLookupSourceSupplier(Supplier<LookupSource>) - Static method in class io.prestosql.operator.OuterLookupSource
 
createOuterOperatorFactory() - Method in interface io.prestosql.operator.JoinOperatorFactory
 
createOuterOperatorFactory() - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
createOutputOperator(int, PlanNodeId, List<Type>, Function<Page, Page>, PagesSerdeFactory) - Method in interface io.prestosql.operator.OutputFactory
 
createOutputOperator(int, PlanNodeId, List<Type>, Function<Page, Page>, PagesSerdeFactory) - Method in class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputFactory
 
createOutputOperator(int, PlanNodeId, List<Type>, Function<Page, Page>, PagesSerdeFactory) - Method in class io.prestosql.operator.TaskOutputOperator.TaskOutputFactory
 
createOutputOperator(int, PlanNodeId, List<Type>, Function<Page, Page>, PagesSerdeFactory) - Method in class io.prestosql.testing.NullOutputOperator.NullOutputFactory
 
createOutputOperator(int, PlanNodeId, List<Type>, Function<Page, Page>, PagesSerdeFactory) - Method in class io.prestosql.testing.PageConsumerOperator.PageConsumerOutputFactory
 
createPageIndexer(List<? extends Type>) - Method in class io.prestosql.GroupByHashPageIndexerFactory
 
createPageProcessor(Page, OptionalInt) - Method in class io.prestosql.operator.index.DynamicTupleFilterFactory
 
createPagesHashStrategy(List<? extends List<Block>>, OptionalInt) - Method in class io.prestosql.sql.gen.JoinCompiler.PagesHashStrategyFactory
 
createPagesHashStrategy(List<Integer>, OptionalInt) - Method in class io.prestosql.operator.PagesIndex
 
createPagesHashStrategy(List<Integer>, OptionalInt, Optional<List<Integer>>) - Method in class io.prestosql.operator.PagesIndex
 
createPageSink(Session, InsertTableHandle) - Method in class io.prestosql.split.PageSinkManager
 
createPageSink(Session, InsertTableHandle) - Method in interface io.prestosql.split.PageSinkProvider
 
createPageSink(Session, OutputTableHandle) - Method in class io.prestosql.split.PageSinkManager
 
createPageSink(Session, OutputTableHandle) - Method in interface io.prestosql.split.PageSinkProvider
 
createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorInsertTableHandle) - Method in class io.prestosql.testing.TestingPageSinkProvider
 
createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorOutputTableHandle) - Method in class io.prestosql.testing.TestingPageSinkProvider
 
createPageSource(Session, Split, TableHandle, List<ColumnHandle>, DynamicFilter) - Method in class io.prestosql.split.PageSourceManager
 
createPageSource(Session, Split, TableHandle, List<ColumnHandle>, DynamicFilter) - Method in interface io.prestosql.split.PageSourceProvider
 
createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, ConnectorTableHandle, List<ColumnHandle>, TupleDomain<ColumnHandle>) - Method in class io.prestosql.connector.informationschema.InformationSchemaPageSourceProvider
 
createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, ConnectorTableHandle, List<ColumnHandle>, TupleDomain<ColumnHandle>) - Method in class io.prestosql.connector.system.SystemPageSourceProvider
 
createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, ConnectorTableHandle, List<ColumnHandle>, TupleDomain<ColumnHandle>) - Method in class io.prestosql.split.RecordPageSourceProvider
 
createPagesResponse(String, long, long, Iterable<SerializedPage>, boolean) - Static method in class io.prestosql.operator.HttpPageBufferClient.PagesResponse
 
createPagesSerde() - Method in class io.prestosql.execution.buffer.PagesSerdeFactory
 
createPagesSerdeForSpill(Optional<SpillCipher>) - Method in class io.prestosql.execution.buffer.PagesSerdeFactory
 
createPagesSpatialIndex() - Method in class io.prestosql.operator.PagesSpatialIndexFactory
createPagesSpatialIndex(Session, int, Optional<Integer>, Optional<Integer>, SpatialIndexBuilderOperator.SpatialPredicate, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, List<Integer>, Map<Integer, Rectangle>) - Method in class io.prestosql.operator.PagesIndex
 
createParsingOptions(Session) - Static method in class io.prestosql.sql.ParsingUtil
 
createPartialAggregations(SymbolAllocator, Metadata) - Method in class io.prestosql.sql.planner.plan.StatisticAggregations
 
CreatePartialTopN - Class in io.prestosql.sql.planner.iterative.rule
 
CreatePartialTopN() - Constructor for class io.prestosql.sql.planner.iterative.rule.CreatePartialTopN
 
createPartitionedLookupSourceSupplier(List<Supplier<LookupSource>>, List<Type>, boolean, BlockTypeOperators) - Static method in class io.prestosql.operator.PartitionedLookupSource
 
createPartitionedSplitCountTracker(InternalNode, TaskId) - Method in class io.prestosql.execution.NodeTaskMap
 
createPlan(Session, String, WarningCollector) - Method in class io.prestosql.testing.LocalQueryRunner
 
createPlan(Session, String, WarningCollector) - Method in interface io.prestosql.testing.QueryRunner
 
createPlan(Session, String, LogicalPlanner.Stage, boolean, WarningCollector) - Method in class io.prestosql.testing.LocalQueryRunner
 
createPlan(Session, String, LogicalPlanner.Stage, WarningCollector) - Method in class io.prestosql.testing.LocalQueryRunner
 
createPlan(Session, String, List<PlanOptimizer>, WarningCollector) - Method in class io.prestosql.testing.LocalQueryRunner
 
createPlan(Session, String, List<PlanOptimizer>, LogicalPlanner.Stage, WarningCollector) - Method in class io.prestosql.testing.LocalQueryRunner
 
createPreemptQueryException(String) - Static method in class io.prestosql.connector.system.KillQueryProcedure
 
createPrincipal(Session, GrantorSpecification) - Static method in class io.prestosql.metadata.MetadataUtil
 
createPrincipal(PrestoPrincipal) - Static method in class io.prestosql.metadata.MetadataUtil
 
createPrincipal(PrincipalSpecification) - Static method in class io.prestosql.metadata.MetadataUtil
 
createQualifiedObjectName(Session, Node, QualifiedName) - Static method in class io.prestosql.metadata.MetadataUtil
 
createQuery(QueryExecution) - Method in interface io.prestosql.execution.QueryManager
Creates a new query using the specified query execution.
createQuery(QueryExecution) - Method in class io.prestosql.execution.SqlQueryManager
 
createQuery(QueryId, Slug, SessionContext, String) - Method in class io.prestosql.dispatcher.DispatchManager
 
createQueryExecution(QueryPreparer.PreparedQuery, QueryStateMachine, Slug, WarningCollector) - Method in class io.prestosql.execution.DataDefinitionExecution.DataDefinitionExecutionFactory
 
createQueryExecution(QueryPreparer.PreparedQuery, QueryStateMachine, Slug, WarningCollector) - Method in interface io.prestosql.execution.QueryExecution.QueryExecutionFactory
 
createQueryExecution(QueryPreparer.PreparedQuery, QueryStateMachine, Slug, WarningCollector) - Method in class io.prestosql.execution.SqlQueryExecution.SqlQueryExecutionFactory
 
createQueryId() - Method in class io.prestosql.dispatcher.DispatchManager
 
createQueryLocation(QueryId) - Method in interface io.prestosql.execution.LocationFactory
 
createQueryLocation(QueryId) - Method in class io.prestosql.server.remotetask.HttpLocationFactory
 
createQueryPerformanceFetcher(QueryManager) - Static method in class io.prestosql.server.CoordinatorModule
 
createQueryProgressStats(BasicQueryStats) - Static method in class io.prestosql.server.QueryProgressStats
 
createQueryStateInfo(BasicQueryInfo, Optional<ResourceGroupId>) - Static method in class io.prestosql.server.QueryStateInfo
 
createQueuedQueryStateInfo(BasicQueryInfo, Optional<ResourceGroupId>, Optional<List<ResourceGroupInfo>>) - Static method in class io.prestosql.server.QueryStateInfo
 
CreateReference(String, ConnectorTableMetadata, Optional<NewTableLayout>) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.CreateReference
 
createRemoteSplit() - Static method in class io.prestosql.testing.TestingSplit
 
createRemoteTask(Session, TaskId, InternalNode, PlanFragment, Multimap<PlanNodeId, Split>, OptionalInt, OutputBuffers, NodeTaskMap.PartitionedSplitCountTracker, boolean) - Method in class io.prestosql.execution.MemoryTrackingRemoteTaskFactory
 
createRemoteTask(Session, TaskId, InternalNode, PlanFragment, Multimap<PlanNodeId, Split>, OptionalInt, OutputBuffers, NodeTaskMap.PartitionedSplitCountTracker, boolean) - Method in interface io.prestosql.execution.RemoteTaskFactory
 
createRemoteTask(Session, TaskId, InternalNode, PlanFragment, Multimap<PlanNodeId, Split>, OptionalInt, OutputBuffers, NodeTaskMap.PartitionedSplitCountTracker, boolean) - Method in class io.prestosql.server.HttpRemoteTaskFactory
 
createRole(Session, String, Optional<PrestoPrincipal>, String) - Method in interface io.prestosql.metadata.Metadata
Creates the specified role in the specified catalog.
createRole(Session, String, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.metadata.MetadataManager
 
CreateRoleTask - Class in io.prestosql.execution
 
CreateRoleTask() - Constructor for class io.prestosql.execution.CreateRoleTask
 
createSchema(Session, CatalogSchemaName, Map<String, Object>, PrestoPrincipal) - Method in interface io.prestosql.metadata.Metadata
Creates a schema.
createSchema(Session, CatalogSchemaName, Map<String, Object>, PrestoPrincipal) - Method in class io.prestosql.metadata.MetadataManager
 
CreateSchemaTask - Class in io.prestosql.execution
 
CreateSchemaTask() - Constructor for class io.prestosql.execution.CreateSchemaTask
 
createSession(QueryId, SessionContext) - Method in class io.prestosql.server.NoOpSessionSupplier
 
createSession(QueryId, SessionContext) - Method in class io.prestosql.server.QuerySessionSupplier
 
createSession(QueryId, SessionContext) - Method in interface io.prestosql.server.SessionSupplier
 
createSigningKeyResolver(OAuth2Config, HttpClient) - Static method in class io.prestosql.server.security.oauth2.OAuth2ServiceModule
 
createSingleState() - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.histogram.HistogramStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory
 
createSingleState() - Method in class io.prestosql.type.setdigest.SetDigestStateFactory
 
createSink() - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeSinkFactory
 
createSinkFactory() - Method in class io.prestosql.operator.exchange.LocalExchange
 
createSnapshot(int, IndexSnapshotBuilder) - Method in class io.prestosql.operator.index.IndexBuildDriverFactoryProvider
 
createSqlQueryScheduler(QueryStateMachine, StageExecutionPlan, NodePartitioningManager, NodeScheduler, RemoteTaskFactory, Session, boolean, int, ExecutorService, ScheduledExecutorService, FailureDetector, OutputBuffers, NodeTaskMap, ExecutionPolicy, SplitSchedulerStats, DynamicFilterService) - Static method in class io.prestosql.execution.scheduler.SqlQueryScheduler
 
createSqlStageExecution(StageId, PlanFragment, Map<PlanNodeId, TableInfo>, RemoteTaskFactory, Session, boolean, NodeTaskMap, ExecutorService, FailureDetector, DynamicFilterService, SplitSchedulerStats) - Static method in class io.prestosql.execution.SqlStageExecution
 
createSqlTask(TaskId, URI, String, QueryContext, SqlTaskExecutionFactory, ExecutorService, Function<SqlTask, ?>, DataSize, DataSize, CounterStat) - Static method in class io.prestosql.execution.SqlTask
 
createState() - Static method in class io.prestosql.operator.scalar.ArrayJoin
 
createState(ArrayType) - Static method in class io.prestosql.operator.scalar.ZipWithFunction
 
createState(MapType) - Static method in class io.prestosql.operator.scalar.MapFilterFunction
 
createState(MapType) - Static method in class io.prestosql.operator.scalar.MapTransformKeysFunction
 
createState(MapType) - Static method in class io.prestosql.operator.scalar.MapTransformValuesFunction
 
createState(MapType) - Static method in class io.prestosql.operator.scalar.MapZipWithFunction
 
createState(Type) - Static method in class io.prestosql.operator.scalar.ArrayConcatFunction
 
createStatementResponseCoreExecutor() - Static method in class io.prestosql.server.CoordinatorModule
 
createStatementResponseExecutor(ExecutorService, TaskManagerConfig) - Static method in class io.prestosql.server.CoordinatorModule
 
createStatementTimeoutExecutor(TaskManagerConfig) - Static method in class io.prestosql.server.CoordinatorModule
 
createStatisticsAggregation(TableStatisticsMetadata, Map<String, Symbol>) - Method in class io.prestosql.sql.planner.StatisticsAggregationPlanner
 
createStreaming(PageBuffer, Page) - Method in class io.prestosql.operator.index.IndexBuildDriverFactoryProvider
 
createSubPlans(Session, Plan, boolean) - Method in class io.prestosql.testing.LocalQueryRunner
 
createSubPlans(Session, Plan, boolean, WarningCollector) - Method in class io.prestosql.sql.planner.PlanFragmenter
 
createSystemTablesCatalogName(CatalogName) - Static method in class io.prestosql.connector.CatalogName
 
createTable(Session, String, ConnectorTableMetadata, boolean) - Method in interface io.prestosql.metadata.Metadata
Creates a table using the specified table metadata.
createTable(Session, String, ConnectorTableMetadata, boolean) - Method in class io.prestosql.metadata.MetadataManager
 
createTable(ConnectorSession, ConnectorTableMetadata, boolean) - Method in class io.prestosql.testing.TestingMetadata
 
CreateTableTask - Class in io.prestosql.execution
 
CreateTableTask() - Constructor for class io.prestosql.execution.CreateTableTask
 
CreateTarget(OutputTableHandle, SchemaTableName) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.CreateTarget
 
createTaskContext(QueryContext, TaskStateMachine, GcMonitor, Executor, ScheduledExecutorService, Session, MemoryTrackingContext, Runnable, boolean, boolean, OptionalInt) - Static method in class io.prestosql.operator.TaskContext
 
createTaskContext(QueryContext, Executor, Session) - Static method in class io.prestosql.testing.TestingTaskContext
 
createTaskContext(Executor, ScheduledExecutorService, Session) - Static method in class io.prestosql.testing.TestingTaskContext
 
createTaskContext(Executor, ScheduledExecutorService, Session, DataSize) - Static method in class io.prestosql.testing.TestingTaskContext
 
createTaskContext(Executor, ScheduledExecutorService, Session, TaskStateMachine) - Static method in class io.prestosql.testing.TestingTaskContext
 
createTaskLocation(InternalNode, TaskId) - Method in interface io.prestosql.execution.LocationFactory
 
createTaskLocation(InternalNode, TaskId) - Method in class io.prestosql.server.remotetask.HttpLocationFactory
 
createTempVariableReferenceExpression(Variable, Type) - Static method in class io.prestosql.sql.gen.RowExpressionCompiler
 
createTestMetadataManager() - Static method in class io.prestosql.metadata.MetadataManager
 
createTestMetadataManager(CatalogManager) - Static method in class io.prestosql.metadata.MetadataManager
 
createTestMetadataManager(CatalogManager, FeaturesConfig) - Static method in class io.prestosql.metadata.MetadataManager
 
createTestMetadataManager(FeaturesConfig) - Static method in class io.prestosql.metadata.MetadataManager
 
createTestMetadataManager(TransactionManager, FeaturesConfig) - Static method in class io.prestosql.metadata.MetadataManager
 
createTestTransactionManager() - Static method in class io.prestosql.transaction.InMemoryTransactionManager
 
createTestTransactionManager(CatalogManager) - Static method in class io.prestosql.transaction.InMemoryTransactionManager
 
createTestWarning(int) - Static method in class io.prestosql.testing.TestingWarningCollector
 
createTransactionFinishingExecutor() - Static method in class io.prestosql.server.CoordinatorModule
 
createTransactionIdleCheckExecutor() - Static method in class io.prestosql.server.CoordinatorModule
 
createTransactionManager(TransactionManagerConfig, CatalogManager, EmbedVersion, ScheduledExecutorService, ExecutorService) - Static method in class io.prestosql.server.CoordinatorModule
 
createType(TypeManager, List<TypeParameter>) - Method in class io.prestosql.type.ArrayParametricType
 
createType(TypeManager, List<TypeParameter>) - Method in class io.prestosql.type.CharParametricType
 
createType(TypeManager, List<TypeParameter>) - Method in class io.prestosql.type.DecimalParametricType
 
createType(TypeManager, List<TypeParameter>) - Method in class io.prestosql.type.FunctionParametricType
 
createType(TypeManager, List<TypeParameter>) - Method in class io.prestosql.type.MapParametricType
 
createType(TypeManager, List<TypeParameter>) - Method in class io.prestosql.type.RowParametricType
 
createType(TypeManager, List<TypeParameter>) - Method in class io.prestosql.type.VarcharParametricType
 
createTypeOperators(TypeOperatorsCache) - Static method in class io.prestosql.server.ServerMainModule
 
createTypeVariableConstraints(Collection<TypeParameter>, List<ImplementationDependency>) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
createUserMapping(Optional<String>, Optional<File>) - Static method in class io.prestosql.server.security.UserMapping
 
createView(Session, QualifiedObjectName, ConnectorViewDefinition, boolean) - Method in interface io.prestosql.metadata.Metadata
Creates the specified view with the specified view definition.
createView(Session, QualifiedObjectName, ConnectorViewDefinition, boolean) - Method in class io.prestosql.metadata.MetadataManager
 
createView(ConnectorSession, SchemaTableName, ConnectorViewDefinition, boolean) - Method in class io.prestosql.testing.TestingMetadata
 
CreateViewTask - Class in io.prestosql.execution
 
CreateViewTask(SqlParser, GroupProvider, StatsCalculator) - Constructor for class io.prestosql.execution.CreateViewTask
 
createWarningCollectorFactory(WarningCollectorConfig) - Method in class io.prestosql.execution.warnings.WarningCollectorModule
 
createWarningCollectorFactory(WarningCollectorConfig, TestingWarningCollectorConfig) - Method in class io.prestosql.testing.TestingWarningCollectorModule
 
createWindowFunction() - Method in class io.prestosql.operator.WindowFunctionDefinition
 
createWindowFunction(List<Integer>, boolean, List<LambdaProvider>) - Method in class io.prestosql.operator.window.AbstractWindowFunctionSupplier
 
createWindowFunction(List<Integer>, boolean, List<LambdaProvider>) - Method in interface io.prestosql.operator.window.WindowFunctionSupplier
 
createWithoutSubqueries(Metadata, AccessControl, Session, TypeProvider, Map<NodeRef<Parameter>, Expression>, Function<? super Node, ? extends RuntimeException>, WarningCollector, boolean) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
createWithoutSubqueries(Metadata, AccessControl, Session, Map<NodeRef<Parameter>, Expression>, ErrorCodeSupplier, String, WarningCollector, boolean) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
createWorkProcessor(ConnectorSession, DriverYieldSignal, LocalMemoryContext, Page, boolean) - Method in class io.prestosql.operator.project.PageProcessor
 
CumulativeDistributionFunction - Class in io.prestosql.operator.window
 
CumulativeDistributionFunction() - Constructor for class io.prestosql.operator.window.CumulativeDistributionFunction
 
currentDate(ConnectorSession) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
currentPath(ConnectorSession) - Static method in class io.prestosql.operator.scalar.SessionFunctions
 
currentProbePositionProducedRow - Variable in class io.prestosql.operator.LookupJoinOperator.SavedRow
A snapshot of LookupJoinOperator.PageJoiner.currentProbePositionProducedRow
CurrentTime - Class in io.prestosql.operator.scalar.timetz
 
CurrentTimestamp - Class in io.prestosql.operator.scalar.timestamptz
 
currentTimeZone(ConnectorSession) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
currentTokenAsBigint(JsonParser) - Static method in class io.prestosql.util.JsonUtil
 
currentTokenAsBoolean(JsonParser) - Static method in class io.prestosql.util.JsonUtil
 
currentTokenAsDouble(JsonParser) - Static method in class io.prestosql.util.JsonUtil
 
currentTokenAsInteger(JsonParser) - Static method in class io.prestosql.util.JsonUtil
 
currentTokenAsLongDecimal(JsonParser, int, int) - Static method in class io.prestosql.util.JsonUtil
 
currentTokenAsReal(JsonParser) - Static method in class io.prestosql.util.JsonUtil
 
currentTokenAsShortDecimal(JsonParser, int, int) - Static method in class io.prestosql.util.JsonUtil
 
currentTokenAsSmallint(JsonParser) - Static method in class io.prestosql.util.JsonUtil
 
currentTokenAsTinyint(JsonParser) - Static method in class io.prestosql.util.JsonUtil
 
currentTokenAsVarchar(JsonParser) - Static method in class io.prestosql.util.JsonUtil
 
currentUser(ConnectorSession) - Static method in class io.prestosql.operator.scalar.SessionFunctions
 
cursor() - Method in class io.prestosql.operator.index.FieldSetFilteringRecordSet
 
cursor() - Method in class io.prestosql.operator.index.PageRecordSet
 
cursor() - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet
 
cursor() - Method in class io.prestosql.split.MappedRecordSet
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.CatalogSystemTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.AttributeJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.CatalogJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.ColumnJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.ProcedureColumnJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.ProcedureJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.PseudoColumnJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.SchemaJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.SuperTableJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.SuperTypeJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.TableJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.TableTypeJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.TypesJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.jdbc.UdtJdbcTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.NodeSystemTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.QuerySystemTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.TableCommentSystemTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.TaskSystemTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.TransactionsSystemTable
 
CursorProcessor - Interface in io.prestosql.operator.project
 
CursorProcessorCompiler - Class in io.prestosql.sql.gen
 
CursorProcessorCompiler(Metadata) - Constructor for class io.prestosql.sql.gen.CursorProcessorCompiler
 
CursorProcessorOutput - Class in io.prestosql.operator.project
 
CursorProcessorOutput(int, boolean) - Constructor for class io.prestosql.operator.project.CursorProcessorOutput
 
CYAN - io.prestosql.operator.scalar.ColorFunctions.SystemColor
 

D

DataDefinitionExecution<T extends Statement> - Class in io.prestosql.execution
 
DataDefinitionExecution.DataDefinitionExecutionFactory - Class in io.prestosql.execution
 
DataDefinitionExecutionFactory(TransactionManager, Metadata, AccessControl, Map<Class<? extends Statement>, DataDefinitionTask<?>>) - Constructor for class io.prestosql.execution.DataDefinitionExecution.DataDefinitionExecutionFactory
 
DataDefinitionTask<T extends Statement> - Interface in io.prestosql.execution
 
DataProviders - Class in io.prestosql.testing
 
DataSizeFunctions - Class in io.prestosql.operator.scalar
 
dateAdd(long, Slice, long, long) - Static method in class io.prestosql.operator.scalar.time.TimeFunctions
 
DateAdd - Class in io.prestosql.operator.scalar.timestamp
 
DateAdd - Class in io.prestosql.operator.scalar.timestamptz
 
DateAdd - Class in io.prestosql.operator.scalar.timetz
 
dateDiff(Slice, long, long) - Static method in class io.prestosql.operator.scalar.time.TimeFunctions
 
DateDiff - Class in io.prestosql.operator.scalar.timestamp
 
DateDiff - Class in io.prestosql.operator.scalar.timestamptz
 
DateDiff - Class in io.prestosql.operator.scalar.timetz
 
dateFormat(ISOChronology, Locale, long, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
DateFormat - Class in io.prestosql.operator.scalar.timestamp
 
DateFormat - Class in io.prestosql.operator.scalar.timestamptz
 
dateMinusIntervalDayToSecond(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
dateMinusIntervalYearToMonth(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
DateOperators - Class in io.prestosql.type
 
dateParse(ConnectorSession, Slice, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
datePlusIntervalDayToSecond(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
datePlusIntervalYearToMonth(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
DATETIME_PATTERN - Static variable in class io.prestosql.type.DateTimes
 
DateTimeFunctions - Class in io.prestosql.operator.scalar
 
DateTimeFunctions.FromUnixtimeNanosDecimal - Class in io.prestosql.operator.scalar
 
DateTimeOperators - Class in io.prestosql.type
 
DateTimes - Class in io.prestosql.type
 
DateTimeTestingUtils - Class in io.prestosql.testing
 
DateTimeUtils - Class in io.prestosql.util
 
DateTimeZoneIndex - Class in io.prestosql.util
 
DateToTimestampCast - Class in io.prestosql.operator.scalar.timestamp
 
DateToTimestampWithTimeZoneCast - Class in io.prestosql.operator.scalar.timestamptz
 
DateTrunc - Class in io.prestosql.operator.scalar.timestamp
 
DateTrunc - Class in io.prestosql.operator.scalar.timestamptz
 
DateTrunc - Class in io.prestosql.operator.scalar.timetz
 
dayFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayOfWeekFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayOfYearFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
deallocate(int) - Method in class io.prestosql.operator.IdRegistry
 
DeallocateTask - Class in io.prestosql.execution
 
DeallocateTask() - Constructor for class io.prestosql.execution.DeallocateTask
 
DECIMAL - Static variable in class io.prestosql.type.DecimalParametricType
 
DECIMAL_ADD_OPERATOR - Static variable in class io.prestosql.type.DecimalOperators
 
DECIMAL_AVERAGE_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
DECIMAL_DIVIDE_OPERATOR - Static variable in class io.prestosql.type.DecimalOperators
 
DECIMAL_MOD_FUNCTION - Static variable in class io.prestosql.operator.scalar.MathFunctions
 
DECIMAL_MODULUS_OPERATOR - Static variable in class io.prestosql.type.DecimalOperators
 
DECIMAL_MULTIPLY_OPERATOR - Static variable in class io.prestosql.type.DecimalOperators
 
DECIMAL_SUBTRACT_OPERATOR - Static variable in class io.prestosql.type.DecimalOperators
 
DECIMAL_SUM_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.DecimalSumAggregation
 
DECIMAL_TO_BIGINT_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
DECIMAL_TO_BIGINT_SATURATED_FLOOR_CAST - Static variable in class io.prestosql.type.DecimalSaturatedFloorCasts
 
DECIMAL_TO_BOOLEAN_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
DECIMAL_TO_DECIMAL_CAST - Static variable in class io.prestosql.type.DecimalToDecimalCasts
 
DECIMAL_TO_DECIMAL_SATURATED_FLOOR_CAST - Static variable in class io.prestosql.type.DecimalSaturatedFloorCasts
 
DECIMAL_TO_DOUBLE_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
DECIMAL_TO_INTEGER_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
DECIMAL_TO_INTEGER_SATURATED_FLOOR_CAST - Static variable in class io.prestosql.type.DecimalSaturatedFloorCasts
 
DECIMAL_TO_JSON_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
DECIMAL_TO_REAL_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
DECIMAL_TO_SMALLINT_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
DECIMAL_TO_SMALLINT_SATURATED_FLOOR_CAST - Static variable in class io.prestosql.type.DecimalSaturatedFloorCasts
 
DECIMAL_TO_TINYINT_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
DECIMAL_TO_TINYINT_SATURATED_FLOOR_CAST - Static variable in class io.prestosql.type.DecimalSaturatedFloorCasts
 
DECIMAL_TO_VARCHAR_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
DecimalAverageAggregation - Class in io.prestosql.operator.aggregation
 
DecimalAverageAggregation() - Constructor for class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
DecimalCasts - Class in io.prestosql.type
 
DecimalOperators - Class in io.prestosql.type
 
DecimalOperators.Negation - Class in io.prestosql.type
 
DecimalParametricType - Class in io.prestosql.type
 
DecimalParametricType() - Constructor for class io.prestosql.type.DecimalParametricType
 
DecimalSaturatedFloorCasts - Class in io.prestosql.type
 
DecimalSumAggregation - Class in io.prestosql.operator.aggregation
 
DecimalSumAggregation() - Constructor for class io.prestosql.operator.aggregation.DecimalSumAggregation
 
DecimalToDecimalCasts - Class in io.prestosql.type
 
declareDependencies(FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder) - Method in class io.prestosql.operator.annotations.CastImplementationDependency
 
declareDependencies(FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder) - Method in class io.prestosql.operator.annotations.FunctionImplementationDependency
 
declareDependencies(FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder) - Method in interface io.prestosql.operator.annotations.ImplementationDependency
 
declareDependencies(FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder) - Method in class io.prestosql.operator.annotations.LiteralImplementationDependency
 
declareDependencies(FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder) - Method in class io.prestosql.operator.annotations.OperatorImplementationDependency
 
declareDependencies(FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder) - Method in class io.prestosql.operator.annotations.TypeImplementationDependency
 
decodeCatalogPropertyValue(CatalogName, String, String, String, Class<T>) - Method in class io.prestosql.metadata.SessionPropertyManager
 
decodeFunction(QualifiedName) - Method in interface io.prestosql.metadata.Metadata
 
decodeFunction(QualifiedName) - Method in class io.prestosql.metadata.MetadataManager
 
decodeKeys(String) - Static method in class io.prestosql.server.security.jwt.JwkDecoder
 
decodePageIndex(long) - Method in class io.prestosql.PagesIndexPageSorter
 
decodePosition(long) - Static method in class io.prestosql.operator.SyntheticAddress
 
decodePositionIndex(long) - Method in class io.prestosql.PagesIndexPageSorter
 
decodeSliceIndex(long) - Static method in class io.prestosql.operator.SyntheticAddress
 
decodeSystemPropertyValue(String, String, Class<T>) - Method in class io.prestosql.metadata.SessionPropertyManager
 
decorate(Runnable) - Method in interface io.prestosql.dispatcher.DecoratingListeningExecutorService.TaskDecorator
 
decorate(Callable<T>) - Method in interface io.prestosql.dispatcher.DecoratingListeningExecutorService.TaskDecorator
 
DecoratingListeningExecutorService - Class in io.prestosql.dispatcher
 
DecoratingListeningExecutorService(ListeningExecutorService, DecoratingListeningExecutorService.TaskDecorator) - Constructor for class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
DecoratingListeningExecutorService.TaskDecorator - Interface in io.prestosql.dispatcher
 
DecorrelatedNode(List<Expression>, PlanNode) - Constructor for class io.prestosql.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatedNode
 
decorrelateFilters(PlanNode, List<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.PlanNodeDecorrelator
 
decrypt(byte[], int, int, byte[], int) - Method in class io.prestosql.spiller.AesSpillCipher
 
decrypt(byte[], int, int, byte[], int) - Method in interface io.prestosql.spiller.SpillCipher
Decrypts the contents of the input buffer into the destination buffer, returning the number of bytes written into the destination buffer
decryptedMaxLength(int) - Method in class io.prestosql.spiller.AesSpillCipher
 
decryptedMaxLength(int) - Method in interface io.prestosql.spiller.SpillCipher
Calculates the required buffer size to decrypt data with the given encrypted length
DEFAULT_ACCURACY - Static variable in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
DEFAULT_FILTER_FACTOR_ENABLED - Static variable in class io.prestosql.SystemSessionProperties
 
DEFAULT_ISOLATION - Static variable in interface io.prestosql.transaction.TransactionManager
 
DEFAULT_MAX_HASHES - Static variable in class io.prestosql.type.setdigest.SetDigest
 
DEFAULT_PRECISION - Static variable in class io.prestosql.testing.MaterializedResult
 
DEFAULT_READ_ONLY - Static variable in interface io.prestosql.transaction.TransactionManager
 
DEFAULT_TIME_ZONE_KEY - Static variable in class io.prestosql.testing.TestingSession
 
DEFAULT_WEIGHT - Static variable in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
DEFAULT_WEIGHT - Static variable in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
DEFAULT_WEIGHT - Static variable in class io.prestosql.operator.scalar.TDigestFunctions
 
DefaultApproximateCountDistinctAggregation - Class in io.prestosql.operator.aggregation
 
DefaultFactory(OrderingCompiler, JoinCompiler, FeaturesConfig, BlockTypeOperators) - Constructor for class io.prestosql.operator.PagesIndex.DefaultFactory
 
defaultParallelism(Session) - Static method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
defaultPrefixes(String) - Static method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
defaultReturnValue() - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
defaultReturnValue(long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
defaultRewrite(PlanNode) - Method in class io.prestosql.sql.planner.plan.SimplePlanRewriter.RewriteContext
Invoke the rewrite logic recursively on children of the given node and swap it out with an identical copy with the rewritten children
defaultRewrite(PlanNode, C) - Method in class io.prestosql.sql.planner.plan.SimplePlanRewriter.RewriteContext
Invoke the rewrite logic recursively on children of the given node and swap it out with an identical copy with the rewritten children
DefaultShutdownAction - Class in io.prestosql.server
 
DefaultShutdownAction() - Constructor for class io.prestosql.server.DefaultShutdownAction
 
DefaultWarningCollector - Class in io.prestosql.execution.warnings
 
DefaultWarningCollector(WarningCollectorConfig) - Constructor for class io.prestosql.execution.warnings.DefaultWarningCollector
 
defineClass(ClassDefinition, Class<T>, DynamicClassLoader) - Static method in class io.prestosql.util.CompilerUtils
 
defineClass(ClassDefinition, Class<T>, Map<Long, MethodHandle>, ClassLoader) - Static method in class io.prestosql.util.CompilerUtils
 
defRetValue - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
The default return value for get(), put() and remove().
degrees(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
delegate() - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
delegate() - Method in class io.prestosql.security.ForwardingAccessControl
 
delete() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
delete(boolean) - Static method in class io.prestosql.server.ui.OAuthWebUiCookie
 
DELETE_TABLE - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
DeleteNode - Class in io.prestosql.sql.planner.plan
 
DeleteNode(PlanNodeId, PlanNode, TableWriterNode.DeleteTarget, Symbol, List<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.DeleteNode
 
DeleteOperator - Class in io.prestosql.operator
 
DeleteOperator(OperatorContext, int) - Constructor for class io.prestosql.operator.DeleteOperator
 
DeleteOperator.DeleteOperatorFactory - Class in io.prestosql.operator
 
DeleteOperatorFactory(int, PlanNodeId, int) - Constructor for class io.prestosql.operator.DeleteOperator.DeleteOperatorFactory
 
DeleteTarget(TableHandle, SchemaTableName) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.DeleteTarget
 
deleteTask(TaskId, boolean, UriInfo) - Method in class io.prestosql.server.TaskResource
 
DenseRankFunction - Class in io.prestosql.operator.window
 
DenseRankFunction() - Constructor for class io.prestosql.operator.window.DenseRankFunction
 
deny(TestingAccessControlManager.TestingPrivilege...) - Method in class io.prestosql.testing.TestingAccessControlManager
 
DenyAllAccessControl - Class in io.prestosql.security
 
DenyAllAccessControl() - Constructor for class io.prestosql.security.DenyAllAccessControl
 
denyCatalogs(Predicate<String>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
denyIdentityTable(BiPredicate<Identity, String>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
denyTables(Predicate<SchemaTableName>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
dependsOn(WindowNode, WindowNode) - Static method in class io.prestosql.sql.planner.optimizations.WindowNodeUtil
 
dequeueLastLong() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
Dequeues the last element from the queue.
dequeueLong() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
 
dereference(long) - Method in class io.prestosql.operator.RowReferencePageManager
 
DEREFERENCE - io.prestosql.sql.relational.SpecialForm.Form
 
DereferenceCodeGenerator - Class in io.prestosql.sql.gen
 
DereferenceCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.DereferenceCodeGenerator
 
deriveProperties(PlanNode, StreamPropertyDerivations.StreamProperties, Metadata, TypeOperators, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations
 
deriveProperties(PlanNode, List<ActualProperties>, Metadata, TypeOperators, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.PropertyDerivations
 
deriveProperties(PlanNode, List<StreamPropertyDerivations.StreamProperties>, Metadata, TypeOperators, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations
 
derivePropertiesRecursively(PlanNode, Metadata, TypeOperators, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.PropertyDerivations
 
derivePropertiesRecursively(PlanNode, Metadata, TypeOperators, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations
 
description(String) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
Descriptor(DynamicFilterId, Expression) - Constructor for class io.prestosql.sql.DynamicFilters.Descriptor
 
Descriptor(DynamicFilterId, Expression, ComparisonExpression.Operator) - Constructor for class io.prestosql.sql.DynamicFilters.Descriptor
 
deserialize(JsonParser, DeserializationContext) - Method in class io.prestosql.block.BlockJsonSerde.Deserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class io.prestosql.server.ExpressionSerialization.ExpressionDeserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class io.prestosql.server.RangeJsonSerde.Deserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class io.prestosql.server.SliceSerialization.SliceDeserializer
 
deserialize(SliceInput, ApproximateMostFrequentHistogram<K>) - Method in interface io.prestosql.operator.aggregation.ApproximateMostFrequentBucketDeserializer
 
deserialize(PagesSerde.PagesSerdeContext, SerializedPage) - Method in class io.prestosql.execution.buffer.PagesSerde
 
deserialize(SerializedPage) - Method in class io.prestosql.execution.buffer.PagesSerde
 
deserialize(Block, int) - Method in class io.prestosql.operator.aggregation.histogram.GroupedHistogramState
 
deserialize(Block, int) - Method in interface io.prestosql.operator.aggregation.histogram.HistogramState
 
deserialize(Block, int) - Method in class io.prestosql.operator.aggregation.histogram.SingleHistogramState
 
deserialize(Block, int, ArrayAggregationState) - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateSerializer
 
deserialize(Block, int, BigintApproximateMostFrequent.State) - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateSerializer
 
deserialize(Block, int, DoubleHistogramAggregation.State) - Method in class io.prestosql.operator.aggregation.state.DoubleHistogramStateSerializer
 
deserialize(Block, int, HistogramState) - Method in class io.prestosql.operator.aggregation.histogram.HistogramStateSerializer
 
deserialize(Block, int, MinMaxByNState) - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateSerializer
 
deserialize(Block, int, MultimapAggregationState) - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateSerializer
 
deserialize(Block, int, BlockPositionState) - Method in class io.prestosql.operator.aggregation.state.BlockPositionStateSerializer
 
deserialize(Block, int, BlockState) - Method in class io.prestosql.operator.aggregation.state.BlockStateSerializer
 
deserialize(Block, int, HyperLogLogState) - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateSerializer
 
deserialize(Block, int, KeyValuePairsState) - Method in class io.prestosql.operator.aggregation.state.KeyValuePairStateSerializer
 
deserialize(Block, int, LongDecimalWithOverflowAndLongState) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateSerializer
 
deserialize(Block, int, LongDecimalWithOverflowState) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateSerializer
 
deserialize(Block, int, MinMaxNState) - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateSerializer
 
deserialize(Block, int, NullableBooleanState) - Method in class io.prestosql.operator.aggregation.state.NullableBooleanStateSerializer
 
deserialize(Block, int, NullableDoubleState) - Method in class io.prestosql.operator.aggregation.state.NullableDoubleStateSerializer
 
deserialize(Block, int, NullableLongState) - Method in class io.prestosql.operator.aggregation.state.NullableLongStateSerializer
 
deserialize(Block, int, QuantileDigestAndPercentileState) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateSerializer
 
deserialize(Block, int, QuantileDigestState) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateSerializer
 
deserialize(Block, int, TDigestAndPercentileArrayState) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateSerializer
 
deserialize(Block, int, TDigestAndPercentileState) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateSerializer
 
deserialize(Block, int, TDigestState) - Method in class io.prestosql.operator.aggregation.state.TDigestStateSerializer
 
deserialize(Block, int, TriStateBooleanState) - Method in class io.prestosql.operator.aggregation.state.TriStateBooleanStateSerializer
 
deserialize(Block, int, VarcharApproximateMostFrequent.State) - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateSerializer
 
deserialize(Block, int, SetDigestState) - Method in class io.prestosql.type.setdigest.SetDigestStateSerializer
 
deserialize(Block, int, T) - Method in class io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueStateSerializer
 
deserialize(Block, Type, Type, BlockTypeOperators.BlockPositionComparison) - Static method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
deserializeBucket(SliceInput, ApproximateMostFrequentHistogram<Slice>) - Static method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateSerializer
 
deserializeBucket(SliceInput, ApproximateMostFrequentHistogram<Long>) - Static method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateSerializer
 
deserializeKey(String, DeserializationContext) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.ColumnStatisticMetadataKeyDeserializer
 
deserializeKey(String, DeserializationContext) - Method in class io.prestosql.type.TypeSignatureKeyDeserializer
 
Deserializer() - Constructor for class io.prestosql.server.RangeJsonSerde.Deserializer
 
Deserializer(BlockEncodingSerde) - Constructor for class io.prestosql.block.BlockJsonSerde.Deserializer
 
destroy() - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
destroy() - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
destroy() - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
destroy() - Method in interface io.prestosql.execution.buffer.OutputBuffer
Destroys the buffer, discarding all pages.
destroy() - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
destroy() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
destroy() - Method in class io.prestosql.execution.executor.TaskHandle
 
destroy() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
destroy() - Method in class io.prestosql.execution.scheduler.NodeSchedulerExporter
 
destroy() - Method in class io.prestosql.memory.ClusterMemoryManager
 
destroy() - Method in class io.prestosql.memory.LocalMemoryManagerExporter
 
destroy() - Method in class io.prestosql.operator.index.IndexLookupSourceFactory
 
destroy() - Method in interface io.prestosql.operator.JoinBridge
 
destroy() - Method in interface io.prestosql.operator.LookupSourceFactory
 
destroy() - Method in interface io.prestosql.operator.NestedLoopJoinBridge
 
destroy() - Method in class io.prestosql.operator.NestedLoopJoinPagesSupplier
 
destroy() - Method in class io.prestosql.operator.OperatorContext
 
destroy() - Method in class io.prestosql.operator.PagesSpatialIndexFactory
 
destroy() - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
destroy() - Method in class io.prestosql.spiller.FileSingleStreamSpillerFactory
 
destroy() - Method in class io.prestosql.sql.planner.PlanOptimizers
 
destroy() - Method in class io.prestosql.util.FinalizerService
 
DesugarArrayConstructor - Class in io.prestosql.sql.planner.iterative.rule
 
DesugarArrayConstructor(Metadata, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.DesugarArrayConstructor
 
DesugarArrayConstructorRewriter - Class in io.prestosql.sql.planner
 
DesugarAtTimeZone - Class in io.prestosql.sql.planner.iterative.rule
 
DesugarAtTimeZone(Metadata, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.DesugarAtTimeZone
 
DesugarAtTimeZoneRewriter - Class in io.prestosql.sql.planner
 
DesugarCurrentPath - Class in io.prestosql.sql.planner.iterative.rule
 
DesugarCurrentPath(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.DesugarCurrentPath
 
DesugarCurrentUser - Class in io.prestosql.sql.planner.iterative.rule
 
DesugarCurrentUser(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.DesugarCurrentUser
 
DesugarLambdaExpression - Class in io.prestosql.sql.planner.iterative.rule
 
DesugarLambdaExpression() - Constructor for class io.prestosql.sql.planner.iterative.rule.DesugarLambdaExpression
 
DesugarLike - Class in io.prestosql.sql.planner.iterative.rule
 
DesugarLike(Metadata, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.DesugarLike
 
DesugarLikeRewriter - Class in io.prestosql.sql.planner
 
DesugarRowSubscript - Class in io.prestosql.sql.planner.iterative.rule
 
DesugarRowSubscript(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.DesugarRowSubscript
 
DesugarRowSubscriptRewriter - Class in io.prestosql.sql.planner
Replaces subscript expression on Row with cast and dereference:
DesugarTryExpression - Class in io.prestosql.sql.planner.iterative.rule
 
DesugarTryExpression(Metadata, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.DesugarTryExpression
 
DesugarTryExpressionRewriter - Class in io.prestosql.sql.planner
 
DetermineJoinDistributionType - Class in io.prestosql.sql.planner.iterative.rule
 
DetermineJoinDistributionType(CostComparator, TaskCountEstimator) - Constructor for class io.prestosql.sql.planner.iterative.rule.DetermineJoinDistributionType
 
DetermineSemiJoinDistributionType - Class in io.prestosql.sql.planner.iterative.rule
This rule must run after the distribution type has already been set for delete queries, since semi joins in delete queries must be replicated.
DetermineSemiJoinDistributionType(CostComparator, TaskCountEstimator) - Constructor for class io.prestosql.sql.planner.iterative.rule.DetermineSemiJoinDistributionType
 
DeterminismEvaluator - Class in io.prestosql.sql.planner
Determines whether a given Expression is deterministic
DeterminismEvaluator - Class in io.prestosql.sql.relational
 
DeterminismEvaluator(Metadata) - Constructor for class io.prestosql.sql.relational.DeterminismEvaluator
 
deterministic(boolean) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
DevNullOperator - Class in io.prestosql.operator
 
DevNullOperator(OperatorContext) - Constructor for class io.prestosql.operator.DevNullOperator
 
DevNullOperator.DevNullOperatorFactory - Class in io.prestosql.operator
 
DevNullOperatorFactory(int, PlanNodeId) - Constructor for class io.prestosql.operator.DevNullOperator.DevNullOperatorFactory
 
DICTIONARY_AGGREGATION - Static variable in class io.prestosql.SystemSessionProperties
 
DictionaryAwarePageFilter - Class in io.prestosql.operator.project
 
DictionaryAwarePageFilter(PageFilter) - Constructor for class io.prestosql.operator.project.DictionaryAwarePageFilter
 
DictionaryAwarePageProjection - Class in io.prestosql.operator.project
 
DictionaryAwarePageProjection(PageProjection, Function<DictionaryBlock, DictionaryId>, boolean) - Constructor for class io.prestosql.operator.project.DictionaryAwarePageProjection
 
diff(Slice, long, long) - Static method in class io.prestosql.operator.scalar.timestamp.DateDiff
 
diff(Slice, long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.DateDiff
 
diff(Slice, long, long) - Static method in class io.prestosql.operator.scalar.timetz.DateDiff
 
diff(Slice, LongTimestamp, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.DateDiff
 
diff(Slice, LongTimestampWithTimeZone, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.DateDiff
 
diff(Slice, LongTimeWithTimeZone, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.DateDiff
 
diffDate(ConnectorSession, Slice, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
DisabledWebUiAuthenticationFilter - Class in io.prestosql.server.ui
 
DisabledWebUiAuthenticationFilter() - Constructor for class io.prestosql.server.ui.DisabledWebUiAuthenticationFilter
 
DISALLOWED - io.prestosql.sql.analyzer.CorrelationSupport
 
DiscoveryNodeManager - Class in io.prestosql.metadata
 
DiscoveryNodeManager(ServiceSelector, NodeInfo, FailureDetector, NodeVersion, HttpClient, InternalCommunicationConfig) - Constructor for class io.prestosql.metadata.DiscoveryNodeManager
 
DisjointSet<T> - Class in io.prestosql.util
 
DisjointSet() - Constructor for class io.prestosql.util.DisjointSet
 
dispatched(CoordinatorLocation, Duration, Duration) - Static method in class io.prestosql.dispatcher.DispatchInfo
 
DispatchExecutor - Class in io.prestosql.dispatcher
 
DispatchExecutor(QueryManagerConfig, EmbedVersion) - Constructor for class io.prestosql.dispatcher.DispatchExecutor
 
DispatchExecutor.DispatchExecutorMBeans - Class in io.prestosql.dispatcher
 
DispatchExecutorMBeans(ExecutorService, ScheduledExecutorService) - Constructor for class io.prestosql.dispatcher.DispatchExecutor.DispatchExecutorMBeans
 
DispatchInfo - Class in io.prestosql.dispatcher
 
DISPATCHING - io.prestosql.execution.QueryState
Query is being dispatched to a coordinator.
DispatchManager - Class in io.prestosql.dispatcher
 
DispatchManager(QueryIdGenerator, QueryPreparer, ResourceGroupManager<?>, DispatchQueryFactory, FailedDispatchQueryFactory, TransactionManager, AccessControl, SessionSupplier, SessionPropertyDefaults, QueryManagerConfig, DispatchExecutor) - Constructor for class io.prestosql.dispatcher.DispatchManager
 
DispatchQuery - Interface in io.prestosql.dispatcher
 
DispatchQueryFactory - Interface in io.prestosql.dispatcher
 
distinct() - Static method in class io.prestosql.sql.planner.plan.Patterns.Except
 
distinct() - Static method in class io.prestosql.sql.planner.plan.Patterns.Intersect
 
distinct(Type, BlockTypeOperators.BlockPositionIsDistinctFrom, BlockTypeOperators.BlockPositionHashCode, Block) - Method in class io.prestosql.operator.scalar.ArrayDistinctFunction
 
distinctLimit() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
DistinctLimit() - Constructor for class io.prestosql.sql.planner.plan.Patterns.DistinctLimit
 
DistinctLimitNode - Class in io.prestosql.sql.planner.plan
 
DistinctLimitNode(PlanNodeId, PlanNode, long, boolean, List<Symbol>, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.DistinctLimitNode
 
DistinctLimitOperator - Class in io.prestosql.operator
 
DistinctLimitOperator(OperatorContext, List<Integer>, List<Type>, long, Optional<Integer>, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.DistinctLimitOperator
 
DistinctLimitOperator.DistinctLimitOperatorFactory - Class in io.prestosql.operator
 
DistinctLimitOperatorFactory(int, PlanNodeId, List<? extends Type>, List<Integer>, long, Optional<Integer>, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.DistinctLimitOperator.DistinctLimitOperatorFactory
 
DistinctOutputQueryUtil - Class in io.prestosql.sql.planner.optimizations
 
DISTRIBUTED_INDEX_JOIN - Static variable in class io.prestosql.SystemSessionProperties
 
DISTRIBUTED_PLAN_SANITY_CHECKER - Static variable in class io.prestosql.sql.planner.sanity.PlanSanityChecker
 
DISTRIBUTED_SORT - Static variable in class io.prestosql.SystemSessionProperties
 
DistributedExecutionPlanner - Class in io.prestosql.sql.planner
 
DistributedExecutionPlanner(SplitManager, Metadata, DynamicFilterService) - Constructor for class io.prestosql.sql.planner.DistributedExecutionPlanner
 
divide(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
divide(long, long) - Static method in class io.prestosql.type.BigintOperators
 
divide(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
divide(long, long) - Static method in class io.prestosql.type.RealOperators
 
divide(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
divide(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
divideByDouble(long, double) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
divideByDouble(long, double) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
divideLongLongLong(Slice, Slice, int) - Static method in class io.prestosql.type.DecimalOperators
 
divideLongShortLong(Slice, long, int) - Static method in class io.prestosql.type.DecimalOperators
 
divideLongShortShort(Slice, long, int) - Static method in class io.prestosql.type.DecimalOperators
 
divideShortLongLong(long, Slice, int) - Static method in class io.prestosql.type.DecimalOperators
 
divideShortLongShort(long, Slice, int) - Static method in class io.prestosql.type.DecimalOperators
 
divideShortShortLong(long, long, int) - Static method in class io.prestosql.type.DecimalOperators
 
divideShortShortShort(long, long, int) - Static method in class io.prestosql.type.DecimalOperators
 
doCalculate(AggregationNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.AggregationStatsRule
 
doCalculate(EnforceSingleRowNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.EnforceSingleRowStatsRule
 
doCalculate(ExchangeNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.ExchangeStatsRule
 
doCalculate(FilterNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.FilterStatsRule
 
doCalculate(FilterNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.SimpleFilterProjectSemiJoinStatsRule
 
doCalculate(JoinNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.JoinStatsRule
 
doCalculate(LimitNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.LimitStatsRule
 
doCalculate(ProjectNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.ProjectStatsRule
 
doCalculate(RowNumberNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.RowNumberStatsRule
 
doCalculate(SpatialJoinNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.SpatialJoinStatsRule
 
doCalculate(TableScanNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.TableScanStatsRule
 
doCalculate(TopNNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.TopNStatsRule
 
doCalculate(UnionNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.UnionStatsRule
 
doCalculate(T, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.SimpleStatsRule
 
DomainCoercer - Class in io.prestosql.sql.planner
Apply saturated floor casts for implicit coercions on TupleDomain.
DomainTranslator - Class in io.prestosql.sql.planner
 
DomainTranslator(Metadata) - Constructor for class io.prestosql.sql.planner.DomainTranslator
 
DomainTranslator.ExtractionResult - Class in io.prestosql.sql.planner
 
DOUBLE_TO_DECIMAL_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
DoubleAndBlockPositionValueState - Interface in io.prestosql.operator.aggregation.minmaxby
 
doubleArrayMax(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMaxFunction
 
doubleArrayMin(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMinFunction
 
DoubleBooleanState - Interface in io.prestosql.operator.aggregation.minmaxby
 
DoubleCorrelationAggregation - Class in io.prestosql.operator.aggregation
 
DoubleCovarianceAggregation - Class in io.prestosql.operator.aggregation
 
DoubleDoubleState - Interface in io.prestosql.operator.aggregation.minmaxby
 
doubleElementAt(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayElementAtFunction
 
DoubleHistogramAggregation - Class in io.prestosql.operator.aggregation
 
DoubleHistogramAggregation.State - Interface in io.prestosql.operator.aggregation
 
DoubleHistogramStateSerializer - Class in io.prestosql.operator.aggregation.state
 
DoubleHistogramStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.DoubleHistogramStateSerializer
 
doubleInput(CentralMomentsState, double) - Static method in class io.prestosql.operator.aggregation.CentralMomentsAggregation
 
doubleInput(VarianceState, double) - Static method in class io.prestosql.operator.aggregation.VarianceAggregation
 
DoubleLongState - Interface in io.prestosql.operator.aggregation.minmaxby
 
doubleMultiply(double, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
doubleMultiply(double, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
DoubleOperators - Class in io.prestosql.type
 
DoubleRegressionAggregation - Class in io.prestosql.operator.aggregation
 
DoubleState - Interface in io.prestosql.operator.aggregation.state
 
doubleSubscript(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
DoubleSumAggregation - Class in io.prestosql.operator.aggregation
 
DoubleToBooleanFunction - Interface in io.prestosql.operator.scalar
 
doubleToLongDecimal(double, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
doubleToShortDecimal(double, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
doubleToSortableLong(double) - Static method in class io.prestosql.operator.aggregation.FloatingPointBitsConverterUtil
Converts a double value to a sortable long.
doubleTypeArrayMax(Block) - Static method in class io.prestosql.operator.scalar.ArrayMaxFunction
 
drainCompletedLifespans() - Method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
 
drainCompletedLifespans() - Method in interface io.prestosql.execution.scheduler.SourceScheduler
 
drainTo(long, LongBigArray) - Method in class io.prestosql.operator.GroupedTopNRowNumberAccumulator
Drain the contents of groupId from this accumulator to the provided output row ID buffer.
Driver - Class in io.prestosql.operator
 
DriverContext - Class in io.prestosql.operator
Only calling getDriverStats is ThreadSafe
DriverContext(PipelineContext, Executor, ScheduledExecutorService, MemoryTrackingContext, Lifespan) - Constructor for class io.prestosql.operator.DriverContext
 
DriverFactory - Class in io.prestosql.operator
 
DriverFactory(int, boolean, boolean, List<OperatorFactory>, OptionalInt, PipelineExecutionStrategy) - Constructor for class io.prestosql.operator.DriverFactory
 
driverFinished(DriverContext) - Method in class io.prestosql.operator.PipelineContext
 
driverGroup(int) - Static method in class io.prestosql.execution.Lifespan
 
DriverStats - Class in io.prestosql.operator
 
DriverStats() - Constructor for class io.prestosql.operator.DriverStats
 
DriverStats(Lifespan, DateTime, DateTime, DateTime, Duration, Duration, DataSize, DataSize, DataSize, Duration, Duration, Duration, boolean, Set<BlockedReason>, DataSize, long, Duration, DataSize, long, Duration, DataSize, long, Duration, DataSize, long, DataSize, long, DataSize, List<OperatorStats>) - Constructor for class io.prestosql.operator.DriverStats
 
DriverWindowInfo(double, double, double, long, long, long) - Constructor for class io.prestosql.operator.WindowInfo.DriverWindowInfo
 
DriverYieldSignal - Class in io.prestosql.operator
Methods setWithDelay and reset should be used in pairs; usually follow the following idiom:
DriverYieldSignal() - Constructor for class io.prestosql.operator.DriverYieldSignal
 
DROP_COLUMN - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
DROP_SCHEMA - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
DROP_TABLE - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
DROP_VIEW - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
dropColumn(Session, TableHandle, ColumnHandle) - Method in interface io.prestosql.metadata.Metadata
Drop the specified column.
dropColumn(Session, TableHandle, ColumnHandle) - Method in class io.prestosql.metadata.MetadataManager
 
DropColumnTask - Class in io.prestosql.execution
 
DropColumnTask() - Constructor for class io.prestosql.execution.DropColumnTask
 
dropConnection(String) - Method in class io.prestosql.connector.ConnectorManager
 
dropMaterializedView(Session, QualifiedObjectName) - Method in interface io.prestosql.metadata.Metadata
Drops the specified materialized view.
dropMaterializedView(Session, QualifiedObjectName) - Method in class io.prestosql.metadata.MetadataManager
 
DropMaterializedViewTask - Class in io.prestosql.execution
 
DropMaterializedViewTask() - Constructor for class io.prestosql.execution.DropMaterializedViewTask
 
dropRole(Session, String, String) - Method in interface io.prestosql.metadata.Metadata
Drops the specified role in the specified catalog.
dropRole(Session, String, String) - Method in class io.prestosql.metadata.MetadataManager
 
DropRoleTask - Class in io.prestosql.execution
 
DropRoleTask() - Constructor for class io.prestosql.execution.DropRoleTask
 
dropSchema(Session, CatalogSchemaName) - Method in interface io.prestosql.metadata.Metadata
Drops the specified schema.
dropSchema(Session, CatalogSchemaName) - Method in class io.prestosql.metadata.MetadataManager
 
DropSchemaTask - Class in io.prestosql.execution
 
DropSchemaTask() - Constructor for class io.prestosql.execution.DropSchemaTask
 
dropTable(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Drops the specified table
dropTable(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
dropTable(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.testing.TestingMetadata
 
DropTableTask - Class in io.prestosql.execution
 
DropTableTask() - Constructor for class io.prestosql.execution.DropTableTask
 
dropView(Session, QualifiedObjectName) - Method in interface io.prestosql.metadata.Metadata
Drops the specified view.
dropView(Session, QualifiedObjectName) - Method in class io.prestosql.metadata.MetadataManager
 
dropView(ConnectorSession, SchemaTableName) - Method in class io.prestosql.testing.TestingMetadata
 
DropViewTask - Class in io.prestosql.execution
 
DropViewTask() - Constructor for class io.prestosql.execution.DropViewTask
 
duplicate() - Method in class io.prestosql.operator.AggregationOperator.AggregationOperatorFactory
 
duplicate() - Method in interface io.prestosql.operator.BasicWorkProcessorOperatorAdapter.BasicAdapterWorkProcessorOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.DeleteOperator.DeleteOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.DevNullOperator.DevNullOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.DistinctLimitOperator.DistinctLimitOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.DynamicFilterSourceOperator.DynamicFilterSourceOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.EnforceSingleRowOperator.EnforceSingleRowOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeSinkFactory
 
duplicate() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator.LocalExchangeSinkOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator.LocalExchangeSourceOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator.LocalMergeSourceOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.ExplainAnalyzeOperator.ExplainAnalyzeOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.GroupIdOperator.GroupIdOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.HashAggregationOperator.HashAggregationOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.HashBuilderOperator.HashBuilderOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.index.PageBufferOperator.PageBufferOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.index.PagesIndexBuilderOperator.PagesIndexBuilderOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.LimitOperator.LimitOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.LookupOuterOperator.LookupOuterOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.MarkDistinctOperator.MarkDistinctOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.NestedLoopBuildOperator.NestedLoopBuildOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.NestedLoopJoinOperator.NestedLoopJoinOperatorFactory
 
duplicate() - Method in interface io.prestosql.operator.OperatorFactory
 
duplicate() - Method in class io.prestosql.operator.OrderByOperator.OrderByOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.RowNumberOperator.RowNumberOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.SetBuilderOperator.SetBuilderOperatorFactory
 
duplicate() - Method in interface io.prestosql.operator.SourceOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.SpatialIndexBuilderOperator.SpatialIndexBuilderOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.SpatialJoinOperator.SpatialJoinOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.StatisticsWriterOperator.StatisticsWriterOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.TableDeleteOperator.TableDeleteOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.TableFinishOperator.TableFinishOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.TableWriterOperator.TableWriterOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.TaskOutputOperator.TaskOutputOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.TopNRowNumberOperator.TopNRowNumberOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.unnest.UnnestOperator.UnnestOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.ValuesOperator.ValuesOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.WindowOperator.WindowOperatorFactory
 
duplicate() - Method in interface io.prestosql.operator.WorkProcessorOperatorAdapter.AdapterWorkProcessorOperatorFactory
 
duplicate() - Method in class io.prestosql.testing.NullOutputOperator.NullOutputOperatorFactory
 
duplicate() - Method in class io.prestosql.testing.PageConsumerOperator.PageConsumerOperatorFactory
 
duplicatePluginClassLoader() - Method in class io.prestosql.connector.ConnectorContextInstance
 
duplicatePluginClassLoader() - Method in class io.prestosql.testing.TestingConnectorContext
 
DYNAMIC_LIFESPAN_SCHEDULE_GROUPED_EXECUTION - io.prestosql.operator.StageExecutionDescriptor.StageExecutionStrategy
 
DYNAMIC_SCHEDULE_FOR_GROUPED_EXECUTION - Static variable in class io.prestosql.SystemSessionProperties
 
DynamicBucketNodeMap - Class in io.prestosql.execution.scheduler.group
 
DynamicBucketNodeMap(ToIntFunction<Split>, int) - Constructor for class io.prestosql.execution.scheduler.group.DynamicBucketNodeMap
 
dynamicFilter(boolean, Slice, Slice) - Static method in class io.prestosql.sql.DynamicFilters.Function
 
dynamicFilter(double, Slice, Slice) - Static method in class io.prestosql.sql.DynamicFilters.Function
 
dynamicFilter(long, Slice, Slice) - Static method in class io.prestosql.sql.DynamicFilters.Function
 
dynamicFilter(Object, Slice, Slice) - Static method in class io.prestosql.sql.DynamicFilters.Function
 
DynamicFilterConfig - Class in io.prestosql.execution
 
DynamicFilterConfig() - Constructor for class io.prestosql.execution.DynamicFilterConfig
 
DynamicFilterDomainStats(DynamicFilterId, String, int, int, Optional<Duration>) - Constructor for class io.prestosql.server.DynamicFilterService.DynamicFilterDomainStats
 
DynamicFilterId - Class in io.prestosql.sql.planner.plan
 
DynamicFilterId(String) - Constructor for class io.prestosql.sql.planner.plan.DynamicFilterId
 
DynamicFilters - Class in io.prestosql.sql
 
DynamicFilters.Descriptor - Class in io.prestosql.sql
 
DynamicFilters.ExtractResult - Class in io.prestosql.sql
 
DynamicFilters.Function - Class in io.prestosql.sql
 
DynamicFiltersChecker - Class in io.prestosql.sql.planner.sanity
When dynamic filter assignments are present on a Join node, they should be consumed by a Filter node on it's probe side
DynamicFiltersChecker() - Constructor for class io.prestosql.sql.planner.sanity.DynamicFiltersChecker
 
DynamicFiltersCollector - Class in io.prestosql.execution
 
DynamicFiltersCollector(Runnable) - Constructor for class io.prestosql.execution.DynamicFiltersCollector
 
DynamicFiltersCollector.VersionedDynamicFilterDomains - Class in io.prestosql.execution
 
DynamicFilterService - Class in io.prestosql.server
 
DynamicFilterService(Metadata, TypeOperators, DynamicFilterConfig) - Constructor for class io.prestosql.server.DynamicFilterService
 
DynamicFilterService(Metadata, TypeOperators, ExecutorService) - Constructor for class io.prestosql.server.DynamicFilterService
 
DynamicFilterService.DynamicFilterDomainStats - Class in io.prestosql.server
 
DynamicFilterService.DynamicFiltersStats - Class in io.prestosql.server
 
DynamicFilterSourceOperator - Class in io.prestosql.operator
This operator acts as a simple "pass-through" pipe, while saving its input pages.
DynamicFilterSourceOperator.Channel - Class in io.prestosql.operator
 
DynamicFilterSourceOperator.DynamicFilterSourceOperatorFactory - Class in io.prestosql.operator
 
DynamicFilterSourceOperatorFactory(int, PlanNodeId, Consumer<TupleDomain<DynamicFilterId>>, List<DynamicFilterSourceOperator.Channel>, int, DataSize, int, BlockTypeOperators) - Constructor for class io.prestosql.operator.DynamicFilterSourceOperator.DynamicFilterSourceOperatorFactory
 
DynamicFiltersStats(List<DynamicFilterService.DynamicFilterDomainStats>, int, int, int, int) - Constructor for class io.prestosql.server.DynamicFilterService.DynamicFiltersStats
 
dynamicLifespanScheduleGroupedExecution(List<PlanNodeId>) - Static method in class io.prestosql.operator.StageExecutionDescriptor
 
DynamicLifespanScheduler - Class in io.prestosql.execution.scheduler.group
See LifespanScheduler about thread safety
DynamicLifespanScheduler(BucketNodeMap, List<InternalNode>, List<ConnectorPartitionHandle>, OptionalInt) - Constructor for class io.prestosql.execution.scheduler.group.DynamicLifespanScheduler
 
DynamicSplitPlacementPolicy - Class in io.prestosql.execution.scheduler
 
DynamicSplitPlacementPolicy(NodeSelector, Supplier<? extends List<RemoteTask>>) - Constructor for class io.prestosql.execution.scheduler.DynamicSplitPlacementPolicy
 
DynamicTupleFilterFactory - Class in io.prestosql.operator.index
 
DynamicTupleFilterFactory(int, PlanNodeId, int[], int[], List<Type>, PageFunctionCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.index.DynamicTupleFilterFactory
 

E

e() - Static method in class io.prestosql.operator.scalar.MathFunctions
 
Edge(PlanNode, Symbol, Symbol) - Constructor for class io.prestosql.sql.planner.optimizations.joins.JoinGraph.Edge
 
EffectivePredicateExtractor - Class in io.prestosql.sql.planner
Computes the effective predicate at the top of the specified PlanNode
EffectivePredicateExtractor(DomainTranslator, Metadata, boolean) - Constructor for class io.prestosql.sql.planner.EffectivePredicateExtractor
 
ELEMENT_TO_ARRAY_CONCAT_FUNCTION - Static variable in class io.prestosql.operator.scalar.ElementToArrayConcatFunction
 
elementAt(Type, Block, boolean) - Static method in class io.prestosql.operator.scalar.MapElementAtFunction
 
elementAt(Type, Block, double) - Static method in class io.prestosql.operator.scalar.MapElementAtFunction
 
elementAt(Type, Block, long) - Static method in class io.prestosql.operator.scalar.MapElementAtFunction
 
elementAt(Type, Block, Object) - Static method in class io.prestosql.operator.scalar.MapElementAtFunction
 
ElementToArrayConcatFunction - Class in io.prestosql.operator.scalar
 
ElementToArrayConcatFunction() - Constructor for class io.prestosql.operator.scalar.ElementToArrayConcatFunction
 
ELIMINATE_CROSS_JOINS - io.prestosql.sql.analyzer.FeaturesConfig.JoinReorderingStrategy
 
EliminateCrossJoins - Class in io.prestosql.sql.planner.iterative.rule
 
EliminateCrossJoins(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.EliminateCrossJoins
 
EmbeddedDiscoveryConfig - Class in io.prestosql.server
 
EmbeddedDiscoveryConfig() - Constructor for class io.prestosql.server.EmbeddedDiscoveryConfig
 
embedVersion(Runnable) - Method in class io.prestosql.version.EmbedVersion
 
embedVersion(Callable<T>) - Method in class io.prestosql.version.EmbedVersion
 
EmbedVersion - Class in io.prestosql.version
 
EmbedVersion(NodeVersion) - Constructor for class io.prestosql.version.EmbedVersion
 
EmbedVersion(String) - Constructor for class io.prestosql.version.EmbedVersion
 
empty() - Static method in class io.prestosql.cost.StatisticRange
 
empty() - Static method in class io.prestosql.cost.StatsAndCosts
 
empty() - Static method in class io.prestosql.execution.buffer.PageBufferInfo
 
empty() - Static method in class io.prestosql.execution.buffer.PageCodecMarker.MarkerSet
 
empty() - Static method in class io.prestosql.sql.planner.iterative.Rule.Result
 
empty() - Static method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
empty() - Static method in class io.prestosql.sql.planner.TypeProvider
 
empty(Session) - Static method in class io.prestosql.server.protocol.QueryResultRows
 
EMPTY - Static variable in class io.prestosql.server.DynamicFilterService.DynamicFiltersStats
 
EMPTY_INDEX - Static variable in interface io.prestosql.operator.PagesSpatialIndex
 
EMPTY_STAGE_STATS - Static variable in class io.prestosql.execution.BasicStageStats
 
emptyApproxSet() - Static method in class io.prestosql.operator.scalar.HyperLogLogFunctions
 
emptyEventListenerManager() - Static method in class io.prestosql.testing.TestingEventListenerManager
 
EmptyMapConstructor - Class in io.prestosql.operator.scalar
 
EmptyMapConstructor(Type) - Constructor for class io.prestosql.operator.scalar.EmptyMapConstructor
 
emptyOrEquals(Optional<T>, T) - Static method in class io.prestosql.connector.system.jdbc.FilterUtil
 
emptyResults(String, long, boolean) - Static method in class io.prestosql.execution.buffer.BufferResult
 
EmptySplit - Class in io.prestosql.split
 
EmptySplit(CatalogName) - Constructor for class io.prestosql.split.EmptySplit
 
EmptySplitHandleResolver - Class in io.prestosql.split
 
EmptySplitHandleResolver() - Constructor for class io.prestosql.split.EmptySplitHandleResolver
 
ENABLE_DYNAMIC_FILTERING - Static variable in class io.prestosql.SystemSessionProperties
 
ENABLE_FORCED_EXCHANGE_BELOW_GROUP_ID - Static variable in class io.prestosql.SystemSessionProperties
 
ENABLE_INTERMEDIATE_AGGREGATIONS - Static variable in class io.prestosql.SystemSessionProperties
 
ENABLE_LARGE_DYNAMIC_FILTERS - Static variable in class io.prestosql.SystemSessionProperties
 
ENABLE_STATS_CALCULATOR - Static variable in class io.prestosql.SystemSessionProperties
 
ENABLED_ROLES - io.prestosql.connector.informationschema.InformationSchemaTable
 
encodeSyntheticAddress(int, int) - Static method in class io.prestosql.operator.SyntheticAddress
 
encrypt(byte[], int, int, byte[], int) - Method in class io.prestosql.spiller.AesSpillCipher
 
encrypt(byte[], int, int, byte[], int) - Method in interface io.prestosql.spiller.SpillCipher
Encrypts the contents of the input buffer into the destination buffer returning the number of bytes written into the destination buffer
ENCRYPTED - io.prestosql.execution.buffer.PageCodecMarker
 
encryptedMaxLength(int) - Method in class io.prestosql.spiller.AesSpillCipher
 
encryptedMaxLength(int) - Method in interface io.prestosql.spiller.SpillCipher
Calculates the maximum required buffer size to encrypt input data with the given length
end - Variable in class io.prestosql.util.LongBigArrayFIFOQueue
The end position in LongBigArrayFIFOQueue.array.
END - io.prestosql.operator.WindowOperator.FrameBoundKey.Type
 
endAnalysis() - Method in class io.prestosql.execution.QueryStateMachine
 
enforceSingleRow() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
EnforceSingleRowNode - Class in io.prestosql.sql.planner.plan
 
EnforceSingleRowNode(PlanNodeId, PlanNode) - Constructor for class io.prestosql.sql.planner.plan.EnforceSingleRowNode
 
EnforceSingleRowOperator - Class in io.prestosql.operator
 
EnforceSingleRowOperator(OperatorContext) - Constructor for class io.prestosql.operator.EnforceSingleRowOperator
 
EnforceSingleRowOperator.EnforceSingleRowOperatorFactory - Class in io.prestosql.operator
 
EnforceSingleRowOperatorFactory(int, PlanNodeId) - Constructor for class io.prestosql.operator.EnforceSingleRowOperator.EnforceSingleRowOperatorFactory
 
EnforceSingleRowStatsRule - Class in io.prestosql.cost
 
EnforceSingleRowStatsRule(StatsNormalizer) - Constructor for class io.prestosql.cost.EnforceSingleRowStatsRule
 
enqueue(int, List<SerializedPage>) - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
enqueue(int, List<SerializedPage>) - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
enqueue(int, List<SerializedPage>) - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
enqueue(int, List<SerializedPage>) - Method in interface io.prestosql.execution.buffer.OutputBuffer
Adds a split-up page to a specific partition.
enqueue(int, List<SerializedPage>) - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
enqueue(long) - Method in class io.prestosql.util.LongBigArrayFIFOQueue
 
enqueue(List<SerializedPage>) - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
enqueue(List<SerializedPage>) - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
enqueue(List<SerializedPage>) - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
enqueue(List<SerializedPage>) - Method in interface io.prestosql.execution.buffer.OutputBuffer
Adds a split-up page to an unpartitioned buffer.
enqueue(List<SerializedPage>) - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
enqueueFirst(long) - Method in class io.prestosql.util.LongBigArrayFIFOQueue
Enqueues a new element as the first element (in dequeuing order) of the queue.
enqueueSplit(PrioritizedSplitRunner) - Method in class io.prestosql.execution.executor.TaskHandle
 
enqueueSplits(TaskHandle, boolean, List<? extends SplitRunner>) - Method in class io.prestosql.execution.executor.TaskExecutor
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.histogram.GroupedHistogramState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
ensureCapacity(long) - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.GroupedMinMaxByNState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory.GroupedState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.GroupedHyperLogLogState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.GroupedState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.GroupedLongDecimalWithOverflowAndLongState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.GroupedMinMaxNState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.GroupedQuantileDigestAndPercentileState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.GroupedQuantileDigestState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.GroupedTDigestAndPercentileArrayState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.GroupedTDigestAndPercentileState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory.GroupedTDigestState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState
 
ensureCapacity(long) - Method in class io.prestosql.type.setdigest.SetDigestStateFactory.GroupedSetDigestState
 
entries - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
Cached set of entries.
ENTRY_BUFFER_SIZE - Static variable in class io.prestosql.operator.aggregation.DoubleHistogramAggregation
 
entrySet() - Method in class io.prestosql.sql.planner.plan.Assignments
 
epochMicrosToMillisWithRounding(long) - Static method in class io.prestosql.type.DateTimes
 
epochSecondToMicrosWithRounding(long, long) - Static method in class io.prestosql.type.DateTimes
 
equal(Block, int, Block, int) - Method in interface io.prestosql.type.BlockTypeOperators.BlockPositionEqual
 
EqualityInference - Class in io.prestosql.sql.planner
Makes equality based inferences to rewrite Expressions and generate equality sets in terms of specified symbol scopes
EqualityInference.EqualityPartition - Class in io.prestosql.sql.planner
 
EqualityPartition(Iterable<Expression>, Iterable<Expression>, Iterable<Expression>) - Constructor for class io.prestosql.sql.planner.EqualityInference.EqualityPartition
 
equalNullSafe(Block, int, Block, int) - Method in interface io.prestosql.type.BlockTypeOperators.BlockPositionEqual
 
equals(int, int, Block, int, int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
equals(long, long, long, long) - Method in interface io.prestosql.util.LongLong2LongOpenCustomBigHashMap.HashStrategy
Returns true if the given elements are equal with respect to this hash strategy.
equals(Object) - Method in class io.prestosql.connector.CatalogName
 
equals(Object) - Method in class io.prestosql.connector.informationschema.InformationSchemaColumnHandle
 
equals(Object) - Method in class io.prestosql.connector.informationschema.InformationSchemaTableHandle
 
equals(Object) - Method in class io.prestosql.connector.informationschema.InformationSchemaTransactionHandle
 
equals(Object) - Method in class io.prestosql.connector.system.GlobalSystemTransactionHandle
 
equals(Object) - Method in class io.prestosql.connector.system.SystemColumnHandle
 
equals(Object) - Method in class io.prestosql.connector.system.SystemTableHandle
 
equals(Object) - Method in class io.prestosql.connector.system.SystemTransactionHandle
 
equals(Object) - Method in class io.prestosql.cost.LocalCostEstimate
 
equals(Object) - Method in class io.prestosql.cost.PlanCostEstimate
 
equals(Object) - Method in class io.prestosql.cost.PlanNodeStatsEstimate
 
equals(Object) - Method in class io.prestosql.cost.StatisticRange
 
equals(Object) - Method in class io.prestosql.cost.SymbolStatsEstimate
 
equals(Object) - Method in class io.prestosql.execution.buffer.BufferInfo
 
equals(Object) - Method in class io.prestosql.execution.buffer.BufferResult
 
equals(Object) - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
equals(Object) - Method in class io.prestosql.execution.buffer.OutputBuffers
 
equals(Object) - Method in class io.prestosql.execution.buffer.OutputBuffers.OutputBufferId
 
equals(Object) - Method in class io.prestosql.execution.buffer.PageBufferInfo
 
equals(Object) - Method in class io.prestosql.execution.buffer.PageCodecMarker.MarkerSet
 
equals(Object) - Method in class io.prestosql.execution.Column
 
equals(Object) - Method in class io.prestosql.execution.Input
 
equals(Object) - Method in class io.prestosql.execution.Lifespan
 
equals(Object) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
equals(Object) - Method in class io.prestosql.execution.ScheduledSplit
 
equals(Object) - Method in class io.prestosql.execution.scheduler.NetworkLocation
 
equals(Object) - Method in class io.prestosql.execution.StageId
 
equals(Object) - Method in class io.prestosql.execution.TaskId
 
equals(Object) - Method in class io.prestosql.memory.ClusterMemoryPool
 
equals(Object) - Method in class io.prestosql.metadata.AllNodes
 
equals(Object) - Method in class io.prestosql.metadata.AnalyzeTableHandle
 
equals(Object) - Method in class io.prestosql.metadata.BoundSignature
 
equals(Object) - Method in class io.prestosql.metadata.FunctionArgumentDefinition
 
equals(Object) - Method in class io.prestosql.metadata.FunctionBinding
 
equals(Object) - Method in class io.prestosql.metadata.FunctionDependencies.FunctionKey
 
equals(Object) - Method in class io.prestosql.metadata.FunctionDependencies.OperatorKey
 
equals(Object) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.CastDependency
 
equals(Object) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependency
 
equals(Object) - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.OperatorDependency
 
equals(Object) - Method in class io.prestosql.metadata.FunctionId
 
equals(Object) - Method in class io.prestosql.metadata.IndexHandle
 
equals(Object) - Method in class io.prestosql.metadata.InsertTableHandle
 
equals(Object) - Method in class io.prestosql.metadata.InternalNode
 
equals(Object) - Method in class io.prestosql.metadata.LongVariableConstraint
 
equals(Object) - Method in class io.prestosql.metadata.NewTableLayout
 
equals(Object) - Method in class io.prestosql.metadata.OutputTableHandle
 
equals(Object) - Method in class io.prestosql.metadata.QualifiedObjectName
 
equals(Object) - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
equals(Object) - Method in class io.prestosql.metadata.ResolvedFunction
 
equals(Object) - Method in class io.prestosql.metadata.Signature
 
equals(Object) - Method in class io.prestosql.metadata.TableHandle
 
equals(Object) - Method in class io.prestosql.metadata.TableProperties.TablePartitioning
 
equals(Object) - Method in class io.prestosql.metadata.TypeVariableConstraint
 
equals(Object) - Method in class io.prestosql.operator.annotations.CastImplementationDependency
 
equals(Object) - Method in class io.prestosql.operator.annotations.FunctionImplementationDependency
 
equals(Object) - Method in class io.prestosql.operator.annotations.OperatorImplementationDependency
 
equals(Object) - Method in class io.prestosql.operator.annotations.ScalarImplementationDependency
 
equals(Object) - Method in class io.prestosql.operator.annotations.TypeImplementationDependency
 
equals(Object) - Method in class io.prestosql.operator.HttpPageBufferClient
 
equals(Object) - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.SpecializedSignature
 
equals(Object) - Method in class io.prestosql.operator.window.FrameInfo
 
equals(Object) - Method in class io.prestosql.operator.WindowOperator.FrameBoundKey
 
equals(Object) - Method in class io.prestosql.security.SecurityContext
 
equals(Object) - Method in class io.prestosql.server.DynamicFilterService.DynamicFilterDomainStats
 
equals(Object) - Method in class io.prestosql.server.DynamicFilterService.DynamicFiltersStats
 
equals(Object) - Method in class io.prestosql.server.security.InternalPrincipal
 
equals(Object) - Method in class io.prestosql.server.security.oauth2.OAuth2ServiceModule
 
equals(Object) - Method in class io.prestosql.sql.analyzer.Analysis.AccessControlInfo
 
equals(Object) - Method in class io.prestosql.sql.analyzer.CanonicalizationAware
 
equals(Object) - Method in class io.prestosql.sql.analyzer.FieldId
 
equals(Object) - Method in class io.prestosql.sql.analyzer.Output
 
equals(Object) - Method in class io.prestosql.sql.analyzer.RelationId
 
equals(Object) - Method in class io.prestosql.sql.DynamicFilters.Descriptor
 
equals(Object) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
equals(Object) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
equals(Object) - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
equals(Object) - Method in class io.prestosql.sql.planner.OrderingScheme
 
equals(Object) - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
equals(Object) - Method in class io.prestosql.sql.planner.Partitioning
 
equals(Object) - Method in class io.prestosql.sql.planner.PartitioningHandle
 
equals(Object) - Method in class io.prestosql.sql.planner.PartitioningScheme
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.Assignments
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.DynamicFilterId
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.IndexJoinNode.EquiJoinClause
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.JoinNode.EquiJoinClause
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.PlanFragmentId
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.PlanNodeId
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.WindowNode.Function
 
equals(Object) - Method in class io.prestosql.sql.planner.plan.WindowNode.Specification
 
equals(Object) - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint
 
equals(Object) - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.EstimatedStatsAndCost
 
equals(Object) - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedDomain
 
equals(Object) - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedMarker
 
equals(Object) - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedRange
 
equals(Object) - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan
 
equals(Object) - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan.TableColumnInfo
 
equals(Object) - Method in class io.prestosql.sql.planner.ScopeAware
 
equals(Object) - Method in class io.prestosql.sql.planner.SortExpressionContext
 
equals(Object) - Method in class io.prestosql.sql.planner.Symbol
 
equals(Object) - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
equals(Object) - Method in class io.prestosql.sql.relational.CallExpression
 
equals(Object) - Method in class io.prestosql.sql.relational.ConstantExpression
 
equals(Object) - Method in class io.prestosql.sql.relational.InputReferenceExpression
 
equals(Object) - Method in class io.prestosql.sql.relational.LambdaDefinitionExpression
 
equals(Object) - Method in class io.prestosql.sql.relational.RowExpression
 
equals(Object) - Method in class io.prestosql.sql.relational.SpecialForm
 
equals(Object) - Method in class io.prestosql.sql.relational.VariableReferenceExpression
 
equals(Object) - Method in class io.prestosql.sql.SqlPath
 
equals(Object) - Method in class io.prestosql.sql.SqlPathElement
 
equals(Object) - Method in class io.prestosql.testing.MaterializedResult
 
equals(Object) - Method in class io.prestosql.testing.MaterializedRow
 
equals(Object) - Method in class io.prestosql.testing.TestingAccessControlManager.TestingPrivilege
 
equals(Object) - Method in class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
equals(Object) - Method in class io.prestosql.testing.TestingTransactionHandle
 
equals(Object) - Method in class io.prestosql.transaction.TransactionId
 
equals(Object) - Method in class io.prestosql.type.ColorType
 
equals(Object) - Method in class io.prestosql.type.IntervalDayTimeType
 
equals(Object) - Method in class io.prestosql.type.IntervalYearMonthType
 
equals(Object) - Method in class io.prestosql.type.SqlIntervalDayTime
 
equals(Object) - Method in class io.prestosql.type.SqlIntervalYearMonth
 
EquiJoinClause(Symbol, Symbol) - Constructor for class io.prestosql.sql.planner.plan.IndexJoinNode.EquiJoinClause
 
EquiJoinClause(Symbol, Symbol) - Constructor for class io.prestosql.sql.planner.plan.JoinNode.EquiJoinClause
 
estimatedInMemorySize() - Method in class io.prestosql.operator.aggregation.ApproximateMostFrequentHistogram
 
estimatedInMemorySize() - Method in class io.prestosql.operator.aggregation.KeyValuePairs
 
estimatedInMemorySize() - Method in class io.prestosql.operator.aggregation.NumericHistogram
 
estimatedInMemorySize() - Method in class io.prestosql.type.setdigest.SetDigest
 
estimatedSerializedSize() - Method in class io.prestosql.type.setdigest.SetDigest
 
EstimatedStatsAndCost(double, double, double, double, double) - Constructor for class io.prestosql.sql.planner.planprinter.IoPlanPrinter.EstimatedStatsAndCost
 
estimateExpressionToExpressionComparison(PlanNodeStatsEstimate, SymbolStatsEstimate, Optional<Symbol>, SymbolStatsEstimate, Optional<Symbol>, ComparisonExpression.Operator) - Static method in class io.prestosql.cost.ComparisonStatsCalculator
 
estimateExpressionToLiteralComparison(PlanNodeStatsEstimate, SymbolStatsEstimate, Optional<Symbol>, OptionalDouble, ComparisonExpression.Operator) - Static method in class io.prestosql.cost.ComparisonStatsCalculator
 
estimateHashedTaskCount(Session) - Method in class io.prestosql.cost.TaskCountEstimator
 
estimateNumberOfHashCollisions(int, int) - Static method in class io.prestosql.util.HashCollisionsEstimator
 
estimateSourceDistributedTaskCount(Session) - Method in class io.prestosql.cost.TaskCountEstimator
 
evaluate() - Method in class io.prestosql.sql.planner.ExpressionInterpreter
 
evaluate(Metadata, ConnectorSession, Map<NodeRef<Expression>, Type>, Expression) - Static method in class io.prestosql.sql.planner.LiteralInterpreter
 
evaluate(SymbolResolver) - Method in class io.prestosql.sql.planner.ExpressionInterpreter
 
evaluate(Supplier<T>, T) - Static method in class io.prestosql.operator.scalar.TryFunction
 
evaluateConstantExpression(Expression, Type, Metadata, Session, AccessControl, Map<NodeRef<Parameter>, Expression>) - Static method in class io.prestosql.sql.planner.ExpressionInterpreter
 
evaluateFinal(int, BlockBuilder) - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
evaluateFinal(BooleanDistinctState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
evaluateFinal(BooleanDistinctState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
evaluateFinal(HyperLogLogState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
evaluateFinal(HyperLogLogState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateSetAggregation
 
evaluateFinal(HyperLogLogState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
evaluateFinal(QuantileDigestStateSerializer, QuantileDigestState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
evaluateFinal(BlockBuilder) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
evaluateIntermediate(int, BlockBuilder) - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
evaluateIntermediate(BlockBuilder) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
evaluatePropertyValue(Expression, Type, Session, Metadata, AccessControl, Map<NodeRef<Parameter>, Expression>) - Static method in class io.prestosql.metadata.SessionPropertyManager
 
EvaluateZeroSample - Class in io.prestosql.sql.planner.iterative.rule
Replaces 0% sample node with empty values node.
EvaluateZeroSample() - Constructor for class io.prestosql.sql.planner.iterative.rule.EvaluateZeroSample
 
EventListenerConfig - Class in io.prestosql.eventlistener
 
EventListenerConfig() - Constructor for class io.prestosql.eventlistener.EventListenerConfig
 
EventListenerManager - Class in io.prestosql.eventlistener
 
EventListenerManager(EventListenerConfig) - Constructor for class io.prestosql.eventlistener.EventListenerManager
 
EventListenerModule - Class in io.prestosql.eventlistener
 
EventListenerModule() - Constructor for class io.prestosql.eventlistener.EventListenerModule
 
EXACT - io.prestosql.metadata.SignatureBinder.RelationshipType
 
exactIntersectionCardinality(SetDigest, SetDigest) - Static method in class io.prestosql.type.setdigest.SetDigest
 
exactlyPartitionedOn(Collection<Symbol>) - Static method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
ExceededCpuLimitException - Exception in io.prestosql
 
ExceededCpuLimitException(Duration) - Constructor for exception io.prestosql.ExceededCpuLimitException
 
exceededGlobalTotalLimit(DataSize) - Static method in exception io.prestosql.ExceededMemoryLimitException
 
exceededGlobalUserLimit(DataSize) - Static method in exception io.prestosql.ExceededMemoryLimitException
 
exceededLocalLimit(DataSize) - Static method in exception io.prestosql.ExceededSpillLimitException
 
exceededLocalTotalMemoryLimit(DataSize, String) - Static method in exception io.prestosql.ExceededMemoryLimitException
 
exceededLocalUserMemoryLimit(DataSize, String) - Static method in exception io.prestosql.ExceededMemoryLimitException
 
ExceededMemoryLimitException - Exception in io.prestosql
 
exceededPerQueryLocalLimit(DataSize) - Static method in exception io.prestosql.ExceededSpillLimitException
 
ExceededScanLimitException - Exception in io.prestosql
 
ExceededScanLimitException(DataSize) - Constructor for exception io.prestosql.ExceededScanLimitException
 
ExceededSpillLimitException - Exception in io.prestosql
 
except() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
except(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayExceptFunction
 
Except() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Except
 
ExceptNode - Class in io.prestosql.sql.planner.plan
 
ExceptNode(PlanNodeId, List<PlanNode>, ListMultimap<Symbol, Symbol>, List<Symbol>, boolean) - Constructor for class io.prestosql.sql.planner.plan.ExceptNode
 
exchange() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
Exchange() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Exchange
 
EXCHANGE_COMPRESSION - Static variable in class io.prestosql.SystemSessionProperties
 
ExchangeClient - Class in io.prestosql.operator
 
ExchangeClient(String, FeaturesConfig.DataIntegrityVerification, DataSize, DataSize, int, Duration, boolean, HttpClient, ScheduledExecutorService, LocalMemoryContext, Executor) - Constructor for class io.prestosql.operator.ExchangeClient
 
ExchangeClientConfig - Class in io.prestosql.operator
 
ExchangeClientConfig() - Constructor for class io.prestosql.operator.ExchangeClientConfig
 
ExchangeClientFactory - Class in io.prestosql.operator
 
ExchangeClientFactory(NodeInfo, FeaturesConfig.DataIntegrityVerification, DataSize, DataSize, int, Duration, boolean, int, HttpClient, ScheduledExecutorService) - Constructor for class io.prestosql.operator.ExchangeClientFactory
 
ExchangeClientFactory(NodeInfo, FeaturesConfig, ExchangeClientConfig, HttpClient, ScheduledExecutorService) - Constructor for class io.prestosql.operator.ExchangeClientFactory
 
ExchangeClientStatus - Class in io.prestosql.operator
 
ExchangeClientStatus(long, long, long, long, int, boolean, List<PageBufferClientStatus>) - Constructor for class io.prestosql.operator.ExchangeClientStatus
 
ExchangeClientSupplier - Interface in io.prestosql.operator
 
ExchangeExecutionMBean - Class in io.prestosql.server
 
ExchangeExecutionMBean(ScheduledExecutorService) - Constructor for class io.prestosql.server.ExchangeExecutionMBean
 
ExchangeNode - Class in io.prestosql.sql.planner.plan
 
ExchangeNode(PlanNodeId, ExchangeNode.Type, ExchangeNode.Scope, PartitioningScheme, List<PlanNode>, List<List<Symbol>>, Optional<OrderingScheme>) - Constructor for class io.prestosql.sql.planner.plan.ExchangeNode
 
ExchangeNode.Scope - Enum in io.prestosql.sql.planner.plan
 
ExchangeNode.Type - Enum in io.prestosql.sql.planner.plan
 
ExchangeOperator - Class in io.prestosql.operator
 
ExchangeOperator(OperatorContext, PlanNodeId, PagesSerde, ExchangeClient) - Constructor for class io.prestosql.operator.ExchangeOperator
 
ExchangeOperator.ExchangeOperatorFactory - Class in io.prestosql.operator
 
ExchangeOperatorFactory(int, PlanNodeId, ExchangeClientSupplier, PagesSerdeFactory) - Constructor for class io.prestosql.operator.ExchangeOperator.ExchangeOperatorFactory
 
ExchangeStatsRule - Class in io.prestosql.cost
 
ExchangeStatsRule(StatsNormalizer) - Constructor for class io.prestosql.cost.ExchangeStatsRule
 
execute(Session, String) - Method in class io.prestosql.testing.LocalQueryRunner
 
execute(Session, String) - Method in interface io.prestosql.testing.QueryRunner
 
execute(Session, Consumer<Session>) - Method in class io.prestosql.transaction.TransactionBuilder
 
execute(Session, Function<Session, T>) - Method in class io.prestosql.transaction.TransactionBuilder
 
execute(AddColumn, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.AddColumnTask
 
execute(Call, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.CallTask
 
execute(Comment, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.CommentTask
 
execute(Commit, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.CommitTask
 
execute(CreateMaterializedView, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.CreateMaterializedViewTask
 
execute(CreateRole, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.CreateRoleTask
 
execute(CreateSchema, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.CreateSchemaTask
 
execute(CreateTable, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.CreateTableTask
 
execute(CreateView, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.CreateViewTask
 
execute(Deallocate, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.DeallocateTask
 
execute(DropColumn, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.DropColumnTask
 
execute(DropMaterializedView, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.DropMaterializedViewTask
 
execute(DropRole, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.DropRoleTask
 
execute(DropSchema, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.DropSchemaTask
 
execute(DropTable, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.DropTableTask
 
execute(DropView, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.DropViewTask
 
execute(Grant, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.GrantTask
 
execute(GrantRoles, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.GrantRolesTask
 
execute(Prepare, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.PrepareTask
 
execute(RenameColumn, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.RenameColumnTask
 
execute(RenameSchema, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.RenameSchemaTask
 
execute(RenameTable, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.RenameTableTask
 
execute(RenameView, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.RenameViewTask
 
execute(ResetSession, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.ResetSessionTask
 
execute(Revoke, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.RevokeTask
 
execute(RevokeRoles, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.RevokeRolesTask
 
execute(Rollback, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.RollbackTask
 
execute(SetPath, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.SetPathTask
 
execute(SetRole, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.SetRoleTask
 
execute(SetSchemaAuthorization, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.SetSchemaAuthorizationTask
 
execute(SetSession, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.SetSessionTask
 
execute(SetTableAuthorization, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.SetTableAuthorizationTask
 
execute(SetViewAuthorization, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.SetViewAuthorizationTask
 
execute(StartTransaction, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.StartTransactionTask
 
execute(Use, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.UseTask
 
execute(Runnable) - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
execute(String) - Method in class io.prestosql.testing.LocalQueryRunner
 
execute(String) - Method in interface io.prestosql.testing.QueryRunner
 
execute(Consumer<TransactionId>) - Method in class io.prestosql.transaction.TransactionBuilder
 
execute(Function<TransactionId, T>) - Method in class io.prestosql.transaction.TransactionBuilder
 
execute(T, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in interface io.prestosql.execution.DataDefinitionTask
 
EXECUTE_FUNCTION - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
EXECUTE_QUERY - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
executeDelete(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Execute delete in connector
executeDelete(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
executeWithPlan(Session, String, WarningCollector) - Method in class io.prestosql.testing.LocalQueryRunner
 
executeWithPlan(Session, String, WarningCollector) - Method in interface io.prestosql.testing.QueryRunner
 
EXECUTING_QUERY - io.prestosql.server.protocol.Slug.Context
 
ExecutingStatementResource - Class in io.prestosql.server.protocol
 
ExecutingStatementResource(QueryManager, ExchangeClientSupplier, BlockEncodingSerde, BoundedExecutor, ScheduledExecutorService, ServerConfig) - Constructor for class io.prestosql.server.protocol.ExecutingStatementResource
 
EXECUTION_POLICY - Static variable in class io.prestosql.SystemSessionProperties
 
ExecutionFailureInfo - Class in io.prestosql.execution
 
ExecutionFailureInfo(String, String, ExecutionFailureInfo, List<ExecutionFailureInfo>, List<String>, ErrorLocation, ErrorCode, HostAddress) - Constructor for class io.prestosql.execution.ExecutionFailureInfo
 
ExecutionPolicy - Interface in io.prestosql.execution.scheduler
 
ExecutionSchedule - Interface in io.prestosql.execution.scheduler
 
ExecutorCleanup(ExecutorService, ScheduledExecutorService, ExecutorService, ScheduledExecutorService, ExecutorService, ScheduledExecutorService) - Constructor for class io.prestosql.server.CoordinatorModule.ExecutorCleanup
 
ExecutorCleanup(ScheduledExecutorService, ExecutorService, ScheduledExecutorService) - Constructor for class io.prestosql.server.ServerMainModule.ExecutorCleanup
 
exp(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
EXPECTED_SIZE_FOR_HASHING - Static variable in class io.prestosql.operator.aggregation.histogram.Histogram
 
expectedValueSize(Type, int) - Static method in class io.prestosql.type.TypeUtils
 
expireQuery(QueryId) - Method in class io.prestosql.execution.QueryTracker
Query is finished and expiration should begin.
explain(CreateMaterializedView, List<Expression>) - Method in class io.prestosql.execution.CreateMaterializedViewTask
 
explain(CreateSchema, List<Expression>) - Method in class io.prestosql.execution.CreateSchemaTask
 
explain(CreateTable, List<Expression>) - Method in class io.prestosql.execution.CreateTableTask
 
explain(CreateView, List<Expression>) - Method in class io.prestosql.execution.CreateViewTask
 
explain(DropSchema, List<Expression>) - Method in class io.prestosql.execution.DropSchemaTask
 
explain(Prepare, List<Expression>) - Method in class io.prestosql.execution.PrepareTask
 
explain(T, List<Expression>) - Method in interface io.prestosql.execution.DataDefinitionTask
 
explainAnalyze() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
ExplainAnalyzeContext - Class in io.prestosql.execution
 
ExplainAnalyzeContext(QueryPerformanceFetcher) - Constructor for class io.prestosql.execution.ExplainAnalyzeContext
 
ExplainAnalyzeNode - Class in io.prestosql.sql.planner.plan
 
ExplainAnalyzeNode(PlanNodeId, PlanNode, Symbol, List<Symbol>, boolean) - Constructor for class io.prestosql.sql.planner.plan.ExplainAnalyzeNode
 
ExplainAnalyzeOperator - Class in io.prestosql.operator
 
ExplainAnalyzeOperator(OperatorContext, QueryPerformanceFetcher, Metadata, boolean) - Constructor for class io.prestosql.operator.ExplainAnalyzeOperator
 
ExplainAnalyzeOperator.ExplainAnalyzeOperatorFactory - Class in io.prestosql.operator
 
ExplainAnalyzeOperatorFactory(int, PlanNodeId, QueryPerformanceFetcher, Metadata, boolean) - Constructor for class io.prestosql.operator.ExplainAnalyzeOperator.ExplainAnalyzeOperatorFactory
 
EXPLICIT_COERCION_FROM - io.prestosql.metadata.SignatureBinder.RelationshipType
 
EXPLICIT_COERCION_TO - io.prestosql.metadata.SignatureBinder.RelationshipType
 
expression() - Method in annotation type io.prestosql.type.Constraint
 
ExpressionAnalysis - Class in io.prestosql.sql.analyzer
 
ExpressionAnalysis(Map<NodeRef<Expression>, Type>, Map<NodeRef<Expression>, Type>, Set<NodeRef<InPredicate>>, Set<NodeRef<SubqueryExpression>>, Set<NodeRef<ExistsPredicate>>, Map<NodeRef<Expression>, ResolvedField>, Set<NodeRef<Expression>>, Set<NodeRef<QuantifiedComparisonExpression>>, Set<NodeRef<FunctionCall>>) - Constructor for class io.prestosql.sql.analyzer.ExpressionAnalysis
 
ExpressionAnalyzer - Class in io.prestosql.sql.analyzer
 
ExpressionAnalyzer(Metadata, AccessControl, Function<Node, StatementAnalyzer>, Session, TypeProvider, Map<NodeRef<Parameter>, Expression>, WarningCollector, boolean, CorrelationSupport) - Constructor for class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
expressionBinding(Expression) - Static method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
ExpressionCompiler - Class in io.prestosql.sql.gen
 
ExpressionCompiler(Metadata, PageFunctionCompiler) - Constructor for class io.prestosql.sql.gen.ExpressionCompiler
 
ExpressionDeserializer(SqlParser) - Constructor for class io.prestosql.server.ExpressionSerialization.ExpressionDeserializer
 
ExpressionEquivalence - Class in io.prestosql.sql.planner.optimizations
 
ExpressionEquivalence(Metadata, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.optimizations.ExpressionEquivalence
 
ExpressionExtractor - Class in io.prestosql.sql.planner
 
expressionInterpreter(Expression, Metadata, Session, Map<NodeRef<Expression>, Type>) - Static method in class io.prestosql.sql.planner.ExpressionInterpreter
 
ExpressionInterpreter - Class in io.prestosql.sql.planner
 
ExpressionNodeInliner - Class in io.prestosql.sql.planner
 
ExpressionNodeInliner(Map<? extends Expression, ? extends Expression>) - Constructor for class io.prestosql.sql.planner.ExpressionNodeInliner
 
expressionOptimizer(Expression, Metadata, Session, Map<NodeRef<Expression>, Type>) - Static method in class io.prestosql.sql.planner.ExpressionInterpreter
 
ExpressionOptimizer - Class in io.prestosql.sql.relational.optimizer
 
ExpressionOptimizer(Metadata, Session) - Constructor for class io.prestosql.sql.relational.optimizer.ExpressionOptimizer
 
expressionOrNullSymbols(Predicate<Symbol>...) - Static method in class io.prestosql.sql.ExpressionUtils
 
ExpressionProfiler - Class in io.prestosql.sql.gen
 
ExpressionProfiler() - Constructor for class io.prestosql.sql.gen.ExpressionProfiler
 
ExpressionProfiler(Ticker, Duration) - Constructor for class io.prestosql.sql.gen.ExpressionProfiler
 
ExpressionRewriteRuleSet - Class in io.prestosql.sql.planner.iterative.rule
 
ExpressionRewriteRuleSet(ExpressionRewriteRuleSet.ExpressionRewriter) - Constructor for class io.prestosql.sql.planner.iterative.rule.ExpressionRewriteRuleSet
 
ExpressionRewriteRuleSet.ExpressionRewriter - Interface in io.prestosql.sql.planner.iterative.rule
 
Expressions - Class in io.prestosql.sql.relational
 
ExpressionSerialization - Class in io.prestosql.server
 
ExpressionSerialization.ExpressionDeserializer - Class in io.prestosql.server
 
ExpressionSerialization.ExpressionSerializer - Class in io.prestosql.server
 
ExpressionSerializer() - Constructor for class io.prestosql.server.ExpressionSerialization.ExpressionSerializer
 
ExpressionSymbolInliner - Class in io.prestosql.sql.planner
 
ExpressionTreeUtils - Class in io.prestosql.sql.analyzer
 
ExpressionUtils - Class in io.prestosql.sql
 
extract() - Method in class io.prestosql.sql.planner.iterative.Memo
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractDay
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractDayOfWeek
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractDayOfYear
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractHour
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractMillisecond
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractMinute
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractMonth
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractQuarter
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractSecond
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractWeekOfYear
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractYear
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractYearOfWeek
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractDay
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractDayOfWeek
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractDayOfYear
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractHour
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractMillisecond
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractMinute
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractMonth
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractQuarter
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractSecond
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractWeekOfYear
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractYear
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractYearOfWeek
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimeZoneHour
 
extract(long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimeZoneMinute
 
extract(long) - Static method in class io.prestosql.operator.scalar.timetz.ExtractHour
 
extract(long) - Static method in class io.prestosql.operator.scalar.timetz.ExtractMillisecond
 
extract(long) - Static method in class io.prestosql.operator.scalar.timetz.ExtractMinute
 
extract(long) - Static method in class io.prestosql.operator.scalar.timetz.ExtractSecond
 
extract(long) - Static method in class io.prestosql.operator.scalar.timetz.TimeZoneHour
 
extract(long) - Static method in class io.prestosql.operator.scalar.timetz.TimeZoneMinute
 
extract(JsonParser) - Method in interface io.prestosql.operator.scalar.JsonExtract.JsonExtractor
Executes the extraction on the existing content of the JsonParser and outputs the match.
extract(JsonParser) - Method in class io.prestosql.operator.scalar.JsonExtract.JsonSizeExtractor
 
extract(JsonParser) - Method in class io.prestosql.operator.scalar.JsonExtract.JsonValueJsonExtractor
 
extract(JsonParser) - Method in class io.prestosql.operator.scalar.JsonExtract.ObjectFieldJsonExtractor
 
extract(JsonParser) - Method in class io.prestosql.operator.scalar.JsonExtract.ScalarValueJsonExtractor
 
extract(Slice, long) - Method in class io.prestosql.type.Re2JRegexp
 
extract(Slice, JsonExtract.JsonExtractor<T>) - Static method in class io.prestosql.operator.scalar.JsonExtract
 
extract(Session, PlanNode, TypeProvider, TypeAnalyzer) - Method in class io.prestosql.sql.planner.EffectivePredicateExtractor
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractDay
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractDayOfWeek
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractDayOfYear
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractHour
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractMillisecond
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractMinute
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractMonth
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractQuarter
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractSecond
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractWeekOfYear
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractYear
 
extract(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ExtractYearOfWeek
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractDay
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractDayOfWeek
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractDayOfYear
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractHour
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractMillisecond
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractMinute
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractMonth
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractQuarter
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractSecond
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractWeekOfYear
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractYear
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ExtractYearOfWeek
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimeZoneHour
 
extract(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimeZoneMinute
 
extract(LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.ExtractHour
 
extract(LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.ExtractMillisecond
 
extract(LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.ExtractMinute
 
extract(LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.ExtractSecond
 
extract(LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.TimeZoneHour
 
extract(LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.TimeZoneMinute
 
extract(Expression) - Static method in class io.prestosql.sql.planner.SubExpressionExtractor
 
extractAll(Slice, long) - Method in class io.prestosql.type.Re2JRegexp
 
extractAll(AggregationNode.Aggregation) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractAll(WindowNode.Function) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractAll(Expression) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractAuthorizedIdentity(Optional<Identity>, MultivaluedMap<String, String>, AccessControl, GroupProvider) - Static method in class io.prestosql.server.HttpRequestSessionContext
 
extractAuthorizedIdentity(HttpServletRequest, HttpHeaders, AccessControl, GroupProvider) - Static method in class io.prestosql.server.HttpRequestSessionContext
 
extractBasicAuthCredentials(String) - Static method in class io.prestosql.server.security.BasicAuthCredentials
 
extractBasicAuthCredentials(ContainerRequestContext) - Static method in class io.prestosql.server.security.BasicAuthCredentials
 
extractCardinality(PlanNode) - Static method in class io.prestosql.sql.planner.optimizations.QueryCardinalityUtil
 
extractCardinality(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.optimizations.QueryCardinalityUtil
 
extractCommonPredicates(Metadata, Expression) - Static method in class io.prestosql.sql.planner.iterative.rule.ExtractCommonPredicatesExpressionRewriter
 
ExtractCommonPredicatesExpressionRewriter - Class in io.prestosql.sql.planner.iterative.rule
 
extractConjuncts(Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
ExtractDay - Class in io.prestosql.operator.scalar.timestamp
 
ExtractDay - Class in io.prestosql.operator.scalar.timestamptz
 
ExtractDayOfWeek - Class in io.prestosql.operator.scalar.timestamp
 
ExtractDayOfWeek - Class in io.prestosql.operator.scalar.timestamptz
 
ExtractDayOfYear - Class in io.prestosql.operator.scalar.timestamp
 
ExtractDayOfYear - Class in io.prestosql.operator.scalar.timestamptz
 
ExtractDereferencesFromFilterAboveScan - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
ExtractDereferencesFromFilterAboveScan(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.ExtractDereferencesFromFilterAboveScan
 
extractDisjuncts(Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
extractDynamicFilters(Expression) - Static method in class io.prestosql.sql.DynamicFilters
 
extractExpressions(PlanNode) - Static method in class io.prestosql.sql.planner.ExpressionExtractor
 
extractExpressions(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.ExpressionExtractor
 
extractExpressions(Iterable<? extends Node>, Class<T>) - Static method in class io.prestosql.sql.analyzer.ExpressionTreeUtils
 
extractExpressionsNonRecursive(PlanNode) - Static method in class io.prestosql.sql.planner.ExpressionExtractor
 
extractFunctionName(QualifiedName) - Static method in class io.prestosql.metadata.ResolvedFunction
 
extractFunctions(Class<?>) - Static method in class io.prestosql.metadata.FunctionExtractor
 
extractFunctions(Collection<Class<?>>) - Static method in class io.prestosql.metadata.FunctionExtractor
 
ExtractHour - Class in io.prestosql.operator.scalar.timestamp
 
ExtractHour - Class in io.prestosql.operator.scalar.timestamptz
 
ExtractHour - Class in io.prestosql.operator.scalar.timetz
 
extractInputs(SubPlan) - Method in class io.prestosql.sql.planner.InputExtractor
 
ExtractionResult(TupleDomain<Symbol>, Expression) - Constructor for class io.prestosql.sql.planner.DomainTranslator.ExtractionResult
 
extractLambdaExpressions(RowExpression) - Static method in class io.prestosql.sql.gen.LambdaExpressionExtractor
 
extractLeadingConstants(List<? extends LocalProperty<T>>) - Static method in class io.prestosql.sql.planner.optimizations.LocalProperties
 
extractLocation(Node) - Static method in class io.prestosql.sql.analyzer.ExpressionTreeUtils
 
ExtractMillisecond - Class in io.prestosql.operator.scalar.timestamp
 
ExtractMillisecond - Class in io.prestosql.operator.scalar.timestamptz
 
ExtractMillisecond - Class in io.prestosql.operator.scalar.timetz
 
ExtractMinute - Class in io.prestosql.operator.scalar.timestamp
 
ExtractMinute - Class in io.prestosql.operator.scalar.timestamptz
 
ExtractMinute - Class in io.prestosql.operator.scalar.timetz
 
ExtractMonth - Class in io.prestosql.operator.scalar.timestamp
 
ExtractMonth - Class in io.prestosql.operator.scalar.timestamptz
 
extractNames(Expression, Set<NodeRef<Expression>>) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractNamesNoSubqueries(Expression, Set<NodeRef<Expression>>) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractOutputSymbols(PlanNode) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractOutputSymbols(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractPartialTranslations(Expression, Session, TypeAnalyzer, TypeProvider) - Static method in class io.prestosql.sql.planner.PartialTranslator
Produces ConnectorExpression translations for disjoint components in the {@param inputExpression} in a top-down manner.
extractPredicates(LogicalBinaryExpression) - Static method in class io.prestosql.sql.ExpressionUtils
 
extractPredicates(LogicalBinaryExpression.Operator, Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
ExtractQuarter - Class in io.prestosql.operator.scalar.timestamp
 
ExtractQuarter - Class in io.prestosql.operator.scalar.timestamptz
 
ExtractResult(List<Expression>, List<DynamicFilters.Descriptor>) - Constructor for class io.prestosql.sql.DynamicFilters.ExtractResult
 
extractRowId() - Method in interface io.prestosql.operator.GroupedTopNRowNumberAccumulator.RowReference
Extract a stable row ID that can be used to reference this row at a future point.
ExtractSecond - Class in io.prestosql.operator.scalar.timestamp
 
ExtractSecond - Class in io.prestosql.operator.scalar.timestamptz
 
ExtractSecond - Class in io.prestosql.operator.scalar.timetz
 
extractSortExpression(Metadata, Set<Symbol>, Expression) - Static method in class io.prestosql.sql.planner.SortExpressionExtractor
 
extractSourceSymbols(List<DynamicFilters.Descriptor>) - Static method in class io.prestosql.sql.DynamicFilters
 
ExtractSpatialInnerJoin(Metadata, SplitManager, PageSourceManager, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins.ExtractSpatialInnerJoin
 
ExtractSpatialJoins - Class in io.prestosql.sql.planner.iterative.rule
Applies to broadcast spatial joins, inner and left, expressed via ST_Contains, ST_Intersects and ST_Distance functions.
ExtractSpatialJoins(Metadata, SplitManager, PageSourceManager, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins
 
ExtractSpatialJoins.ExtractSpatialInnerJoin - Class in io.prestosql.sql.planner.iterative.rule
 
ExtractSpatialJoins.ExtractSpatialLeftJoin - Class in io.prestosql.sql.planner.iterative.rule
 
ExtractSpatialLeftJoin(Metadata, SplitManager, PageSourceManager, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins.ExtractSpatialLeftJoin
 
extractSupportedSpatialComparisons(Expression) - Static method in class io.prestosql.util.SpatialJoinUtils
Returns a subset of conjuncts matching one the following shapes: - ST_Distance(...) <= ...
extractSupportedSpatialFunctions(Expression) - Static method in class io.prestosql.util.SpatialJoinUtils
Returns a subset of conjuncts matching one of the following shapes: - ST_Contains(...) - ST_Within(...) - ST_Intersects(...)
extractTimePrecision(String) - Static method in class io.prestosql.type.DateTimes
 
extractTimestampPrecision(String) - Static method in class io.prestosql.type.DateTimes
 
extractUnique(AggregationNode.Aggregation) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractUnique(PlanNode) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractUnique(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractUnique(WindowNode.Function) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractUnique(Expression) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractUnique(Iterable<? extends Expression>) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractUniqueNonRecursive(PlanNode) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractVariables(ConnectorExpression) - Static method in class io.prestosql.sql.planner.ConnectorExpressions
 
ExtractWeekOfYear - Class in io.prestosql.operator.scalar.timestamp
 
ExtractWeekOfYear - Class in io.prestosql.operator.scalar.timestamptz
 
ExtractYear - Class in io.prestosql.operator.scalar.timestamp
 
ExtractYear - Class in io.prestosql.operator.scalar.timestamptz
 
ExtractYearOfWeek - Class in io.prestosql.operator.scalar.timestamp
 
ExtractYearOfWeek - Class in io.prestosql.operator.scalar.timestamptz
 
extractZoneOffsetMinutes(long) - Static method in class io.prestosql.util.DateTimeZoneIndex
 
extractZoneOffsetMinutes(long, short) - Static method in class io.prestosql.util.DateTimeZoneIndex
 

F

f - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
The acceptable load factor.
f - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
The acceptable load factor.
FactoryBuilder(int, PagesHashStrategy, LongArrayList) - Constructor for class io.prestosql.operator.SortedPositionLinks.FactoryBuilder
 
fail() - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
fail() - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
fail() - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
fail() - Method in interface io.prestosql.execution.buffer.OutputBuffer
Fail the buffer, discarding all pages, but blocking readers.
fail() - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
fail(long, Slice) - Static method in class io.prestosql.operator.scalar.FailureFunction
 
fail(Slice) - Static method in class io.prestosql.operator.scalar.FailureFunction
 
fail(TransactionId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
fail(TransactionId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
fail(TransactionId) - Method in interface io.prestosql.transaction.TransactionManager
 
fail(Throwable) - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
fail(Throwable) - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
fail(Throwable) - Method in class io.prestosql.execution.DataDefinitionExecution
 
fail(Throwable) - Method in interface io.prestosql.execution.ManagedQueryExecution
 
fail(Throwable) - Method in interface io.prestosql.execution.QueryTracker.TrackedQuery
 
fail(Throwable) - Method in class io.prestosql.execution.SqlQueryExecution
 
failAbandonedTasks() - Method in class io.prestosql.execution.SqlTaskManager
 
failed(ExecutionFailureInfo, Duration, Duration) - Static method in class io.prestosql.dispatcher.DispatchInfo
 
failed(Throwable) - Method in class io.prestosql.execution.SqlTask
 
failed(Throwable) - Method in class io.prestosql.execution.TaskStateMachine
 
failed(Throwable) - Method in class io.prestosql.operator.DriverContext
 
failed(Throwable) - Method in class io.prestosql.operator.PipelineContext
 
failed(Throwable) - Method in class io.prestosql.operator.TaskContext
 
failed(Throwable) - Method in interface io.prestosql.server.remotetask.SimpleHttpResponseCallback
 
failed(Throwable) - Method in class io.prestosql.server.remotetask.TaskInfoFetcher
 
FAILED - io.prestosql.execution.buffer.BufferState
Buffer has failed.
FAILED - io.prestosql.execution.QueryState
Query execution failed.
FAILED - io.prestosql.execution.StageState
Stage execution failed.
FAILED - io.prestosql.execution.TaskState
Task execution failed.
FailedDispatchQuery - Class in io.prestosql.dispatcher
 
FailedDispatchQuery(Session, String, Optional<String>, URI, Optional<ResourceGroupId>, Throwable, Executor) - Constructor for class io.prestosql.dispatcher.FailedDispatchQuery
 
FailedDispatchQueryFactory - Class in io.prestosql.dispatcher
 
FailedDispatchQueryFactory(QueryMonitor, LocationFactory, DispatchExecutor) - Constructor for class io.prestosql.dispatcher.FailedDispatchQueryFactory
 
failQuery(QueryId, Throwable) - Method in class io.prestosql.dispatcher.DispatchManager
 
failQuery(QueryId, Throwable) - Method in interface io.prestosql.execution.QueryManager
Attempts to fail the query for the specified reason.
failQuery(QueryId, Throwable) - Method in class io.prestosql.execution.SqlQueryManager
 
failure() - Method in class io.prestosql.server.remotetask.Backoff
 
Failure - Exception in io.prestosql.execution
 
FailureDetector - Interface in io.prestosql.failuredetector
 
FailureDetector.State - Enum in io.prestosql.failuredetector
 
FailureDetectorConfig - Class in io.prestosql.failuredetector
 
FailureDetectorConfig() - Constructor for class io.prestosql.failuredetector.FailureDetectorConfig
 
FailureDetectorModule - Class in io.prestosql.failuredetector
 
FailureDetectorModule() - Constructor for class io.prestosql.failuredetector.FailureDetectorModule
 
FailureFunction - Class in io.prestosql.operator.scalar
 
Failures - Class in io.prestosql.util
 
failWith(TaskStatus, TaskState, List<ExecutionFailureInfo>) - Static method in class io.prestosql.execution.TaskStatus
 
failWithException(Slice) - Static method in class io.prestosql.operator.scalar.FailureFunction
 
FALSE_VALUE - Static variable in interface io.prestosql.operator.aggregation.state.TriStateBooleanState
 
FastutilSetHelper - Class in io.prestosql.util
 
fatal(Throwable) - Method in interface io.prestosql.server.remotetask.SimpleHttpResponseCallback
 
fatal(Throwable) - Method in class io.prestosql.server.remotetask.TaskInfoFetcher
 
FeaturesConfig - Class in io.prestosql.sql.analyzer
 
FeaturesConfig() - Constructor for class io.prestosql.sql.analyzer.FeaturesConfig
 
FeaturesConfig.DataIntegrityVerification - Enum in io.prestosql.sql.analyzer
 
FeaturesConfig.JoinDistributionType - Enum in io.prestosql.sql.analyzer
 
FeaturesConfig.JoinReorderingStrategy - Enum in io.prestosql.sql.analyzer
 
field(int, Type) - Static method in class io.prestosql.sql.relational.Expressions
 
field(Class<?>, String) - Static method in class io.prestosql.util.Reflection
 
Field - Class in io.prestosql.sql.analyzer
 
Field(Optional<QualifiedName>, Optional<String>, Type, boolean, Optional<QualifiedObjectName>, Optional<String>, boolean) - Constructor for class io.prestosql.sql.analyzer.Field
 
FieldId - Class in io.prestosql.sql.analyzer
 
FieldId(RelationId, int) - Constructor for class io.prestosql.sql.analyzer.FieldId
 
FieldSetFilteringRecordSet - Class in io.prestosql.operator.index
Only retains rows that have identical values for each respective fieldSet.
FieldSetFilteringRecordSet(TypeOperators, RecordSet, List<Set<Integer>>) - Constructor for class io.prestosql.operator.index.FieldSetFilteringRecordSet
 
FILE - io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig.TopologyType
 
FileBasedNetworkTopology - Class in io.prestosql.execution.scheduler
 
FileBasedNetworkTopology(TopologyFileConfig) - Constructor for class io.prestosql.execution.scheduler.FileBasedNetworkTopology
 
FileSigningKeyResolver - Class in io.prestosql.server.security.jwt
 
FileSigningKeyResolver(JwtAuthenticatorConfig) - Constructor for class io.prestosql.server.security.jwt.FileSigningKeyResolver
 
FileSigningKeyResolver(String) - Constructor for class io.prestosql.server.security.jwt.FileSigningKeyResolver
 
FileSingleStreamSpiller - Class in io.prestosql.spiller
 
FileSingleStreamSpiller(PagesSerde, ListeningExecutorService, Path, SpillerStats, SpillContext, LocalMemoryContext, Optional<SpillCipher>, Runnable) - Constructor for class io.prestosql.spiller.FileSingleStreamSpiller
 
FileSingleStreamSpillerFactory - Class in io.prestosql.spiller
 
FileSingleStreamSpillerFactory(ListeningExecutorService, BlockEncodingSerde, SpillerStats, List<Path>, double, boolean, boolean) - Constructor for class io.prestosql.spiller.FileSingleStreamSpillerFactory
 
FileSingleStreamSpillerFactory(Metadata, SpillerStats, FeaturesConfig, NodeSpillConfig) - Constructor for class io.prestosql.spiller.FileSingleStreamSpillerFactory
 
filter() - Static method in class io.prestosql.sql.planner.plan.Patterns.CorrelatedJoin
 
filter() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
filter(int, int, Page) - Method in interface io.prestosql.operator.JoinFilterFunction
 
filter(int, int, Page) - Method in class io.prestosql.operator.StandardJoinFilterFunction
 
filter(int, Page, int, Page) - Method in interface io.prestosql.operator.InternalJoinFilterFunction
 
filter(Predicate<Symbol>) - Method in class io.prestosql.sql.planner.plan.Assignments
 
filter(ConnectorSession, Page) - Method in class io.prestosql.operator.index.TuplePageFilter
 
filter(ConnectorSession, Page) - Method in class io.prestosql.operator.project.DictionaryAwarePageFilter
 
filter(ConnectorSession, Page) - Method in interface io.prestosql.operator.project.PageFilter
 
filter(Collection<Symbol>) - Method in class io.prestosql.sql.planner.plan.Assignments
 
filter(ContainerRequestContext) - Method in class io.prestosql.server.security.AuthenticationFilter
 
filter(ContainerRequestContext) - Method in class io.prestosql.server.ui.DisabledWebUiAuthenticationFilter
 
filter(ContainerRequestContext) - Method in class io.prestosql.server.ui.FixedUserWebUiAuthenticationFilter
 
filter(ContainerRequestContext) - Method in class io.prestosql.server.ui.FormWebUiAuthenticationFilter
 
filter(ContainerRequestContext) - Method in class io.prestosql.server.ui.NoWebUiAuthenticationFilter
 
filter(ContainerRequestContext) - Method in class io.prestosql.server.ui.OAuth2WebUiAuthenticationFilter
 
FILTER_AND_PROJECT_MIN_OUTPUT_PAGE_ROW_COUNT - Static variable in class io.prestosql.SystemSessionProperties
 
FILTER_AND_PROJECT_MIN_OUTPUT_PAGE_SIZE - Static variable in class io.prestosql.SystemSessionProperties
 
FilterAndProjectOperator - Class in io.prestosql.operator
 
filterBoolean(Type, Block, BooleanToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayFilterFunction
 
filterCatalogs(Identity, Set<String>) - Method in interface io.prestosql.security.AccessControl
Filter the list of catalogs to those visible to the identity.
filterCatalogs(Identity, Set<String>) - Method in class io.prestosql.security.AccessControlManager
 
filterCatalogs(Identity, Set<String>) - Method in class io.prestosql.security.AllowAllAccessControl
 
filterCatalogs(Identity, Set<String>) - Method in class io.prestosql.security.DenyAllAccessControl
 
filterCatalogs(Identity, Set<String>) - Method in class io.prestosql.security.ForwardingAccessControl
 
filterCatalogs(Identity, Set<String>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
filterColumns(SecurityContext, CatalogSchemaTableName, Set<String>) - Method in interface io.prestosql.security.AccessControl
Filter the list of columns to those visible to the identity.
filterColumns(SecurityContext, CatalogSchemaTableName, Set<String>) - Method in class io.prestosql.security.AccessControlManager
 
filterColumns(SecurityContext, CatalogSchemaTableName, Set<String>) - Method in class io.prestosql.security.AllowAllAccessControl
 
filterColumns(SecurityContext, CatalogSchemaTableName, Set<String>) - Method in class io.prestosql.security.DenyAllAccessControl
 
filterColumns(SecurityContext, CatalogSchemaTableName, Set<String>) - Method in class io.prestosql.security.ForwardingAccessControl
 
filterColumns(ConnectorSecurityContext, SchemaTableName, Set<String>) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
filterConjuncts(Metadata, Expression, Predicate<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
filterDeterministicConjuncts(Metadata, Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
filterDouble(Type, Block, DoubleToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayFilterFunction
 
filteredCopy(Iterable<T>, Predicate<T>) - Static method in class io.prestosql.util.MoreLists
 
filterExpressionRewrite() - Method in class io.prestosql.sql.planner.iterative.rule.ExpressionRewriteRuleSet
 
filterIfMissing(Collection<Symbol>, Symbol) - Static method in class io.prestosql.sql.planner.optimizations.PropertyDerivations
 
FILTERING_SEMI_JOIN_TO_INNER - Static variable in class io.prestosql.SystemSessionProperties
 
filterLong(Type, Block, LongToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayFilterFunction
 
FilterNode - Class in io.prestosql.sql.planner.plan
 
FilterNode(PlanNodeId, PlanNode, Expression) - Constructor for class io.prestosql.sql.planner.plan.FilterNode
 
filterNonDeterministicConjuncts(Metadata, Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
filterObject(Type, Block, ObjectToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayFilterFunction
 
filterOrRewrite(Collection<Symbol>, Collection<JoinNode.EquiJoinClause>, Symbol) - Static method in class io.prestosql.sql.planner.optimizations.PropertyDerivations
 
filterQueries(Identity, List<BasicQueryInfo>, AccessControl) - Static method in class io.prestosql.security.AccessControlUtil
 
filterQueriesOwnedBy(Identity, Set<String>) - Method in interface io.prestosql.security.AccessControl
Filter the list of users to those the identity view query owned by the user.
filterQueriesOwnedBy(Identity, Set<String>) - Method in class io.prestosql.security.AccessControlManager
 
filterQueriesOwnedBy(Identity, Set<String>) - Method in class io.prestosql.security.AllowAllAccessControl
 
filterQueriesOwnedBy(Identity, Set<String>) - Method in class io.prestosql.security.DenyAllAccessControl
 
filterQueriesOwnedBy(Identity, Set<String>) - Method in class io.prestosql.security.ForwardingAccessControl
 
filterQueriesOwnedBy(Identity, Set<String>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
filterRequest(Request) - Method in class io.prestosql.server.GenerateTraceTokenRequestFilter
 
filterRequest(Request) - Method in class io.prestosql.server.InternalAuthenticationManager
 
filterSchemas(SecurityContext, String, Set<String>) - Method in interface io.prestosql.security.AccessControl
Filter the list of schemas in a catalog to those visible to the identity.
filterSchemas(SecurityContext, String, Set<String>) - Method in class io.prestosql.security.AccessControlManager
 
filterSchemas(SecurityContext, String, Set<String>) - Method in class io.prestosql.security.AllowAllAccessControl
 
filterSchemas(SecurityContext, String, Set<String>) - Method in class io.prestosql.security.DenyAllAccessControl
 
filterSchemas(SecurityContext, String, Set<String>) - Method in class io.prestosql.security.ForwardingAccessControl
 
filterSchemas(ConnectorSecurityContext, Set<String>) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
filterStats(PlanNodeStatsEstimate, Expression, Session, TypeProvider) - Method in class io.prestosql.cost.FilterStatsCalculator
 
FilterStatsCalculator - Class in io.prestosql.cost
 
FilterStatsCalculator(Metadata, ScalarStatsCalculator, StatsNormalizer) - Constructor for class io.prestosql.cost.FilterStatsCalculator
 
FilterStatsRule - Class in io.prestosql.cost
 
FilterStatsRule(StatsNormalizer, FilterStatsCalculator) - Constructor for class io.prestosql.cost.FilterStatsRule
 
filterTables(SecurityContext, String, Set<SchemaTableName>) - Method in interface io.prestosql.security.AccessControl
Filter the list of tables and views to those visible to the identity.
filterTables(SecurityContext, String, Set<SchemaTableName>) - Method in class io.prestosql.security.AccessControlManager
 
filterTables(SecurityContext, String, Set<SchemaTableName>) - Method in class io.prestosql.security.AllowAllAccessControl
 
filterTables(SecurityContext, String, Set<SchemaTableName>) - Method in class io.prestosql.security.DenyAllAccessControl
 
filterTables(SecurityContext, String, Set<SchemaTableName>) - Method in class io.prestosql.security.ForwardingAccessControl
 
filterTables(SecurityContext, String, Set<SchemaTableName>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
filterTables(ConnectorSecurityContext, Set<SchemaTableName>) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
FilterUtil - Class in io.prestosql.connector.system.jdbc
 
filterWithTuple(Page) - Method in class io.prestosql.operator.index.DynamicTupleFilterFactory
 
FINAL - io.prestosql.sql.planner.plan.AggregationNode.Step
 
FINAL - io.prestosql.sql.planner.plan.TopNNode.Step
 
FinalizerService - Class in io.prestosql.util
 
FinalizerService() - Constructor for class io.prestosql.util.FinalizerService
 
find(T) - Method in class io.prestosql.util.DisjointSet
 
findAggregationStateParamId(Method) - Static method in class io.prestosql.operator.aggregation.AggregationImplementation.Parser
 
findAggregationStateParamId(Method, int) - Static method in class io.prestosql.operator.aggregation.AggregationImplementation.Parser
 
findAggregationStateParamType(Method) - Static method in class io.prestosql.operator.aggregation.AggregationImplementation.Parser
 
findAll() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
findAndUnion(T, T) - Method in class io.prestosql.util.DisjointSet
 
findColumnMetadata(ConnectorTableMetadata, String) - Static method in class io.prestosql.metadata.MetadataUtil
 
findConstructor(Class<?>) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
findFirst() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
findJoinPositions(int, Page, int, Optional<Integer>) - Method in class io.prestosql.operator.PagesRTreeIndex
Returns an array of addresses from PagesIndex.valueAddresses corresponding to rows with matching geometries.
findJoinPositions(int, Page, int, Optional<Integer>) - Method in interface io.prestosql.operator.PagesSpatialIndex
 
findOnlyElement() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
findOnlyElement(T) - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
findPublicMethodsWithAnnotation(Class<?>, Class<? extends Annotation>...) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
findPublicStaticMethodsWithAnnotation(Class<?>, Class<?>) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
findSingle() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
finish() - Method in class io.prestosql.execution.scheduler.ScaledWriterScheduler
 
finish() - Method in class io.prestosql.operator.AggregationOperator
 
finish() - Method in class io.prestosql.operator.BasicWorkProcessorOperatorAdapter
 
finish() - Method in class io.prestosql.operator.DeleteOperator
 
finish() - Method in class io.prestosql.operator.DevNullOperator
 
finish() - Method in class io.prestosql.operator.DistinctLimitOperator
 
finish() - Method in class io.prestosql.operator.DynamicFilterSourceOperator
 
finish() - Method in class io.prestosql.operator.EnforceSingleRowOperator
 
finish() - Method in interface io.prestosql.operator.exchange.LocalExchanger
 
finish() - Method in class io.prestosql.operator.exchange.LocalExchangeSink
 
finish() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator
 
finish() - Method in class io.prestosql.operator.exchange.LocalExchangeSource
 
finish() - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator
 
finish() - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator
 
finish() - Method in class io.prestosql.operator.exchange.PassthroughExchanger
 
finish() - Method in class io.prestosql.operator.ExchangeOperator
 
finish() - Method in class io.prestosql.operator.ExplainAnalyzeOperator
 
finish() - Method in class io.prestosql.operator.FinishedOperator
 
finish() - Method in class io.prestosql.operator.GroupIdOperator
 
finish() - Method in class io.prestosql.operator.HashAggregationOperator
 
finish() - Method in class io.prestosql.operator.HashBuilderOperator
 
finish() - Method in class io.prestosql.operator.index.IndexSourceOperator
 
finish() - Method in class io.prestosql.operator.index.PageBufferOperator
 
finish() - Method in class io.prestosql.operator.index.PagesIndexBuilderOperator
 
finish() - Method in class io.prestosql.operator.LimitOperator
 
finish() - Method in class io.prestosql.operator.LookupJoinOperator
 
finish() - Method in class io.prestosql.operator.LookupOuterOperator
 
finish() - Method in class io.prestosql.operator.MarkDistinctOperator
 
finish() - Method in class io.prestosql.operator.MergeOperator
 
finish() - Method in class io.prestosql.operator.NestedLoopBuildOperator
 
finish() - Method in class io.prestosql.operator.NestedLoopJoinOperator
 
finish() - Method in interface io.prestosql.operator.Operator
Notifies the operator that no more pages will be added and the operator should finish processing and flush results.
finish() - Method in class io.prestosql.operator.OrderByOperator
 
finish() - Method in class io.prestosql.operator.PageBuffer
 
finish() - Method in class io.prestosql.operator.PageSourceOperator
 
finish() - Method in class io.prestosql.operator.PartitionedOutputOperator
 
finish() - Method in class io.prestosql.operator.RowNumberOperator
 
finish() - Method in class io.prestosql.operator.SetBuilderOperator
 
finish() - Method in class io.prestosql.operator.SpatialIndexBuilderOperator
 
finish() - Method in class io.prestosql.operator.SpatialJoinOperator
 
finish() - Method in class io.prestosql.operator.StatisticsWriterOperator
 
finish() - Method in class io.prestosql.operator.TableDeleteOperator
 
finish() - Method in class io.prestosql.operator.TableFinishOperator
 
finish() - Method in class io.prestosql.operator.TableScanOperator
 
finish() - Method in class io.prestosql.operator.TableWriterOperator
 
finish() - Method in class io.prestosql.operator.TaskOutputOperator
 
finish() - Method in class io.prestosql.operator.TopNOperator
 
finish() - Method in class io.prestosql.operator.TopNRowNumberOperator
 
finish() - Method in class io.prestosql.operator.unnest.UnnestOperator
 
finish() - Method in class io.prestosql.operator.ValuesOperator
 
finish() - Method in class io.prestosql.operator.WindowOperator
 
finish() - Method in interface io.prestosql.operator.WorkProcessorOperatorAdapter.AdapterWorkProcessorOperator
 
finish() - Method in class io.prestosql.operator.WorkProcessorOperatorAdapter
 
finish() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
finish() - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
finish() - Method in class io.prestosql.testing.NullOutputOperator
 
finish() - Method in class io.prestosql.testing.PageConsumerOperator
 
finishChallenge(String, String, URI) - Method in class io.prestosql.server.security.oauth2.OAuth2Service
 
finishCreateTable(Session, OutputTableHandle, Collection<Slice>, Collection<ComputedStatistics>) - Method in interface io.prestosql.metadata.Metadata
Finish a table creation with data after the data is written.
finishCreateTable(Session, OutputTableHandle, Collection<Slice>, Collection<ComputedStatistics>) - Method in class io.prestosql.metadata.MetadataManager
 
finishCreateTable(ConnectorSession, ConnectorOutputTableHandle, Collection<Slice>, Collection<ComputedStatistics>) - Method in class io.prestosql.testing.TestingMetadata
 
finishDelete(Session, TableHandle, Collection<Slice>) - Method in interface io.prestosql.metadata.Metadata
Finish delete query
finishDelete(Session, TableHandle, Collection<Slice>) - Method in class io.prestosql.metadata.MetadataManager
 
finished() - Method in class io.prestosql.execution.TaskStateMachine
 
finished() - Method in class io.prestosql.operator.DriverContext
 
finished() - Static method in class io.prestosql.operator.WorkProcessor.ProcessState
Signals that process has finished.
finished() - Static method in class io.prestosql.operator.WorkProcessor.TransformationState
Signals that transformation has finished.
FINISHED - io.prestosql.execution.buffer.BufferState
No more buffers can be added and all pages have been consumed.
FINISHED - io.prestosql.execution.QueryState
Query has finished executing and all output has been consumed.
FINISHED - io.prestosql.execution.StageState
Stage has finished executing and all output has been consumed.
FINISHED - io.prestosql.execution.TaskState
Task has finished executing and all output has been consumed.
FINISHED - io.prestosql.operator.WorkProcessor.ProcessState.Type
 
FINISHED - Static variable in interface io.prestosql.operator.exchange.LocalExchanger
 
finishedLocalExchangeSink() - Static method in class io.prestosql.operator.exchange.LocalExchangeSink
 
FinishedOperator - Class in io.prestosql.operator
 
FinishedOperator(OperatorContext) - Constructor for class io.prestosql.operator.FinishedOperator
 
FINISHING - io.prestosql.execution.QueryState
Query is finishing (e.g.
finishInsert(Session, InsertTableHandle, Collection<Slice>, Collection<ComputedStatistics>) - Method in interface io.prestosql.metadata.Metadata
Finish insert query
finishInsert(Session, InsertTableHandle, Collection<Slice>, Collection<ComputedStatistics>) - Method in class io.prestosql.metadata.MetadataManager
 
finishInsert(ConnectorSession, ConnectorInsertTableHandle, Collection<Slice>, Collection<ComputedStatistics>) - Method in class io.prestosql.testing.TestingMetadata
 
finishMemoryRevoke() - Method in interface io.prestosql.operator.aggregation.builder.HashAggregationBuilder
 
finishMemoryRevoke() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
finishMemoryRevoke() - Method in class io.prestosql.operator.aggregation.builder.SpillableHashAggregationBuilder
 
finishMemoryRevoke() - Method in class io.prestosql.operator.HashAggregationOperator
 
finishMemoryRevoke() - Method in class io.prestosql.operator.HashBuilderOperator
 
finishMemoryRevoke() - Method in interface io.prestosql.operator.Operator
Clean up and release resources after completed memory revoking.
finishMemoryRevoke() - Method in class io.prestosql.operator.OrderByOperator
 
finishMemoryRevoke() - Method in class io.prestosql.operator.WindowOperator
 
finishMemoryRevoke() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
finishProbeOperator(OptionalInt) - Method in interface io.prestosql.operator.LookupSourceFactory
 
finishProbeOperator(OptionalInt) - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
finishRefreshMaterializedView(Session, TableHandle, InsertTableHandle, Collection<Slice>, Collection<ComputedStatistics>, List<TableHandle>) - Method in interface io.prestosql.metadata.Metadata
Finish refresh materialized view query
finishRefreshMaterializedView(Session, TableHandle, InsertTableHandle, Collection<Slice>, Collection<ComputedStatistics>, List<TableHandle>) - Method in class io.prestosql.metadata.MetadataManager
 
finishStatisticsCollection(Session, AnalyzeTableHandle, Collection<ComputedStatistics>) - Method in interface io.prestosql.metadata.Metadata
Finish statistics collection
finishStatisticsCollection(Session, AnalyzeTableHandle, Collection<ComputedStatistics>) - Method in class io.prestosql.metadata.MetadataManager
 
finishTable(Collection<Slice>, Collection<ComputedStatistics>) - Method in interface io.prestosql.operator.TableFinishOperator.TableFinisher
 
finishWhen(BooleanSupplier) - Method in interface io.prestosql.operator.WorkProcessor
 
firstLong() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
 
firstNonNaN(double...) - Static method in class io.prestosql.util.MoreMath
 
FirstValueFunction - Class in io.prestosql.operator.window
 
FirstValueFunction(List<Integer>, boolean) - Constructor for class io.prestosql.operator.window.FirstValueFunction
 
FIXED - io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties.StreamDistribution
 
FIXED_ARBITRARY_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
FIXED_BROADCAST_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
FIXED_HASH_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
FIXED_LIFESPAN_SCHEDULE_GROUPED_EXECUTION - io.prestosql.operator.StageExecutionDescriptor.StageExecutionStrategy
 
FIXED_PASSTHROUGH_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
FixedBucketNodeMap - Class in io.prestosql.execution.scheduler
 
FixedBucketNodeMap(ToIntFunction<Split>, List<InternalNode>) - Constructor for class io.prestosql.execution.scheduler.FixedBucketNodeMap
 
FixedCountScheduler - Class in io.prestosql.execution.scheduler
 
FixedCountScheduler(FixedCountScheduler.TaskScheduler, List<InternalNode>) - Constructor for class io.prestosql.execution.scheduler.FixedCountScheduler
 
FixedCountScheduler(SqlStageExecution, List<InternalNode>) - Constructor for class io.prestosql.execution.scheduler.FixedCountScheduler
 
FixedCountScheduler.TaskScheduler - Interface in io.prestosql.execution.scheduler
 
fixedLifespanScheduleGroupedExecution(List<PlanNodeId>) - Static method in class io.prestosql.operator.StageExecutionDescriptor
 
FixedLifespanScheduler - Class in io.prestosql.execution.scheduler.group
See LifespanScheduler about thread safety
FixedLifespanScheduler(BucketNodeMap, List<ConnectorPartitionHandle>, OptionalInt) - Constructor for class io.prestosql.execution.scheduler.group.FixedLifespanScheduler
 
fixedParallelism() - Static method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
FixedSourcePartitionedScheduler - Class in io.prestosql.execution.scheduler
 
FixedSourcePartitionedScheduler(SqlStageExecution, Map<PlanNodeId, SplitSource>, StageExecutionDescriptor, List<PlanNodeId>, List<InternalNode>, BucketNodeMap, int, OptionalInt, NodeSelector, List<ConnectorPartitionHandle>, DynamicFilterService) - Constructor for class io.prestosql.execution.scheduler.FixedSourcePartitionedScheduler
 
FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy - Class in io.prestosql.execution.scheduler
 
FixedUiAuthenticatorModule - Class in io.prestosql.server.ui
 
FixedUiAuthenticatorModule() - Constructor for class io.prestosql.server.ui.FixedUiAuthenticatorModule
 
FixedUserWebUiAuthenticationFilter - Class in io.prestosql.server.ui
 
FixedUserWebUiAuthenticationFilter(FixedUserWebUiConfig) - Constructor for class io.prestosql.server.ui.FixedUserWebUiAuthenticationFilter
 
FixedUserWebUiAuthenticationFilter(Identity) - Constructor for class io.prestosql.server.ui.FixedUserWebUiAuthenticationFilter
 
FixedUserWebUiConfig - Class in io.prestosql.server.ui
 
FixedUserWebUiConfig() - Constructor for class io.prestosql.server.ui.FixedUserWebUiConfig
 
FLAT - io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig.TopologyType
 
flatMap(Function<T, WorkProcessor<R>>) - Method in interface io.prestosql.operator.WorkProcessor
 
FlatNetworkTopology - Class in io.prestosql.execution.scheduler
 
FlatNetworkTopology() - Constructor for class io.prestosql.execution.scheduler.FlatNetworkTopology
 
flatten(WorkProcessor<WorkProcessor<T>>) - Static method in interface io.prestosql.operator.WorkProcessor
 
flatten(Type, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayFlattenFunction
 
flatTransform(WorkProcessor.Transformation<T, WorkProcessor<R>>) - Method in interface io.prestosql.operator.WorkProcessor
Flattens WorkProcessors returned by transformation.
flip() - Method in class io.prestosql.sql.planner.plan.JoinNode.EquiJoinClause
 
flipChildren() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
FloatingPointBitsConverterUtil - Class in io.prestosql.operator.aggregation
 
floatToSortableInt(float) - Static method in class io.prestosql.operator.aggregation.FloatingPointBitsConverterUtil
Converts a float value to a sortable int.
floor(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
floor(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
floorFloat(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
floorInteger(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
floorLong(long, Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Floor
 
floorLongShort(long, Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Floor
 
floorShort(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions.Floor
 
floorSmallint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
floorTinyint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
FLUSHING - io.prestosql.execution.buffer.BufferState
No more pages or buffers can be added, and buffer is waiting for the final pages to be consumed.
FLUSHING - io.prestosql.execution.StageState
Stage has finished executing and output being consumed.
FLUSHING - io.prestosql.execution.TaskState
Task has finished executing and output is left to be consumed.
ForAsyncHttp - Annotation Type in io.prestosql.server
 
forBlockIndexParameter() - Static method in class io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata
 
FORCE_SINGLE_NODE_OUTPUT - Static variable in class io.prestosql.SystemSessionProperties
 
forceYieldForTesting() - Method in class io.prestosql.operator.DriverYieldSignal
 
forEach(ArrayAggregationStateConsumer) - Method in interface io.prestosql.operator.aggregation.arrayagg.ArrayAggregationState
 
forEach(ArrayAggregationStateConsumer) - Method in class io.prestosql.operator.aggregation.arrayagg.SingleArrayAggregationState
 
forEach(MultimapAggregationStateConsumer) - Method in interface io.prestosql.operator.aggregation.multimapagg.MultimapAggregationState
 
forEach(MultimapAggregationStateConsumer) - Method in class io.prestosql.operator.aggregation.multimapagg.SingleMultimapAggregationState
 
forEach(BiConsumer<Symbol, Expression>) - Method in class io.prestosql.sql.planner.plan.Assignments
 
forEach(T) - Method in class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
 
forEachBucket(BucketConsumer<K>) - Method in class io.prestosql.operator.aggregation.ApproximateMostFrequentHistogram
 
forEachExpression(PlanNode, Consumer<Expression>) - Static method in class io.prestosql.sql.planner.ExpressionExtractor
 
ForExchange - Annotation Type in io.prestosql.operator
 
ForFailureDetector - Annotation Type in io.prestosql.failuredetector
 
ForJwk - Annotation Type in io.prestosql.server.security.jwt
 
format(long, ConnectorSession, LongTimestamp, Slice) - Static method in class io.prestosql.operator.scalar.timestamp.DateFormat
 
format(ConnectorSession, long, Slice) - Static method in class io.prestosql.operator.scalar.timestamp.DateFormat
 
format(ConnectorSession, long, Slice) - Static method in class io.prestosql.operator.scalar.timestamp.FormatDateTime
 
format(ConnectorSession, long, Slice) - Static method in class io.prestosql.operator.scalar.timestamptz.DateFormat
 
format(ConnectorSession, long, Slice) - Static method in class io.prestosql.operator.scalar.timestamptz.FormatDateTime
 
format(ConnectorSession, LongTimestampWithTimeZone, Slice) - Static method in class io.prestosql.operator.scalar.timestamptz.DateFormat
 
format(ConnectorSession, LongTimestampWithTimeZone, Slice) - Static method in class io.prestosql.operator.scalar.timestamptz.FormatDateTime
 
FORMAT_FUNCTION - Static variable in class io.prestosql.operator.scalar.FormatFunction
 
formatAggregation(AggregationNode.Aggregation) - Static method in class io.prestosql.sql.planner.planprinter.PlanPrinter
 
formatDatetime(long, ConnectorSession, LongTimestamp, Slice) - Static method in class io.prestosql.operator.scalar.timestamp.FormatDateTime
 
FormatDateTime - Class in io.prestosql.operator.scalar.timestamp
 
FormatDateTime - Class in io.prestosql.operator.scalar.timestamptz
 
FormatFunction - Class in io.prestosql.operator.scalar
 
formatOneLine() - Method in class io.prestosql.sql.gen.ArrayMapBytecodeExpression
 
formatOneLine() - Method in class io.prestosql.sql.gen.InvokeFunctionBytecodeExpression
 
formatOneLine() - Method in class io.prestosql.sql.gen.SqlTypeBytecodeExpression
 
FormattedDomain(boolean, Set<IoPlanPrinter.FormattedRange>) - Constructor for class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedDomain
 
FormattedMarker(Optional<String>, Marker.Bound) - Constructor for class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedMarker
 
FormattedRange(IoPlanPrinter.FormattedMarker, IoPlanPrinter.FormattedMarker) - Constructor for class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedRange
 
formatTimestamp(int, long, int, ZoneId) - Static method in class io.prestosql.type.DateTimes
Formats a timestamp of the given precision.
formatTimestamp(int, long, int, ZoneId, DateTimeFormatter) - Static method in class io.prestosql.type.DateTimes
Formats a timestamp of the given precision.
formatTimestamp(int, LocalDateTime, long, DateTimeFormatter, Consumer<StringBuilder>) - Static method in class io.prestosql.type.DateTimes
 
formatTimestampWithTimeZone(int, long, int, ZoneId) - Static method in class io.prestosql.type.DateTimes
 
FormAuthenticator - Interface in io.prestosql.server.ui
 
ForMemoryManager - Annotation Type in io.prestosql.memory
 
FormUiAuthenticatorModule - Class in io.prestosql.server.ui
 
FormUiAuthenticatorModule(boolean) - Constructor for class io.prestosql.server.ui.FormUiAuthenticatorModule
 
FormWebUiAuthenticationFilter - Class in io.prestosql.server.ui
 
FormWebUiAuthenticationFilter(FormWebUiConfig, FormAuthenticator, Optional<Authenticator>) - Constructor for class io.prestosql.server.ui.FormWebUiAuthenticationFilter
 
FormWebUiConfig - Class in io.prestosql.server.ui
 
FormWebUiConfig() - Constructor for class io.prestosql.server.ui.FormWebUiConfig
 
ForNodeManager - Annotation Type in io.prestosql.metadata
 
ForOAuth2 - Annotation Type in io.prestosql.server.security.oauth2
 
ForQueryExecution - Annotation Type in io.prestosql.execution
 
ForScheduler - Annotation Type in io.prestosql.operator
 
forSession(Session) - Method in class io.prestosql.cost.CostComparator
 
ForStatementResource - Annotation Type in io.prestosql.server
 
forStateParameter() - Static method in class io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata
 
ForTransactionManager - Annotation Type in io.prestosql.transaction
 
ForwardingAccessControl - Class in io.prestosql.security
 
ForwardingAccessControl() - Constructor for class io.prestosql.security.ForwardingAccessControl
 
ForWebUi - Annotation Type in io.prestosql.server.ui
 
ForWorkerInfo - Annotation Type in io.prestosql.server
 
FRAGMENT_CHANNEL - Static variable in class io.prestosql.operator.TableWriterOperator
 
FragmentTableScanCounter - Class in io.prestosql.sql.planner
Visitor to count number of tables scanned in the current fragment (fragments separated by ExchangeNodes).
Frame(WindowFrame.Type, FrameBound.Type, Optional<Symbol>, Optional<Symbol>, FrameBound.Type, Optional<Symbol>, Optional<Symbol>, Optional<Expression>, Optional<Expression>) - Constructor for class io.prestosql.sql.planner.plan.WindowNode.Frame
 
FrameBoundKey(int, WindowOperator.FrameBoundKey.Type) - Constructor for class io.prestosql.operator.WindowOperator.FrameBoundKey
 
FramedWindowFunction - Class in io.prestosql.operator.window
 
FramedWindowFunction(WindowFunction, FrameInfo) - Constructor for class io.prestosql.operator.window.FramedWindowFunction
 
FrameInfo - Class in io.prestosql.operator.window
 
FrameInfo(WindowFrame.Type, FrameBound.Type, Optional<Integer>, Optional<Integer>, FrameBound.Type, Optional<Integer>, Optional<Integer>, Optional<Integer>, Optional<SortItem.Ordering>) - Constructor for class io.prestosql.operator.window.FrameInfo
 
free(long) - Method in class io.prestosql.spiller.SpillSpaceTracker
 
free(QueryId, String, long) - Method in class io.prestosql.memory.MemoryPool
 
FreeLambdaReferenceExtractor - Class in io.prestosql.sql.analyzer
Extract expressions that are free (unbound) references to a lambda argument.
freeRevocable(QueryId, long) - Method in class io.prestosql.memory.MemoryPool
 
freeSpill(long) - Method in class io.prestosql.memory.QueryContext
 
freeSpill(long) - Method in class io.prestosql.operator.DriverContext
 
freeSpill(long) - Method in class io.prestosql.operator.PipelineContext
 
freeSpill(long) - Method in class io.prestosql.operator.TaskContext
 
from(SymbolStatsEstimate) - Static method in class io.prestosql.cost.StatisticRange
 
from(LookupSourceProvider.LookupSourceLease) - Static method in class io.prestosql.operator.LookupJoinOperator.SpillInfoSnapshot
 
from(ResolvedField) - Static method in class io.prestosql.sql.analyzer.FieldId
 
from(Expression) - Static method in class io.prestosql.sql.planner.Symbol
 
from(Function<GroupReference, Stream<PlanNode>>) - Static method in interface io.prestosql.sql.planner.iterative.Lookup
 
fromAnnotatedElement(AnnotatedElement) - Static method in class io.prestosql.operator.scalar.annotations.ScalarImplementationHeader
 
fromBase(Slice, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
fromBase64UrlVarbinary(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
fromBase64UrlVarchar(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
fromBase64Varbinary(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
fromBase64Varchar(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
fromBigEndian32(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
fromBigEndian64(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
fromByteValue(byte) - Static method in class io.prestosql.execution.buffer.PageCodecMarker.MarkerSet
 
fromHexVarbinary(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
fromHexVarchar(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
fromIEEE754Binary32(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
fromIEEE754Binary64(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
fromISO8601Date(ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
fromISO8601Timestamp(ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
fromIso8601TimestampNanos(ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
fromIterable(Iterable<T>) - Static method in interface io.prestosql.operator.WorkProcessor
 
fromIterator(Iterator<T>) - Static method in interface io.prestosql.operator.WorkProcessor
 
fromJoinNodeType(JoinNode.Type) - Static method in enum io.prestosql.sql.planner.plan.SpatialJoinNode.Type
 
fromLong(long, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions.FromUnixtimeNanosDecimal
 
fromOrderBy(OrderBy) - Static method in class io.prestosql.sql.planner.OrderingScheme
 
fromPredicate(Metadata, TypeOperators, Session, Expression, TypeProvider) - Static method in class io.prestosql.sql.planner.DomainTranslator
Convert an Expression predicate into an ExtractionResult consisting of: 1) A successfully extracted TupleDomain 2) An Expression fragment which represents the part of the original Expression that will need to be re-evaluated after filtering with the TupleDomain.
fromQualifiedName(QualifiedName) - Method in class io.prestosql.metadata.ResolvedFunction.ResolvedFunctionDecoder
 
fromSchemaTableName(SchemaTableName) - Static method in class io.prestosql.connector.system.SystemTableHandle
 
fromShort(long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions.FromUnixtimeNanosDecimal
 
fromSqlType(Type, boolean, boolean, String) - Static method in class io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata
 
fromSqlType(String) - Method in interface io.prestosql.metadata.Metadata
 
fromSqlType(String) - Method in class io.prestosql.metadata.MetadataManager
 
fromSqlType(String) - Method in class io.prestosql.type.InternalTypeManager
 
fromString(String) - Static method in class io.prestosql.execution.buffer.OutputBuffers.OutputBufferId
 
fromString(String) - Static method in enum io.prestosql.memory.MemoryManagerConfig.LowMemoryKillerPolicy
 
fromStringValue(String) - Method in enum io.prestosql.connector.informationschema.InformationSchemaTable
 
fromType(SampledRelation.Type) - Static method in enum io.prestosql.sql.planner.plan.SampleNode.Type
 
fromTypes(Type...) - Static method in class io.prestosql.sql.analyzer.TypeSignatureProvider
 
fromTypes(List<? extends Type>) - Static method in class io.prestosql.sql.analyzer.TypeSignatureProvider
 
fromTypeSignatures(TypeSignature...) - Static method in class io.prestosql.sql.analyzer.TypeSignatureProvider
 
fromTypeSignatures(List<? extends TypeSignature>) - Static method in class io.prestosql.sql.analyzer.TypeSignatureProvider
 
fromUnixTime(double) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
fromUnixTime(double, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
fromUnixTime(double, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
fromUnixtimeNanosLong(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
fromUtf8(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
fromUtf8(Slice, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
fromUtf8(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
FULL - io.prestosql.sql.planner.plan.CorrelatedJoinNode.Type
 
FULL - io.prestosql.sql.planner.plan.JoinNode.Type
 
FULL_OUTER - io.prestosql.operator.LookupJoinOperators.JoinType
 
FullConnectorSession - Class in io.prestosql
 
FullConnectorSession(Session, ConnectorIdentity) - Constructor for class io.prestosql.FullConnectorSession
 
FullConnectorSession(Session, ConnectorIdentity, Map<String, String>, CatalogName, String, SessionPropertyManager) - Constructor for class io.prestosql.FullConnectorSession
 
fullOuterJoin(int, PlanNodeId, JoinBridgeManager<? extends LookupSourceFactory>, List<Type>, List<Integer>, OptionalInt, Optional<List<Integer>>, OptionalInt, PartitioningSpillerFactory, BlockTypeOperators) - Method in class io.prestosql.operator.LookupJoinOperators
 
function(SqlFunction) - Method in class io.prestosql.metadata.FunctionListBuilder
 
Function(ResolvedFunction, List<Expression>, WindowNode.Frame, boolean) - Constructor for class io.prestosql.sql.planner.plan.WindowNode.Function
 
FUNCTION - Static variable in class io.prestosql.type.FunctionParametricType
 
FunctionArgumentDefinition - Class in io.prestosql.metadata
 
FunctionArgumentDefinition(boolean) - Constructor for class io.prestosql.metadata.FunctionArgumentDefinition
 
FunctionBinding - Class in io.prestosql.metadata
 
FunctionBinding(FunctionId, BoundSignature, Map<String, Type>, Map<String, Long>) - Constructor for class io.prestosql.metadata.FunctionBinding
 
FunctionCallBuilder - Class in io.prestosql.sql.planner
 
FunctionCallBuilder(Metadata) - Constructor for class io.prestosql.sql.planner.FunctionCallBuilder
 
FunctionDependencies - Class in io.prestosql.metadata
 
FunctionDependencies(Metadata, Map<TypeSignature, Type>, Collection<ResolvedFunction>) - Constructor for class io.prestosql.metadata.FunctionDependencies
 
FunctionDependencies.FunctionKey - Class in io.prestosql.metadata
 
FunctionDependencies.OperatorKey - Class in io.prestosql.metadata
 
FunctionDependencyDeclaration - Class in io.prestosql.metadata
 
FunctionDependencyDeclaration.CastDependency - Class in io.prestosql.metadata
 
FunctionDependencyDeclaration.FunctionDependency - Class in io.prestosql.metadata
 
FunctionDependencyDeclaration.FunctionDependencyDeclarationBuilder - Class in io.prestosql.metadata
 
FunctionDependencyDeclaration.OperatorDependency - Class in io.prestosql.metadata
 
FunctionExtractor - Class in io.prestosql.metadata
 
FunctionId - Class in io.prestosql.metadata
 
FunctionId(String) - Constructor for class io.prestosql.metadata.FunctionId
 
FunctionImplementationDependency - Class in io.prestosql.operator.annotations
 
FunctionImplementationDependency(QualifiedName, List<TypeSignature>, InvocationConvention, Class<?>) - Constructor for class io.prestosql.operator.annotations.FunctionImplementationDependency
 
FunctionInvoker - Class in io.prestosql.metadata
 
FunctionInvoker(MethodHandle, Optional<MethodHandle>) - Constructor for class io.prestosql.metadata.FunctionInvoker
 
FunctionInvoker(MethodHandle, Optional<MethodHandle>, List<Class<?>>) - Constructor for class io.prestosql.metadata.FunctionInvoker
 
FunctionKind - Enum in io.prestosql.metadata
 
FunctionListBuilder - Class in io.prestosql.metadata
 
FunctionListBuilder() - Constructor for class io.prestosql.metadata.FunctionListBuilder
 
FunctionMetadata - Class in io.prestosql.metadata
 
FunctionMetadata(FunctionId, Signature, boolean, List<FunctionArgumentDefinition>, boolean, boolean, String, FunctionKind, boolean) - Constructor for class io.prestosql.metadata.FunctionMetadata
 
FunctionMetadata(Signature, boolean, List<FunctionArgumentDefinition>, boolean, boolean, String, FunctionKind) - Constructor for class io.prestosql.metadata.FunctionMetadata
 
FunctionMetadata(Signature, boolean, List<FunctionArgumentDefinition>, boolean, boolean, String, FunctionKind, boolean) - Constructor for class io.prestosql.metadata.FunctionMetadata
 
FunctionParametricType - Class in io.prestosql.type
 
FunctionRegistry - Class in io.prestosql.metadata
 
FunctionRegistry(Supplier<BlockEncodingSerde>, FeaturesConfig, TypeOperators, BlockTypeOperators) - Constructor for class io.prestosql.metadata.FunctionRegistry
 
FunctionResolver - Class in io.prestosql.metadata
 
FunctionResolver(Metadata) - Constructor for class io.prestosql.metadata.FunctionResolver
 
functions(SqlFunction...) - Method in class io.prestosql.metadata.FunctionListBuilder
 
FunctionsParserHelper - Class in io.prestosql.operator.annotations
 
FunctionType - Class in io.prestosql.type
 
FunctionType(List<Type>, Type) - Constructor for class io.prestosql.type.FunctionType
 
FutureStateChange<T> - Class in io.prestosql.execution
 
FutureStateChange() - Constructor for class io.prestosql.execution.FutureStateChange
 

G

GATHER - io.prestosql.sql.planner.plan.ExchangeNode.Type
 
GatherAndMergeWindows - Class in io.prestosql.sql.planner.iterative.rule
 
GatherAndMergeWindows.MergeAdjacentWindowsOverProjects - Class in io.prestosql.sql.planner.iterative.rule
 
GatherAndMergeWindows.SwapAdjacentWindowsBySpecifications - Class in io.prestosql.sql.planner.iterative.rule
 
gatheringExchange(PlanNodeId, ExchangeNode.Scope, PlanNode) - Static method in class io.prestosql.sql.planner.plan.ExchangeNode
 
GENERAL_POOL - Static variable in class io.prestosql.memory.LocalMemoryManager
 
generate(RowExpression) - Method in class io.prestosql.sql.gen.BytecodeGeneratorContext
 
generateAccumulatorFactoryBinder(AggregationMetadata, DynamicClassLoader) - Static method in class io.prestosql.operator.aggregation.AccumulatorCompiler
 
generateAggregation(Type) - Method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
generateAggregation(Type, Type) - Method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
generateAggregation(Type, MethodHandle) - Method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
generateAggregationName(String, TypeSignature, List<TypeSignature>) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
generateBlockPositionLessThan(Type) - Method in class io.prestosql.type.BlockTypeOperators
 
generateBlockPositionOrdering(Type, SortOrder) - Method in class io.prestosql.type.BlockTypeOperators
 
generateCall(ResolvedFunction, List<BytecodeNode>) - Method in class io.prestosql.sql.gen.BytecodeGeneratorContext
Generates a function call with null handling, automatic binding of session parameter, etc.
generateCpuQuota(long) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
generatedNameOf(Class<?>, Map<String, String>) - Method in class io.prestosql.server.PrefixObjectNameGeneratorModule.PrefixObjectNameGenerator
 
GeneratedPageProjection - Class in io.prestosql.operator.project
 
GeneratedPageProjection(RowExpression, boolean, InputChannels, MethodHandle) - Constructor for class io.prestosql.operator.project.GeneratedPageProjection
 
generateEqualitiesPartitionedBy(Set<Symbol>) - Method in class io.prestosql.sql.planner.EqualityInference
Dumps the inference equalities as equality expressions that are partitioned by the symbolScope.
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.AndCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.BetweenCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.BindCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in interface io.prestosql.sql.gen.BytecodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.CoalesceCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.DereferenceCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.IfCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.InCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.IsNullCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.NullIfCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.OrCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.RowConstructorCodeGenerator
 
generateExpression(BytecodeGeneratorContext) - Method in class io.prestosql.sql.gen.SwitchCodeGenerator
 
generateExtractor(String, JsonExtract.JsonExtractor<T>) - Static method in class io.prestosql.operator.scalar.JsonExtract
 
generateExtractor(String, JsonExtract.JsonExtractor<T>, boolean) - Static method in class io.prestosql.operator.scalar.JsonExtract
 
generateFullCall(ResolvedFunction, List<RowExpression>) - Method in class io.prestosql.sql.gen.BytecodeGeneratorContext
 
generateFullInvocation(Scope, FunctionMetadata, Function<InvocationConvention, FunctionInvoker>, Function<MethodHandle, BytecodeNode>, List<Function<Optional<Class<?>>, BytecodeNode>>, CallSiteBinder) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
generateFullInvocation(Scope, ResolvedFunction, Metadata, Function<MethodHandle, BytecodeNode>, List<Function<Optional<Class<?>>, BytecodeNode>>, CallSiteBinder) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
generateInitializations(Variable, BytecodeBlock) - Method in class io.prestosql.sql.gen.CachedInstanceBinder
 
generateInvocation(Scope, FunctionMetadata, Function<InvocationConvention, FunctionInvoker>, List<BytecodeNode>, CallSiteBinder) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
generateInvocation(Scope, ResolvedFunction, Metadata, List<BytecodeNode>, CallSiteBinder) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
generateLambda(BytecodeGeneratorContext, List<RowExpression>, LambdaBytecodeGenerator.CompiledLambda, Class<?>) - Static method in class io.prestosql.sql.gen.LambdaBytecodeGenerator
 
generateMethods(ClassDefinition, CallSiteBinder, RowExpression, List<RowExpression>) - Method in interface io.prestosql.sql.gen.BodyCompiler
 
generateMethods(ClassDefinition, CallSiteBinder, RowExpression, List<RowExpression>) - Method in class io.prestosql.sql.gen.CursorProcessorCompiler
 
generateMethodsForLambda(ClassDefinition, CallSiteBinder, CachedInstanceBinder, RowExpression, Metadata) - Static method in class io.prestosql.sql.gen.LambdaBytecodeGenerator
 
generateStateFactory(Class<T>) - Static method in class io.prestosql.operator.aggregation.state.StateCompiler
 
generateStateFactory(Class<T>, DynamicClassLoader) - Static method in class io.prestosql.operator.aggregation.state.StateCompiler
 
generateStateFactory(Class<T>, Map<String, Type>, DynamicClassLoader) - Static method in class io.prestosql.operator.aggregation.state.StateCompiler
 
generateStateSerializer(Class<T>) - Static method in class io.prestosql.operator.aggregation.state.StateCompiler
 
generateStateSerializer(Class<T>, DynamicClassLoader) - Static method in class io.prestosql.operator.aggregation.state.StateCompiler
 
generateStateSerializer(Class<T>, Map<String, Type>, DynamicClassLoader) - Static method in class io.prestosql.operator.aggregation.state.StateCompiler
 
GenerateTimeZoneIndex - Class in io.prestosql.util
 
GenerateTraceTokenRequestFilter - Class in io.prestosql.server
 
GenerateTraceTokenRequestFilter() - Constructor for class io.prestosql.server.GenerateTraceTokenRequestFilter
 
generateVarArgsToArrayAdapter(Class<?>, Class<?>, int, MethodHandle, MethodHandle) - Static method in class io.prestosql.sql.gen.VarArgsToArrayAdapterGenerator
 
generateVarArgsToMapAdapter(Class<?>, List<Class<?>>, List<String>, Function<Map<String, Object>, Object>) - Static method in class io.prestosql.sql.gen.VarArgsToMapAdapterGenerator
Generate byte code that
generateWrite(CallSiteBinder, Scope, Variable, Type) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
GenericAccumulatorFactory - Class in io.prestosql.operator.aggregation
 
GenericAccumulatorFactory(List<AggregationMetadata.AccumulatorStateDescriptor>, Constructor<? extends Accumulator>, boolean, Constructor<? extends GroupedAccumulator>, List<LambdaProvider>, List<Integer>, Optional<Integer>, List<Type>, List<Integer>, List<SortOrder>, PagesIndex.Factory, JoinCompiler, BlockTypeOperators, Session, boolean) - Constructor for class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
GenericAccumulatorFactoryBinder - Class in io.prestosql.operator.aggregation
 
GenericAccumulatorFactoryBinder(List<AggregationMetadata.AccumulatorStateDescriptor>, Class<? extends Accumulator>, boolean, Class<? extends GroupedAccumulator>) - Constructor for class io.prestosql.operator.aggregation.GenericAccumulatorFactoryBinder
 
GenericComparisonOperator - Class in io.prestosql.operator.scalar
 
GenericComparisonOperator(TypeOperators) - Constructor for class io.prestosql.operator.scalar.GenericComparisonOperator
 
GenericDistinctFromOperator - Class in io.prestosql.operator.scalar
 
GenericDistinctFromOperator(TypeOperators) - Constructor for class io.prestosql.operator.scalar.GenericDistinctFromOperator
 
GenericEqualOperator - Class in io.prestosql.operator.scalar
 
GenericEqualOperator(TypeOperators) - Constructor for class io.prestosql.operator.scalar.GenericEqualOperator
 
GenericHashCodeOperator - Class in io.prestosql.operator.scalar
 
GenericHashCodeOperator(TypeOperators) - Constructor for class io.prestosql.operator.scalar.GenericHashCodeOperator
 
GenericIndeterminateOperator - Class in io.prestosql.operator.scalar
 
GenericIndeterminateOperator(TypeOperators) - Constructor for class io.prestosql.operator.scalar.GenericIndeterminateOperator
 
genericIntegerTypeToLongDecimal(long, int, int) - Static method in class io.prestosql.type.DecimalSaturatedFloorCasts
 
genericIntegerTypeToShortDecimal(long, int, int) - Static method in class io.prestosql.type.DecimalSaturatedFloorCasts
 
GenericLessThanOperator - Class in io.prestosql.operator.scalar
 
GenericLessThanOperator(TypeOperators) - Constructor for class io.prestosql.operator.scalar.GenericLessThanOperator
 
GenericLessThanOrEqualOperator - Class in io.prestosql.operator.scalar
 
GenericLessThanOrEqualOperator(TypeOperators) - Constructor for class io.prestosql.operator.scalar.GenericLessThanOrEqualOperator
 
GenericPartitioningSpiller - Class in io.prestosql.spiller
 
GenericPartitioningSpiller(List<Type>, PartitionFunction, SpillContext, AggregatedMemoryContext, SingleStreamSpillerFactory) - Constructor for class io.prestosql.spiller.GenericPartitioningSpiller
 
GenericPartitioningSpillerFactory - Class in io.prestosql.spiller
 
GenericPartitioningSpillerFactory(SingleStreamSpillerFactory) - Constructor for class io.prestosql.spiller.GenericPartitioningSpillerFactory
 
GenericSpiller - Class in io.prestosql.spiller
 
GenericSpiller(List<Type>, SpillContext, AggregatedMemoryContext, SingleStreamSpillerFactory) - Constructor for class io.prestosql.spiller.GenericSpiller
 
GenericSpillerFactory - Class in io.prestosql.spiller
 
GenericSpillerFactory(SingleStreamSpillerFactory) - Constructor for class io.prestosql.spiller.GenericSpillerFactory
 
GenericXxHash64Operator - Class in io.prestosql.operator.scalar
 
GenericXxHash64Operator(TypeOperators) - Constructor for class io.prestosql.operator.scalar.GenericXxHash64Operator
 
GeometricMeanAggregations - Class in io.prestosql.operator.aggregation
 
GeometryWithPosition(OGCGeometry, int, int) - Constructor for class io.prestosql.operator.PagesRTreeIndex.GeometryWithPosition
 
get() - Method in class io.prestosql.execution.StateMachine
 
get() - Method in interface io.prestosql.operator.aggregation.BigintApproximateMostFrequent.State
 
get() - Method in interface io.prestosql.operator.aggregation.DoubleHistogramAggregation.State
 
get() - Method in class io.prestosql.operator.aggregation.histogram.GroupedHistogramState
 
get() - Method in interface io.prestosql.operator.aggregation.histogram.HistogramState
will create an empty histogram if none exists
get() - Method in class io.prestosql.operator.aggregation.histogram.SingleHistogramState
 
get() - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState
 
get() - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory.SingleLongApproximateMostFrequentState
 
get() - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory.GroupedState
 
get() - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory.SingleState
 
get() - Method in interface io.prestosql.operator.aggregation.state.KeyValuePairsState
 
get() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.GroupedState
 
get() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.SingleState
 
get() - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState
 
get() - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory.SingleLongApproximateMostFrequentState
 
get() - Method in interface io.prestosql.operator.aggregation.VarcharApproximateMostFrequent.State
 
get() - Method in class io.prestosql.operator.HashCollisionsCounter
 
get() - Method in class io.prestosql.operator.JoinHashSupplier
 
get() - Method in class io.prestosql.operator.JoinStatisticsCounter
 
get() - Method in class io.prestosql.operator.PagesSpatialIndexSupplier
 
get() - Method in class io.prestosql.sql.planner.plan.SimplePlanRewriter.RewriteContext
 
get() - Method in class io.prestosql.sql.planner.PlanOptimizers
 
get(int) - Method in class io.prestosql.operator.IdRegistry
 
get(long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
get(long, long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
get(OutputBuffers.OutputBufferId, long, DataSize) - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
get(OutputBuffers.OutputBufferId, long, DataSize) - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
get(OutputBuffers.OutputBufferId, long, DataSize) - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
get(OutputBuffers.OutputBufferId, long, DataSize) - Method in interface io.prestosql.execution.buffer.OutputBuffer
Gets pages from the output buffer, and acknowledges all pages received from the last request.
get(OutputBuffers.OutputBufferId, long, DataSize) - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
get(LocalMemoryContext) - Method in class io.prestosql.operator.ExchangeClientFactory
 
get(LocalMemoryContext) - Method in interface io.prestosql.operator.ExchangeClientSupplier
 
get(FunctionId) - Method in class io.prestosql.metadata.FunctionRegistry
 
get(Symbol) - Method in class io.prestosql.sql.planner.plan.Assignments
 
get(Symbol) - Method in class io.prestosql.sql.planner.TypeProvider
 
get(QualifiedName) - Method in class io.prestosql.metadata.FunctionRegistry
 
getAbandonedQueries() - Method in class io.prestosql.execution.QueryManagerStats
 
getAccessControl() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getAccessControl() - Method in class io.prestosql.sql.analyzer.Analysis.AccessControlInfo
 
getAccessControl() - Method in class io.prestosql.testing.LocalQueryRunner
 
getAccessControl() - Method in interface io.prestosql.testing.QueryRunner
 
getAccessControlFiles() - Method in class io.prestosql.security.AccessControlConfig
 
getAccessControlScope(Table) - Method in class io.prestosql.sql.analyzer.Analysis
 
getAccessToken() - Method in class io.prestosql.server.security.oauth2.OAuth2Client.AccessToken
 
getAccessToken() - Method in class io.prestosql.server.security.oauth2.OAuth2Service.OAuthResult
 
getAccessToken(String, URI) - Method in interface io.prestosql.server.security.oauth2.OAuth2Client
 
getAccessToken(String, URI) - Method in class io.prestosql.server.security.oauth2.ScribeJavaOAuth2Client
 
getAccessType(AnnotatedElement) - Method in class io.prestosql.server.security.AnnotatedResourceAccessTypeLoader
 
getAccessType(AnnotatedElement) - Method in interface io.prestosql.server.security.ResourceAccessTypeLoader
 
getAccessType(AnnotatedElement) - Method in class io.prestosql.server.security.ResourceSecurityBinder.StaticResourceAccessTypeLoader
 
getAccessType(ResourceInfo) - Method in class io.prestosql.server.security.ResourceAccessType
 
getAccumulatorFactoryBinder() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
getAccumulatorStateDescriptors() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getActiveConnectorNodes(CatalogName) - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
getActiveConnectorNodes(CatalogName) - Method in class io.prestosql.metadata.InMemoryNodeManager
 
getActiveConnectorNodes(CatalogName) - Method in interface io.prestosql.metadata.InternalNodeManager
 
getActiveCoordinators() - Method in class io.prestosql.metadata.AllNodes
 
getActiveCoordinators() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getActiveCount() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector
 
getActiveNodeCount() - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
getActiveNodes() - Method in class io.prestosql.metadata.AllNodes
 
getActiveNodesWithConnector(CatalogName) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getActiveQueryIds() - Method in class io.prestosql.metadata.MetadataManager
 
getActiveWorkers() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getActualOutputs() - Method in class io.prestosql.sql.planner.plan.ExplainAnalyzeNode
 
getAddedPreparedStatements() - Method in class io.prestosql.execution.QueryInfo
 
getAddedPreparedStatements() - Method in class io.prestosql.execution.QueryStateMachine
 
getAddInputCalls() - Method in class io.prestosql.operator.OperatorStats
 
getAddInputCpu() - Method in class io.prestosql.operator.OperatorStats
 
getAddInputWall() - Method in class io.prestosql.operator.OperatorStats
 
getAdditionalModules() - Method in class io.prestosql.server.Server
 
getAddress() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getAddresses() - Method in class io.prestosql.connector.informationschema.InformationSchemaSplit
 
getAddresses() - Method in class io.prestosql.connector.system.SystemSplit
 
getAddresses() - Method in class io.prestosql.metadata.Split
 
getAddresses() - Method in class io.prestosql.operator.index.IndexSplit
 
getAddresses() - Method in class io.prestosql.split.EmptySplit
 
getAddresses() - Method in class io.prestosql.split.RemoteSplit
 
getAddresses() - Method in class io.prestosql.testing.TestingSplit
 
getAddressIndex(int, Page) - Method in class io.prestosql.operator.PagesHash
 
getAddressIndex(int, Page, long) - Method in class io.prestosql.operator.PagesHash
 
getAddressProtocol() - Method in class io.prestosql.execution.scheduler.SubnetTopologyConfig
 
getAddWarnings() - Method in class io.prestosql.testing.TestingWarningCollectorConfig
 
getAge() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getAggregateFunctionImplementation(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.metadata.FunctionRegistry
 
getAggregateFunctionImplementation(ResolvedFunction) - Method in interface io.prestosql.metadata.Metadata
 
getAggregateFunctionImplementation(ResolvedFunction) - Method in class io.prestosql.metadata.MetadataManager
 
getAggregates(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
getAggregation() - Method in class io.prestosql.sql.planner.StatisticsAggregationPlanner.ColumnStatisticsAggregation
 
getAggregationArguments() - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
getAggregationBuilder() - Method in class io.prestosql.operator.HashAggregationOperator
 
getAggregationFunctionMetadata(FunctionBinding) - Method in class io.prestosql.metadata.FunctionRegistry
 
getAggregationFunctionMetadata(ResolvedFunction) - Method in interface io.prestosql.metadata.Metadata
 
getAggregationFunctionMetadata(ResolvedFunction) - Method in class io.prestosql.metadata.MetadataManager
 
getAggregationMetadata(FunctionBinding) - Method in class io.prestosql.metadata.SqlAggregationFunction
 
getAggregationOperatorUnspillMemoryLimit() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getAggregationOperatorUnspillMemoryLimit(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getAggregations() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getAggregations() - Method in class io.prestosql.sql.planner.plan.StatisticAggregations
 
getAggregations() - Method in class io.prestosql.sql.planner.StatisticsAggregationPlanner.TableStatisticAggregation
 
getAlgorithm() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkEcPublicKey
 
getAlgorithm() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkRsaPublicKey
 
getAllFieldCount() - Method in class io.prestosql.sql.analyzer.RelationType
Gets the count of all fields including hidden fields.
getAllFields() - Method in class io.prestosql.sql.analyzer.Analysis.GroupingSetAnalysis
 
getAllFields() - Method in class io.prestosql.sql.analyzer.RelationType
Gets all fields including hidden fields.
getAllFragments() - Method in class io.prestosql.sql.planner.SubPlan
Flattens the subplan and returns all PlanFragments in the tree
getAllNodes() - Method in class io.prestosql.connector.ConnectorAwareNodeManager
 
getAllNodes() - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
getAllNodes() - Method in class io.prestosql.metadata.InMemoryNodeManager
 
getAllNodes() - Method in interface io.prestosql.metadata.InternalNodeManager
 
getAllNodes() - Method in class io.prestosql.testing.TestingNodeManager
 
getAllNodes(NodeMap, boolean) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
getAllQueries() - Method in class io.prestosql.execution.QueryTracker
 
getAllQueryInfo(String, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.QueryResource
 
getAllQueryInfo(String, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.ui.UiQueryResource
 
getAllQueryTypes() - Static method in class io.prestosql.util.StatementUtils
 
getAllSessionProperties(Session, Map<String, CatalogName>) - Method in class io.prestosql.metadata.SessionPropertyManager
 
getAllSpilledPages() - Method in class io.prestosql.spiller.FileSingleStreamSpiller
 
getAllSpilledPages() - Method in interface io.prestosql.spiller.SingleStreamSpiller
Initiates read of previously spilled pages.
getAllStages(Optional<StageInfo>) - Static method in class io.prestosql.execution.StageInfo
 
getAllTaskInfo() - Method in class io.prestosql.execution.SqlTaskManager
 
getAllTaskInfo() - Method in interface io.prestosql.execution.TaskManager
Gets all of the currently tracked tasks.
getAllTaskInfo(UriInfo) - Method in class io.prestosql.server.TaskResource
 
getAllTasks() - Method in class io.prestosql.execution.SqlStageExecution
 
getAllTasks() - Method in class io.prestosql.execution.SqlTaskManager
 
getAllTransactionInfos() - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getAllTransactionInfos() - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getAllTransactionInfos() - Method in interface io.prestosql.transaction.TransactionManager
 
getAnalysisTime() - Method in class io.prestosql.execution.QueryStats
 
getAnalyzePropertyManager() - Method in interface io.prestosql.metadata.Metadata
 
getAnalyzePropertyManager() - Method in class io.prestosql.metadata.MetadataManager
 
getAnalyzeTarget() - Method in class io.prestosql.sql.analyzer.Analysis
 
getArgumentConventions() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
getArgumentDefinitions() - Method in class io.prestosql.metadata.FunctionMetadata
 
getArgumentDefinitions() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getArgumentDefinitions() - Method in interface io.prestosql.operator.ParametricImplementation
 
getArgumentDefinitions() - Method in class io.prestosql.operator.ParametricImplementationsGroup
 
getArgumentDefinitions() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation
 
getArgumentNativeContainerTypes() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.Parser
 
getArguments() - Method in class io.prestosql.sql.planner.Partitioning
 
getArguments() - Method in class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
getArguments() - Method in class io.prestosql.sql.planner.plan.WindowNode.Function
 
getArguments() - Method in class io.prestosql.sql.relational.CallExpression
 
getArguments() - Method in class io.prestosql.sql.relational.LambdaDefinitionExpression
 
getArguments() - Method in class io.prestosql.sql.relational.SpecialForm
 
getArgumentTypes() - Method in class io.prestosql.metadata.BoundSignature
 
getArgumentTypes() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependency
 
getArgumentTypes() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.OperatorDependency
 
getArgumentTypes() - Method in exception io.prestosql.metadata.OperatorNotFoundException
 
getArgumentTypes() - Method in class io.prestosql.metadata.Signature
 
getArgumentTypes() - Method in class io.prestosql.operator.annotations.OperatorImplementationDependency
 
getArgumentTypes() - Method in class io.prestosql.sql.relational.LambdaDefinitionExpression
 
getArgumentTypes() - Method in class io.prestosql.type.FunctionType
 
getArity() - Method in class io.prestosql.metadata.FunctionBinding
 
getAssetsFile(String, ServletContext) - Method in class io.prestosql.server.ui.WebUiStaticResource
 
getAssignedNode(int) - Method in class io.prestosql.execution.scheduler.BucketNodeMap
 
getAssignedNode(int) - Method in class io.prestosql.execution.scheduler.FixedBucketNodeMap
 
getAssignedNode(int) - Method in class io.prestosql.execution.scheduler.group.DynamicBucketNodeMap
 
getAssignedNode(Split) - Method in class io.prestosql.execution.scheduler.BucketNodeMap
 
getAssignedQueries() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getAssignments() - Method in class io.prestosql.execution.scheduler.SplitPlacementResult
 
getAssignments() - Method in class io.prestosql.memory.MemoryPoolAssignmentsRequest
 
getAssignments() - Method in class io.prestosql.sql.planner.plan.IndexSourceNode
 
getAssignments() - Method in class io.prestosql.sql.planner.plan.ProjectNode
 
getAssignments() - Method in class io.prestosql.sql.planner.plan.TableScanNode
 
getAuthenticatedIdentity() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getAuthenticatedIdentity() - Method in interface io.prestosql.server.SessionContext
 
getAuthenticateHeader() - Method in exception io.prestosql.server.security.AuthenticationException
 
getAuthentication() - Method in class io.prestosql.server.ui.WebUiAuthenticationConfig
 
getAuthenticationTypes() - Method in class io.prestosql.server.security.SecurityConfig
 
getAuthenticator() - Method in class io.prestosql.server.security.CertificateAuthenticatorManager
 
getAuthenticator() - Method in class io.prestosql.server.security.PasswordAuthenticatorManager
 
getAuthenticatorList(SecurityConfig, Map<String, Authenticator>) - Method in class io.prestosql.server.security.ServerSecurityModule
 
getAuthorizationFail() - Method in class io.prestosql.security.AccessControlManager
 
getAuthorizationSuccess() - Method in class io.prestosql.security.AccessControlManager
 
getAuthorizationUri(String, URI) - Method in interface io.prestosql.server.security.oauth2.OAuth2Client
 
getAuthorizationUri(String, URI) - Method in class io.prestosql.server.security.oauth2.ScribeJavaOAuth2Client
 
getAuthUrl() - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
getAvailableProcessors() - Method in class io.prestosql.memory.MemoryInfo
 
getAverageBytesPerRequest() - Method in class io.prestosql.operator.ExchangeClientStatus
 
getAverageRowSize() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
getBackoffDelayNanos() - Method in class io.prestosql.server.remotetask.Backoff
 
getBaseDataDir() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getBaseUrl() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getBasicQueryInfo() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getBasicQueryInfo() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getBasicQueryInfo() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getBasicQueryInfo() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
getBasicQueryInfo() - Method in interface io.prestosql.execution.QueryExecution
 
getBasicQueryInfo() - Method in class io.prestosql.execution.SqlQueryExecution
 
getBasicQueryInfo(Optional<BasicStageStats>) - Method in class io.prestosql.execution.QueryStateMachine
 
getBasicStageStats() - Method in class io.prestosql.execution.scheduler.SqlQueryScheduler
 
getBasicStageStats() - Method in class io.prestosql.execution.SqlStageExecution
 
getBasicStageStats(Supplier<Iterable<TaskInfo>>) - Method in class io.prestosql.execution.StageStateMachine
 
getBasisType() - Method in class io.prestosql.sql.analyzer.Scope.AsteriskedIdentifierChainBasis
 
getBindingId() - Method in class io.prestosql.sql.gen.Binding
 
getBindings() - Method in class io.prestosql.sql.gen.CallSiteBinder
 
getBlock() - Method in interface io.prestosql.operator.aggregation.state.BlockPositionState
 
getBlock() - Method in interface io.prestosql.operator.aggregation.state.BlockState
 
getBlocked() - Method in class io.prestosql.execution.scheduler.ScheduleResult
 
getBlocked() - Method in class io.prestosql.execution.scheduler.SplitPlacementResult
 
getBlocked() - Method in class io.prestosql.operator.WorkProcessor.ProcessState
 
getBlockedDrivers() - Method in class io.prestosql.execution.QueryStats
 
getBlockedDrivers() - Method in class io.prestosql.execution.StageStats
 
getBlockedDrivers() - Method in class io.prestosql.operator.PipelineStats
 
getBlockedDrivers() - Method in class io.prestosql.operator.PipelineStatus
 
getBlockedDrivers() - Method in class io.prestosql.operator.TaskStats
 
getBlockedFuture() - Method in interface io.prestosql.operator.WorkProcessor
 
getBlockedNodes() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getBlockedQuantaWallTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getBlockedQueries() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getBlockedReason() - Method in class io.prestosql.execution.scheduler.ScheduleResult
 
getBlockedReason() - Method in class io.prestosql.operator.OperatorStats
 
getBlockedReasons() - Method in class io.prestosql.execution.BasicStageStats
 
getBlockedReasons() - Method in class io.prestosql.execution.QueryStats
 
getBlockedReasons() - Method in class io.prestosql.execution.StageStats
 
getBlockedReasons() - Method in class io.prestosql.operator.DriverStats
 
getBlockedReasons() - Method in class io.prestosql.operator.PipelineStats
 
getBlockedReasons() - Method in class io.prestosql.operator.TaskStats
 
getBlockedReasons() - Method in class io.prestosql.server.BasicQueryStats
 
getBlockedSplits() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getBlockedWall() - Method in class io.prestosql.operator.OperatorStats
 
getBlockEncodingSerde() - Method in interface io.prestosql.metadata.Metadata
 
getBlockEncodingSerde() - Method in class io.prestosql.metadata.MetadataManager
 
getBlockTypeOperators() - Method in class io.prestosql.testing.LocalQueryRunner
 
getBody() - Method in class io.prestosql.sql.relational.LambdaDefinitionExpression
 
getBoolean() - Method in interface io.prestosql.operator.aggregation.state.NullableBooleanState
 
getBoolean(int) - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
getBoolean(int) - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
getBoolean(int, int) - Method in class io.prestosql.operator.PagesIndex
 
getBoolean(int, int) - Method in class io.prestosql.operator.window.PagesWindowIndex
 
getBoolean(Block, int) - Method in class io.prestosql.type.FunctionType
 
getBoolean(Block, int) - Method in class io.prestosql.type.UnknownType
 
getBound() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedMarker
 
getBoundSignature() - Method in class io.prestosql.metadata.FunctionBinding
 
getBucketCount() - Method in class io.prestosql.execution.scheduler.BucketNodeMap
 
getBucketCount() - Method in class io.prestosql.execution.scheduler.FixedBucketNodeMap
 
getBucketCount() - Method in class io.prestosql.execution.scheduler.group.DynamicBucketNodeMap
 
getBucketNodeMap(Session, PartitioningHandle, boolean) - Method in class io.prestosql.sql.planner.NodePartitioningManager
 
getBuckets() - Method in class io.prestosql.operator.aggregation.ApproximateMostFrequentHistogram
 
getBuckets() - Method in class io.prestosql.operator.aggregation.NumericHistogram
 
getBucketToPartition() - Method in class io.prestosql.sql.planner.NodePartitionMap
 
getBucketToPartition() - Method in class io.prestosql.sql.planner.PartitioningScheme
 
getBufferCount() - Method in class io.prestosql.operator.exchange.LocalExchange
 
getBufferCount() - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeFactory
 
getBufferedBytes() - Method in class io.prestosql.execution.buffer.PageBufferInfo
 
getBufferedBytes() - Method in class io.prestosql.operator.exchange.LocalExchange
 
getBufferedBytes() - Method in class io.prestosql.operator.exchange.LocalExchangeBufferInfo
 
getBufferedBytes() - Method in class io.prestosql.operator.exchange.LocalExchangeMemoryManager
 
getBufferedBytes() - Method in class io.prestosql.operator.ExchangeClientStatus
 
getBufferedDataSize() - Method in class io.prestosql.execution.StageStats
 
getBufferedPages() - Method in class io.prestosql.execution.buffer.BufferInfo
 
getBufferedPages() - Method in class io.prestosql.execution.buffer.PageBufferInfo
 
getBufferedPages() - Method in class io.prestosql.operator.exchange.LocalExchangeBufferInfo
 
getBufferedPages() - Method in class io.prestosql.operator.ExchangeClientStatus
 
getBufferId() - Method in class io.prestosql.execution.buffer.BufferInfo
 
getBufferInfo() - Method in class io.prestosql.operator.exchange.LocalExchangeSource
 
getBufferLocations() - Method in class io.prestosql.execution.QueryExecution.QueryOutputInfo
 
getBuffers() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
getBuffers() - Method in class io.prestosql.execution.buffer.OutputBuffers
 
getBuildChannels() - Method in class io.prestosql.sql.planner.LocalDynamicFilterConsumer
 
getBuildExecutionStrategy() - Method in class io.prestosql.operator.JoinBridgeManager
 
getBuildExecutionStrategy() - Method in class io.prestosql.operator.JoinOperatorFactory.OuterOperatorFactoryResult
 
getBuildOutputTypes() - Method in class io.prestosql.operator.JoinBridgeManager
 
getByte() - Method in interface io.prestosql.operator.aggregation.state.BooleanDistinctState
 
getByte() - Method in interface io.prestosql.operator.aggregation.state.TriStateBooleanState
 
getByte(int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getBytecode(MethodGenerationContext) - Method in class io.prestosql.sql.gen.ArrayMapBytecodeExpression
 
getBytecode(MethodGenerationContext) - Method in class io.prestosql.sql.gen.InvokeFunctionBytecodeExpression
 
getBytecode(MethodGenerationContext) - Method in class io.prestosql.sql.gen.SqlTypeBytecodeExpression
 
getC2() - Method in interface io.prestosql.operator.aggregation.state.CovarianceState
 
getCachedInstance(MethodHandle) - Method in class io.prestosql.sql.gen.CachedInstanceBinder
 
getCacheHitRate() - Method in class io.prestosql.type.BlockTypeOperators
 
getCacheHitRate() - Method in class io.prestosql.type.TypeOperatorsCache
 
getCacheMissRate() - Method in class io.prestosql.type.BlockTypeOperators
 
getCacheMissRate() - Method in class io.prestosql.type.TypeOperatorsCache
 
getCacheRequestCount() - Method in class io.prestosql.type.BlockTypeOperators
 
getCacheRequestCount() - Method in class io.prestosql.type.TypeOperatorsCache
 
getCall(CurrentPath, Metadata) - Static method in class io.prestosql.sql.planner.iterative.rule.DesugarCurrentPath
 
getCall(CurrentUser, Metadata) - Static method in class io.prestosql.sql.planner.iterative.rule.DesugarCurrentUser
 
getCallbackErrorHtml(String) - Method in class io.prestosql.server.security.oauth2.OAuth2Service
 
getCalledArguments() - Method in class io.prestosql.testing.ProcedureTester
 
getCalledName() - Method in class io.prestosql.testing.ProcedureTester
 
getCallSiteBinder() - Method in class io.prestosql.sql.gen.BytecodeGeneratorContext
 
getCallSiteBinder() - Method in class io.prestosql.sql.gen.CachedInstanceBinder
 
getCanceledQueries() - Method in class io.prestosql.execution.QueryManagerStats
 
getCandidates(Object) - Method in class io.prestosql.sql.planner.iterative.RuleIndex
 
getCapacity() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
getCapacity() - Method in class io.prestosql.operator.aggregation.TypedHeap
 
getCapacity() - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
getCapacity() - Method in class io.prestosql.operator.BigintGroupByHash
 
getCapacity() - Method in class io.prestosql.operator.ChannelSet.ChannelSetBuilder
 
getCapacity() - Method in class io.prestosql.operator.DistinctLimitOperator
 
getCapacity() - Method in interface io.prestosql.operator.GroupByHash
 
getCapacity() - Method in class io.prestosql.operator.MarkDistinctHash
 
getCapacity() - Method in class io.prestosql.operator.MarkDistinctOperator
 
getCapacity() - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
getCapacity() - Method in class io.prestosql.operator.NoChannelGroupByHash
 
getCapacity() - Method in class io.prestosql.operator.RowNumberOperator
 
getCapacity() - Method in class io.prestosql.operator.SetBuilderOperator
 
getCapacity() - Method in class io.prestosql.operator.TopNRowNumberOperator
 
getCastableFrom() - Method in class io.prestosql.metadata.TypeVariableConstraint
 
getCastableTo() - Method in class io.prestosql.metadata.TypeVariableConstraint
 
getCastDependencies() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration
 
getCastDependency(Type, Type) - Method in class io.prestosql.sql.relational.SpecialForm
 
getCastInvoker(Type, Type, InvocationConvention) - Method in class io.prestosql.metadata.FunctionDependencies
 
getCastMetadata(Type, Type) - Method in class io.prestosql.metadata.FunctionDependencies
 
getCastSignatureInvoker(TypeSignature, TypeSignature, InvocationConvention) - Method in class io.prestosql.metadata.FunctionDependencies
 
getCatalog() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getCatalog() - Method in class io.prestosql.server.QueryStateInfo
 
getCatalog() - Method in interface io.prestosql.server.SessionContext
 
getCatalog() - Method in class io.prestosql.Session
 
getCatalog() - Method in class io.prestosql.SessionRepresentation
 
getCatalog() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateReference
 
getCatalog() - Method in class io.prestosql.sql.SqlPathElement
 
getCatalog(String) - Method in class io.prestosql.metadata.CatalogManager
 
getCatalogConfigurationDir() - Method in class io.prestosql.metadata.StaticCatalogStoreConfig
 
getCatalogHandle(Session, String) - Method in interface io.prestosql.metadata.Metadata
Returns a connector id for the specified catalog name.
getCatalogHandle(Session, String) - Method in class io.prestosql.metadata.MetadataManager
 
getCatalogManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getCatalogMetadata(TransactionId, CatalogName) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getCatalogMetadata(TransactionId, CatalogName) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getCatalogMetadata(TransactionId, CatalogName) - Method in interface io.prestosql.transaction.TransactionManager
 
getCatalogMetadataForWrite(TransactionId, CatalogName) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getCatalogMetadataForWrite(TransactionId, CatalogName) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getCatalogMetadataForWrite(TransactionId, CatalogName) - Method in interface io.prestosql.transaction.TransactionManager
 
getCatalogMetadataForWrite(TransactionId, String) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getCatalogMetadataForWrite(TransactionId, String) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getCatalogMetadataForWrite(TransactionId, String) - Method in interface io.prestosql.transaction.TransactionManager
 
getCatalogName() - Method in class io.prestosql.connector.CatalogName
 
getCatalogName() - Method in class io.prestosql.connector.informationschema.InformationSchemaTableHandle
 
getCatalogName() - Method in class io.prestosql.execution.Input
 
getCatalogName() - Method in class io.prestosql.metadata.AnalyzeTableHandle
 
getCatalogName() - Method in class io.prestosql.metadata.Catalog
 
getCatalogName() - Method in class io.prestosql.metadata.CatalogMetadata
 
getCatalogName() - Method in class io.prestosql.metadata.IndexHandle
 
getCatalogName() - Method in class io.prestosql.metadata.InsertTableHandle
 
getCatalogName() - Method in class io.prestosql.metadata.NewTableLayout
 
getCatalogName() - Method in class io.prestosql.metadata.OutputTableHandle
 
getCatalogName() - Method in class io.prestosql.metadata.QualifiedObjectName
 
getCatalogName() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
getCatalogName() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
getCatalogName() - Method in class io.prestosql.metadata.Split
 
getCatalogName() - Method in class io.prestosql.metadata.TableHandle
 
getCatalogName() - Method in class io.prestosql.metadata.TableMetadata
 
getCatalogName() - Method in class io.prestosql.operator.SplitOperatorInfo
 
getCatalogName() - Method in class io.prestosql.split.BufferingSplitSource
 
getCatalogName() - Method in class io.prestosql.split.ConnectorAwareSplitSource
 
getCatalogName() - Method in class io.prestosql.split.EmptySplit
 
getCatalogName() - Method in class io.prestosql.split.SampledSplitSource
 
getCatalogName() - Method in interface io.prestosql.split.SplitSource
 
getCatalogName() - Method in class io.prestosql.sql.analyzer.Output
 
getCatalogNames() - Method in class io.prestosql.transaction.TransactionInfo
 
getCatalogNames(Session) - Method in interface io.prestosql.metadata.Metadata
Gets all the loaded catalogs
getCatalogNames(Session) - Method in class io.prestosql.metadata.MetadataManager
 
getCatalogNames(TransactionId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getCatalogNames(TransactionId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getCatalogNames(TransactionId) - Method in interface io.prestosql.transaction.TransactionManager
 
getCatalogProperties() - Method in class io.prestosql.SessionRepresentation
 
getCatalogs() - Method in class io.prestosql.metadata.CatalogManager
 
getCatalogSessionProperties() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getCatalogSessionProperties() - Method in interface io.prestosql.server.SessionContext
 
getCause() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
getChallengeTimeout() - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
getChannel(int) - Method in class io.prestosql.operator.PagesIndex
 
getChannelCount() - Method in class io.prestosql.operator.index.IndexLoader
 
getChannelCount() - Method in class io.prestosql.operator.index.IndexLookupSource
 
getChannelCount() - Method in class io.prestosql.operator.JoinHash
 
getChannelCount() - Method in interface io.prestosql.operator.LookupSource
 
getChannelCount() - Method in class io.prestosql.operator.OuterLookupSource
 
getChannelCount() - Method in class io.prestosql.operator.PagesHash
 
getChannelCount() - Method in interface io.prestosql.operator.PagesHashStrategy
Gets the number of columns appended by this PagesHashStrategy.
getChannelCount() - Method in class io.prestosql.operator.PartitionedLookupSource
 
getChannelCount() - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
getChannelSet() - Method in class io.prestosql.operator.SetBuilderOperator.SetSupplier
 
getChildNodes() - Method in class io.prestosql.sql.gen.ArrayMapBytecodeExpression
 
getChildNodes() - Method in class io.prestosql.sql.gen.InvokeFunctionBytecodeExpression
 
getChildNodes() - Method in class io.prestosql.sql.gen.SqlTypeBytecodeExpression
 
getChildren() - Method in class io.prestosql.operator.GroupByIdBlock
 
getChildren() - Method in class io.prestosql.sql.planner.planprinter.JsonRenderer.JsonRenderedNode
 
getChildren() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getChildren() - Method in class io.prestosql.sql.planner.SubPlan
 
getChoice() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.Parser
 
getChoices() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation
 
getChoices() - Method in class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation
 
getChronology(TimeZoneKey) - Static method in class io.prestosql.util.DateTimeZoneIndex
 
getCidrPrefixLengths() - Method in class io.prestosql.execution.scheduler.SubnetTopologyConfig
 
getClassName() - Method in class io.prestosql.server.ThreadResource.StackLine
 
getClientCapabilities() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getClientCapabilities() - Method in interface io.prestosql.server.SessionContext
 
getClientCapabilities() - Method in class io.prestosql.Session
 
getClientCapabilities() - Method in class io.prestosql.SessionRepresentation
 
getClientId() - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
getClientInfo() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getClientInfo() - Method in class io.prestosql.server.QueryStateInfo
 
getClientInfo() - Method in interface io.prestosql.server.SessionContext
 
getClientInfo() - Method in class io.prestosql.Session
 
getClientInfo() - Method in class io.prestosql.SessionRepresentation
 
getClientSecret() - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
getClientTags() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getClientTags() - Method in interface io.prestosql.server.SessionContext
 
getClientTags() - Method in class io.prestosql.Session
 
getClientTags() - Method in class io.prestosql.SessionRepresentation
 
getClientThreads() - Method in class io.prestosql.operator.ExchangeClientConfig
 
getClientTimeout() - Method in class io.prestosql.execution.QueryManagerConfig
 
getClientTimeout() - Method in class io.prestosql.execution.TaskManagerConfig
 
getClusterMemoryBytes() - Method in class io.prestosql.memory.ClusterMemoryManager
 
getClusterMemoryManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getClusterStats() - Method in class io.prestosql.server.ui.ClusterStatsResource
 
getClusterTotalMemoryReservation() - Method in class io.prestosql.memory.ClusterMemoryManager
 
getClusterUserMemoryReservation() - Method in class io.prestosql.memory.ClusterMemoryManager
 
getCoercion(OperatorType, Type, Type) - Method in interface io.prestosql.metadata.Metadata
 
getCoercion(OperatorType, Type, Type) - Method in class io.prestosql.metadata.MetadataManager
 
getCoercion(Type, Type) - Method in interface io.prestosql.metadata.Metadata
 
getCoercion(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
getCoercion(Expression) - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getCoercion(QualifiedName, Type, Type) - Method in interface io.prestosql.metadata.Metadata
 
getCoercion(QualifiedName, Type, Type) - Method in class io.prestosql.metadata.MetadataManager
 
getCoercions() - Method in class io.prestosql.sql.analyzer.Analysis
 
getCollectionDuration() - Method in class io.prestosql.server.DynamicFilterService.DynamicFilterDomainStats
 
getColumn() - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
getColumn(Field) - Method in class io.prestosql.sql.analyzer.Analysis
 
getColumn(String) - Method in class io.prestosql.metadata.TableMetadata
 
getColumnConstraints() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan.TableColumnInfo
 
getColumnHandleClass() - Method in class io.prestosql.connector.informationschema.InformationSchemaHandleResolver
 
getColumnHandleClass() - Method in class io.prestosql.connector.system.SystemHandleResolver
 
getColumnHandleClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getColumnHandleClass() - Method in class io.prestosql.split.EmptySplitHandleResolver
 
getColumnHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
getColumnHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getColumnHandles(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Gets all of the columns on the specified table, or an empty map if the columns cannot be enumerated.
getColumnHandles(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.testing.TestingMetadata
 
getColumnIndex(String) - Method in class io.prestosql.metadata.InternalTable
 
getColumnMask(ConnectorSecurityContext, SchemaTableName, String, Type) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
getColumnMasks(SecurityContext, QualifiedObjectName, String, Type) - Method in interface io.prestosql.security.AccessControl
 
getColumnMasks(SecurityContext, QualifiedObjectName, String, Type) - Method in class io.prestosql.security.AccessControlManager
 
getColumnMasks(SecurityContext, QualifiedObjectName, String, Type) - Method in class io.prestosql.security.ForwardingAccessControl
 
getColumnMasks(SecurityContext, QualifiedObjectName, String, Type) - Method in class io.prestosql.security.ViewAccessControl
 
getColumnMasks(SecurityContext, QualifiedObjectName, String, Type) - Method in class io.prestosql.testing.TestingAccessControlManager
 
getColumnMasks(Table) - Method in class io.prestosql.sql.analyzer.Analysis
 
getColumnMetadata(Session, TableHandle, ColumnHandle) - Method in interface io.prestosql.metadata.Metadata
Gets the metadata for the specified table column.
getColumnMetadata(Session, TableHandle, ColumnHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getColumnMetadata(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
getColumnMetadata(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
getColumnMetadata(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in class io.prestosql.testing.TestingMetadata
 
getColumnName() - Method in class io.prestosql.connector.informationschema.InformationSchemaColumnHandle
 
getColumnName() - Method in class io.prestosql.connector.system.SystemColumnHandle
 
getColumnName() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint
 
getColumnNames() - Method in class io.prestosql.execution.QueryExecution.QueryOutputInfo
 
getColumnNames() - Method in class io.prestosql.sql.planner.plan.OutputNode
 
getColumnNames() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getColumnPropertyManager() - Method in interface io.prestosql.metadata.Metadata
 
getColumnPropertyManager() - Method in class io.prestosql.metadata.MetadataManager
 
getColumnReferenceFields() - Method in class io.prestosql.sql.analyzer.Analysis
 
getColumnReferences() - Method in class io.prestosql.sql.analyzer.Analysis
 
getColumnReferences() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getColumns() - Method in class io.prestosql.execution.Input
 
getColumns() - Method in class io.prestosql.metadata.TableMetadata
 
getColumns() - Method in class io.prestosql.server.protocol.QueryResultRows
 
getColumns() - Method in class io.prestosql.sql.analyzer.Analysis.Insert
 
getColumns() - Method in class io.prestosql.sql.analyzer.Analysis.RefreshMaterializedViewAnalysis
 
getColumns() - Method in class io.prestosql.sql.planner.Partitioning
 
getColumns() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getColumns() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertReference
 
getColumnStatistics() - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
getColumnTypes() - Method in class io.prestosql.execution.QueryExecution.QueryOutputInfo
 
getColumnTypes() - Method in class io.prestosql.operator.index.FieldSetFilteringRecordSet
 
getColumnTypes() - Method in class io.prestosql.operator.index.PageRecordSet
 
getColumnTypes() - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet
 
getColumnTypes() - Method in class io.prestosql.split.MappedRecordSet
 
getCombineDependencies() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getCombineFunction() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getCombineFunction() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getCommonGroupingColumns() - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
getCommonPartitioning(Session, PartitioningHandle, PartitioningHandle) - Method in interface io.prestosql.metadata.Metadata
Return a partitioning handle which the connector can transparently convert both left and right into.
getCommonPartitioning(Session, PartitioningHandle, PartitioningHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getCommonSuperType() - Method in class io.prestosql.type.TypeCoercion.TypeCompatibility
 
getCommonSuperType(Type, Type) - Method in class io.prestosql.type.TypeCoercion
 
getComparator() - Method in class io.prestosql.operator.PagesIndexOrdering
 
getComparisonOperator(Type) - Method in class io.prestosql.type.BlockTypeOperators
 
getCompletedBytes() - Method in class io.prestosql.connector.informationschema.InformationSchemaPageSource
 
getCompletedBytes() - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
getCompletedBytes() - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
getCompletedBytes() - Method in class io.prestosql.split.MappedPageSource
 
getCompletedDriverGroups() - Method in class io.prestosql.execution.TaskStatus
 
getCompletedDriverGroups() - Method in class io.prestosql.operator.TaskContext
Returns the completed driver groups (excluding taskWide).
getCompletedDrivers() - Method in class io.prestosql.execution.BasicStageStats
 
getCompletedDrivers() - Method in class io.prestosql.execution.QueryStats
 
getCompletedDrivers() - Method in class io.prestosql.execution.StageStats
 
getCompletedDrivers() - Method in class io.prestosql.operator.PipelineStats
 
getCompletedDrivers() - Method in class io.prestosql.operator.TaskStats
 
getCompletedDrivers() - Method in class io.prestosql.server.BasicQueryStats
 
getCompletedQueries() - Method in class io.prestosql.execution.QueryManagerStats
 
getCompletedSplitsLevel0() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getCompletedSplitsLevel1() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getCompletedSplitsLevel2() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getCompletedSplitsLevel3() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getCompletedSplitsLevel4() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getCompletedTasks() - Method in class io.prestosql.execution.QueryStats
 
getCompletedTasks() - Method in class io.prestosql.execution.StageStats
 
getCompletedTasksLevel0() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getCompletedTasksLevel1() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getCompletedTasksLevel2() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getCompletedTasksLevel3() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getCompletedTasksLevel4() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getComplexExpressions() - Method in class io.prestosql.sql.analyzer.Analysis.GroupingSetAnalysis
 
getConcurrentLifespansPerNode(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getConcurrentLifespansPerTask() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getConcurrentRequestMultiplier() - Method in class io.prestosql.operator.ExchangeClientConfig
 
getConfigurationManager() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
getConfiguredEventListeners() - Method in class io.prestosql.testing.TestingEventListenerManager
 
getConnector(CatalogName) - Method in class io.prestosql.metadata.Catalog
 
getConnectorCapabilities() - Method in class io.prestosql.metadata.CatalogMetadata
 
getConnectorCapabilities(Session, CatalogName) - Method in interface io.prestosql.metadata.Metadata
 
getConnectorCapabilities(Session, CatalogName) - Method in class io.prestosql.metadata.MetadataManager
 
getConnectorCatalogName() - Method in class io.prestosql.metadata.Catalog
 
getConnectorHandle() - Method in class io.prestosql.metadata.AnalyzeTableHandle
 
getConnectorHandle() - Method in class io.prestosql.metadata.IndexHandle
 
getConnectorHandle() - Method in class io.prestosql.metadata.InsertTableHandle
 
getConnectorHandle() - Method in class io.prestosql.metadata.OutputTableHandle
 
getConnectorHandle() - Method in class io.prestosql.metadata.TableHandle
 
getConnectorHandle() - Method in class io.prestosql.sql.planner.PartitioningHandle
 
getConnectorId() - Method in class io.prestosql.sql.planner.PartitioningHandle
 
getConnectorId(Session, QualifiedObjectName) - Method in class io.prestosql.metadata.CatalogMetadata
 
getConnectorInfo() - Method in class io.prestosql.execution.Input
 
getConnectorOutputMetadata() - Method in class io.prestosql.operator.TableFinishInfo
 
getConnectorProperties() - Method in class io.prestosql.Session
 
getConnectorProperties(CatalogName) - Method in class io.prestosql.Session
 
getConnectorSessionPropertyMetadata(CatalogName, String) - Method in class io.prestosql.metadata.SessionPropertyManager
 
getConnectorSplit() - Method in class io.prestosql.metadata.Split
 
getConnectorTransaction(TransactionId, CatalogName) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getConnectorTransaction(TransactionId, CatalogName) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getConnectorTransaction(TransactionId, CatalogName) - Method in interface io.prestosql.transaction.TransactionManager
 
getConnectorTransactionHandle() - Method in class io.prestosql.connector.system.SystemTransactionHandle
 
getConstant() - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
getConstants() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
getConstraint() - Method in class io.prestosql.connector.system.SystemSplit
 
getConstraint() - Method in class io.prestosql.connector.system.SystemTableHandle
 
getConstructor() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
getConstructor() - Method in class io.prestosql.sql.gen.VarArgsToArrayAdapterGenerator.MethodHandleAndConstructor
 
getConstructorDependencies() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
getConsumedCpuTimeSecs() - Method in class io.prestosql.execution.QueryManagerStats
 
getConsumedInputBytes() - Method in class io.prestosql.execution.QueryManagerStats
 
getConsumedInputRows() - Method in class io.prestosql.execution.QueryManagerStats
 
getCoordinatorId() - Method in class io.prestosql.execution.QueryIdGenerator
 
getCoordinatorId() - Method in class io.prestosql.memory.MemoryPoolAssignmentsRequest
 
getCoordinatorLocation() - Method in class io.prestosql.dispatcher.DispatchInfo
 
getCoordinatorNodeIds() - Method in class io.prestosql.execution.scheduler.NodeMap
 
getCoordinators() - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
getCoordinators() - Method in class io.prestosql.metadata.InMemoryNodeManager
 
getCoordinators() - Method in interface io.prestosql.metadata.InternalNodeManager
 
getCorrelatedPredicates() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatedNode
 
getCorrelation() - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
getCorrelation() - Method in class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
getCorrelation(CorrelationState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
getCost() - Method in class io.prestosql.sql.planner.iterative.rule.PlanNodeWithCost
 
getCost(int) - Method in class io.prestosql.sql.planner.iterative.Memo
 
getCost(PlanNode) - Method in class io.prestosql.cost.CachingCostProvider
 
getCost(PlanNode) - Method in interface io.prestosql.cost.CostProvider
 
getCostCalculator() - Method in class io.prestosql.testing.LocalQueryRunner
 
getCostEstimationWorkerCount(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getCostProvider() - Method in interface io.prestosql.sql.planner.iterative.Rule.Context
 
getCosts() - Method in class io.prestosql.cost.StatsAndCosts
 
getCount() - Method in interface io.prestosql.operator.aggregation.state.CentralMomentsState
 
getCount() - Method in interface io.prestosql.operator.aggregation.state.CovarianceState
 
getCount() - Method in interface io.prestosql.operator.aggregation.state.VarianceState
 
getCount() - Method in class io.prestosql.sql.planner.plan.LimitNode
 
getCount() - Method in class io.prestosql.sql.planner.plan.OffsetNode
 
getCount() - Method in class io.prestosql.sql.planner.plan.TopNNode
 
getCountSymbols() - Method in class io.prestosql.sql.planner.iterative.rule.SetOperationNodeTranslator.TranslationResult
 
getCovariancePopulation(CovarianceState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
getCovarianceSample(CovarianceState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
getCpuCost() - Method in class io.prestosql.cost.LocalCostEstimate
 
getCpuCost() - Method in class io.prestosql.cost.PlanCostEstimate
Returns CPU component of the cost.
getCpuCost() - Method in class io.prestosql.cost.PlanNodeStatsAndCostSummary
 
getCpuCost() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.EstimatedStatsAndCost
 
getCpuCostWeight() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getCpuInputByteRate() - Method in class io.prestosql.execution.QueryManagerStats
 
getCpuQuotaGenerationMillisPerSecond() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getCpuTimeMillis() - Method in class io.prestosql.server.QueryProgressStats
 
getCpuTimeNanos() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
getCpuUsage() - Method in class io.prestosql.server.ResourceGroupInfo
 
getCreate() - Method in class io.prestosql.sql.analyzer.Analysis
 
getCreatedNanos() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
getCreatedSymbols() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getCreatedTime() - Method in class io.prestosql.execution.TaskStateMachine
 
getCreateTime() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getCreateTime() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getCreateTime() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getCreateTime() - Method in class io.prestosql.execution.QueryStateMachine
 
getCreateTime() - Method in class io.prestosql.execution.QueryStats
 
getCreateTime() - Method in interface io.prestosql.execution.QueryTracker.TrackedQuery
 
getCreateTime() - Method in class io.prestosql.execution.SqlQueryExecution
 
getCreateTime() - Method in class io.prestosql.operator.DriverStats
 
getCreateTime() - Method in class io.prestosql.operator.TaskStats
 
getCreateTime() - Method in class io.prestosql.server.BasicQueryStats
 
getCreateTime() - Method in class io.prestosql.server.QueryStateInfo
 
getCreateTime() - Method in class io.prestosql.transaction.TransactionInfo
 
getCriteria() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode
 
getCriteria() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getCubes() - Method in class io.prestosql.sql.analyzer.Analysis.GroupingSetAnalysis
 
getCumulativeUserMemory() - Method in class io.prestosql.execution.BasicStageStats
 
getCumulativeUserMemory() - Method in class io.prestosql.execution.QueryStats
 
getCumulativeUserMemory() - Method in class io.prestosql.execution.StageStats
 
getCumulativeUserMemory() - Method in class io.prestosql.operator.TaskStats
 
getCumulativeUserMemory() - Method in class io.prestosql.server.BasicQueryStats
 
getCurrentAssignmentVersion() - Method in class io.prestosql.memory.RemoteNodeMemory
 
getCurrentBytes() - Method in class io.prestosql.spiller.SpillSpaceTracker
Returns the number of bytes currently on disk.
getCurrentJoinPosition(LookupSource) - Method in class io.prestosql.operator.JoinProbe
 
getCurrentMemoryBytes() - Method in class io.prestosql.server.QueryProgressStats
 
getCurrentNode() - Method in class io.prestosql.connector.ConnectorAwareNodeManager
 
getCurrentNode() - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
getCurrentNode() - Method in class io.prestosql.metadata.InMemoryNodeManager
 
getCurrentNode() - Method in interface io.prestosql.metadata.InternalNodeManager
 
getCurrentNode() - Method in class io.prestosql.testing.TestingNodeManager
 
getCursorProcessorCache() - Method in class io.prestosql.sql.gen.ExpressionCompiler
 
getDateTimeZone(TimeZoneKey) - Static method in class io.prestosql.util.DateTimeZoneIndex
 
getDeallocatedPreparedStatements() - Method in class io.prestosql.execution.QueryInfo
 
getDeallocatedPreparedStatements() - Method in class io.prestosql.execution.QueryStateMachine
 
getDeclaredSpecializedTypeParameters(Method, Set<TypeParameter>) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
getDefaultCatalog() - Method in class io.prestosql.sql.SqlEnvironmentConfig
 
getDefaultSchema() - Method in class io.prestosql.sql.SqlEnvironmentConfig
 
getDefaultSession() - Method in class io.prestosql.testing.LocalQueryRunner
 
getDefaultSession() - Method in interface io.prestosql.testing.QueryRunner
 
getDefaultValue() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
getDefinitionClass() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getDeleteCookie(boolean) - Static method in class io.prestosql.server.ui.FormWebUiAuthenticationFilter
 
getDependencies() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
getDescription() - Method in class io.prestosql.metadata.FunctionMetadata
 
getDescription() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
getDescription() - Method in class io.prestosql.operator.aggregation.AggregationHeader
 
getDescription() - Method in class io.prestosql.operator.scalar.annotations.ScalarImplementationHeader
 
getDescription() - Method in class io.prestosql.operator.scalar.ScalarHeader
 
getDescription() - Method in class io.prestosql.operator.window.AbstractWindowFunctionSupplier
 
getDescription() - Method in interface io.prestosql.operator.window.WindowFunctionSupplier
 
getDescriptor() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
getDescriptor() - Method in class io.prestosql.sql.planner.StatisticsAggregationPlanner.TableStatisticAggregation
 
getDescriptor(Expression) - Static method in class io.prestosql.sql.DynamicFilters
 
getDestination() - Method in class io.prestosql.sql.analyzer.Analysis.Create
 
getDetails() - Method in class io.prestosql.sql.planner.planprinter.JsonRenderer.JsonRenderedNode
 
getDetails() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getDigest() - Method in interface io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileState
 
getDigest() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.GroupedQuantileDigestAndPercentileState
 
getDigest() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.SingleQuantileDigestAndPercentileState
 
getDigest() - Method in interface io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayState
 
getDigest() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.GroupedTDigestAndPercentileArrayState
 
getDigest() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.SingleTDigestAndPercentileArrayState
 
getDigest() - Method in interface io.prestosql.operator.aggregation.state.TDigestAndPercentileState
 
getDigest() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.GroupedTDigestAndPercentileState
 
getDigest() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.SingleTDigestAndPercentileState
 
getDigest() - Method in interface io.prestosql.type.setdigest.SetDigestState
 
getDigest() - Method in class io.prestosql.type.setdigest.SetDigestStateFactory.GroupedSetDigestState
 
getDigest() - Method in class io.prestosql.type.setdigest.SetDigestStateFactory.SingleSetDigestState
 
getDisabledCatalogs() - Method in class io.prestosql.metadata.StaticCatalogStoreConfig
 
getDiscretePredicates() - Method in class io.prestosql.metadata.TableProperties
 
getDiscreteValuesCount() - Method in class io.prestosql.server.DynamicFilterService.DynamicFilterDomainStats
 
getDispatchedFuture() - Method in interface io.prestosql.dispatcher.DispatchQuery
 
getDispatchedFuture() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getDispatchedFuture() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getDispatchInfo() - Method in interface io.prestosql.dispatcher.DispatchQuery
 
getDispatchInfo() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getDispatchInfo() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getDispatchInfo(QueryId) - Method in class io.prestosql.dispatcher.DispatchManager
 
getDispatchingTime() - Method in class io.prestosql.execution.QueryStats
 
getDispatchManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getDisplayLabel(Type, boolean) - Static method in class io.prestosql.type.TypeUtils
 
getDisplayName() - Method in class io.prestosql.type.FunctionType
 
getDistinctFromOperator(Type) - Method in class io.prestosql.type.BlockTypeOperators
 
getDistinctSymbols() - Method in class io.prestosql.sql.planner.plan.DistinctLimitNode
 
getDistinctSymbols() - Method in class io.prestosql.sql.planner.plan.MarkDistinctNode
 
getDistinctValuesCount() - Method in class io.prestosql.cost.StatisticRange
 
getDistinctValuesCount() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
getDistribution() - Method in class io.prestosql.connector.system.CatalogSystemTable
 
getDistribution() - Method in class io.prestosql.connector.system.jdbc.JdbcTable
 
getDistribution() - Method in class io.prestosql.connector.system.NodeSystemTable
 
getDistribution() - Method in class io.prestosql.connector.system.QuerySystemTable
 
getDistribution() - Method in class io.prestosql.connector.system.RuleStatsSystemTable
 
getDistribution() - Method in class io.prestosql.connector.system.TableCommentSystemTable
 
getDistribution() - Method in class io.prestosql.connector.system.TaskSystemTable
 
getDistribution() - Method in class io.prestosql.connector.system.TransactionsSystemTable
 
getDistribution() - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
getDistributionType() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getDistributionType() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getDistributionType() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getDomain() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint
 
getDomainBase() - Method in class io.prestosql.server.JmxNamingConfig
 
getDouble() - Method in interface io.prestosql.operator.aggregation.state.DoubleState
 
getDouble() - Method in interface io.prestosql.operator.aggregation.state.LongAndDoubleState
 
getDouble() - Method in interface io.prestosql.operator.aggregation.state.NullableDoubleState
 
getDouble(int) - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
getDouble(int) - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
getDouble(int, int) - Method in class io.prestosql.operator.PagesIndex
 
getDouble(int, int) - Method in class io.prestosql.operator.window.PagesWindowIndex
 
getDouble(Block, int) - Method in class io.prestosql.type.FunctionType
 
getDriverContext() - Method in class io.prestosql.operator.Driver
 
getDriverContext() - Method in class io.prestosql.operator.OperatorContext
 
getDriverFactories() - Method in class io.prestosql.sql.planner.LocalExecutionPlanner.LocalExecutionPlan
 
getDriverInstances() - Method in class io.prestosql.operator.DriverFactory
 
getDrivers() - Method in class io.prestosql.operator.PipelineStats
 
getDriverStats() - Method in class io.prestosql.operator.DriverContext
 
getDriverYieldSignal() - Method in class io.prestosql.operator.ProcessorContext
 
getDurationType() - Method in class io.prestosql.operator.scalar.QuarterOfYearDateTimeField
 
getDynamicConjuncts() - Method in class io.prestosql.sql.DynamicFilters.ExtractResult
 
getDynamicFilterDomains() - Method in class io.prestosql.execution.DynamicFiltersCollector.VersionedDynamicFilterDomains
 
getDynamicFilterDomains() - Method in class io.prestosql.sql.planner.LocalDynamicFilterConsumer
 
getDynamicFilterDomainStats() - Method in class io.prestosql.server.DynamicFilterService.DynamicFiltersStats
 
getDynamicFilterId() - Method in class io.prestosql.server.DynamicFilterService.DynamicFilterDomainStats
 
getDynamicFilterId() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getDynamicFilteringStats(QueryId, Session) - Method in class io.prestosql.server.DynamicFilterService
 
getDynamicFilters() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getDynamicFiltersCompleted() - Method in class io.prestosql.server.DynamicFilterService.DynamicFiltersStats
 
getDynamicFilterSplitsProcessed() - Method in class io.prestosql.operator.OperatorStats
 
getDynamicFilterSplitsProcessed() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
getDynamicFilterSplitsProcessed() - Method in class io.prestosql.operator.TableScanWorkProcessorOperator
 
getDynamicFilterSplitsProcessed() - Method in interface io.prestosql.operator.WorkProcessorSourceOperator
 
getDynamicFiltersStats() - Method in class io.prestosql.execution.QueryStats
 
getDynamicFiltersVersion() - Method in class io.prestosql.execution.DynamicFiltersCollector
 
getDynamicFiltersVersion() - Method in class io.prestosql.execution.TaskStatus
 
getDynamicFiltersVersion() - Method in class io.prestosql.operator.TaskContext
 
getEdges(PlanNode) - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
getElapsedTime() - Method in class io.prestosql.dispatcher.DispatchInfo
 
getElapsedTime() - Method in class io.prestosql.execution.QueryStats
 
getElapsedTime() - Method in class io.prestosql.operator.DriverStats
 
getElapsedTime() - Method in class io.prestosql.operator.PipelineStats
 
getElapsedTime() - Method in class io.prestosql.operator.TaskStats
 
getElapsedTime() - Method in class io.prestosql.server.BasicQueryStats
 
getElapsedTimeMillis() - Method in class io.prestosql.server.QueryProgressStats
 
getEncoded() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkEcPublicKey
 
getEncoded() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkRsaPublicKey
 
getEncodingName() - Method in class io.prestosql.operator.GroupByIdBlock
 
getEndChannel() - Method in class io.prestosql.operator.window.FrameInfo
 
getEndTime() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getEndTime() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getEndTime() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getEndTime() - Method in class io.prestosql.execution.QueryStateMachine
 
getEndTime() - Method in class io.prestosql.execution.QueryStats
 
getEndTime() - Method in interface io.prestosql.execution.QueryTracker.TrackedQuery
 
getEndTime() - Method in class io.prestosql.execution.SqlQueryExecution
 
getEndTime() - Method in class io.prestosql.operator.DriverStats
 
getEndTime() - Method in class io.prestosql.operator.TaskStats
 
getEndTime() - Method in class io.prestosql.server.BasicQueryStats
 
getEndType() - Method in class io.prestosql.operator.window.FrameInfo
 
getEndType() - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
getEndValue() - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
getEnforcedConstraint() - Method in class io.prestosql.sql.planner.plan.TableScanNode
A TupleDomain that represents a predicate that has been successfully pushed into this TableScan node.
getEntryCount() - Method in class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
 
getEntryCount() - Method in interface io.prestosql.operator.aggregation.multimapagg.MultimapAggregationState
 
getEntryCount() - Method in class io.prestosql.operator.aggregation.multimapagg.SingleMultimapAggregationState
 
getEnvironment() - Method in class io.prestosql.connector.ConnectorAwareNodeManager
 
getEnvironment() - Method in class io.prestosql.execution.resourcegroups.ResourceGroupConfigurationManagerContextInstance
 
getEnvironment() - Method in class io.prestosql.server.NodeStatus
 
getEnvironment() - Method in class io.prestosql.server.SessionPropertyConfigurationManagerContextInstance
 
getEnvironment() - Method in class io.prestosql.server.ui.ClusterResource.ClusterInfo
 
getEnvironment() - Method in class io.prestosql.testing.TestingNodeManager
 
getEqualOperator(Type) - Method in class io.prestosql.type.BlockTypeOperators
 
getEquivalentClasses() - Method in class io.prestosql.util.DisjointSet
 
getErrorCode() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getErrorCode() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getErrorCode() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
getErrorCode() - Method in exception io.prestosql.execution.Failure
 
getErrorCode() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
getErrorCode() - Method in class io.prestosql.execution.QueryInfo
 
getErrorCode() - Method in class io.prestosql.server.BasicQueryInfo
 
getErrorLocation() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
getErrorType() - Method in class io.prestosql.execution.QueryInfo
 
getErrorType() - Method in class io.prestosql.server.BasicQueryInfo
 
getEstimate() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan
 
getEstimate() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan.TableColumnInfo
 
getEstimatedCost() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getEstimatedExchangesCostCalculator() - Method in class io.prestosql.testing.LocalQueryRunner
 
getEstimatedMemorySizeInBytes() - Method in class io.prestosql.operator.PagesRTreeIndex.GeometryWithPosition
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
 
getEstimatedSize() - Method in interface io.prestosql.operator.aggregation.Accumulator
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.arrayagg.SingleArrayAggregationState
 
getEstimatedSize() - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.histogram.GroupedHistogramState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.histogram.SingleHistogramState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
getEstimatedSize() - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.histogram.ValueStore
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory.SingleLongApproximateMostFrequentState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.GroupedMinMaxByNState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.SingleMinMaxByNState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.multimapagg.SingleMultimapAggregationState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory.GroupedState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory.SingleState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.GroupedHyperLogLogState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.SingleHyperLogLogState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.GroupedState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.SingleState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.GroupedLongDecimalWithOverflowAndLongState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.SingleLongDecimalWithOverflowAndLongState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.GroupedMinMaxNState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.SingleMinMaxNState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.GroupedQuantileDigestAndPercentileState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.SingleQuantileDigestAndPercentileState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.GroupedQuantileDigestState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.SingleQuantileDigestState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.GroupedTDigestAndPercentileArrayState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.SingleTDigestAndPercentileArrayState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.GroupedTDigestAndPercentileState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.SingleTDigestAndPercentileState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory.GroupedTDigestState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory.SingleTDigestState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory.SingleLongApproximateMostFrequentState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.TypedHeap
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
getEstimatedSize() - Method in class io.prestosql.operator.BigintGroupByHash
 
getEstimatedSize() - Method in class io.prestosql.operator.ChannelSet.ChannelSetBuilder
 
getEstimatedSize() - Method in interface io.prestosql.operator.GroupByHash
 
getEstimatedSize() - Method in class io.prestosql.operator.MarkDistinctHash
 
getEstimatedSize() - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
getEstimatedSize() - Method in class io.prestosql.operator.NestedLoopJoinPages
 
getEstimatedSize() - Method in class io.prestosql.operator.NestedLoopJoinPagesBuilder
 
getEstimatedSize() - Method in class io.prestosql.operator.NoChannelGroupByHash
 
getEstimatedSize() - Method in class io.prestosql.operator.PagesIndex
 
getEstimatedSize() - Method in class io.prestosql.operator.PagesSpatialIndexSupplier
 
getEstimatedSize() - Method in class io.prestosql.type.setdigest.SetDigestStateFactory.GroupedSetDigestState
 
getEstimatedSize() - Method in class io.prestosql.type.setdigest.SetDigestStateFactory.SingleSetDigestState
 
getEstimatedSizeInBytes() - Method in class io.prestosql.operator.ChannelSet
 
getEstimatedSizeInBytes() - Method in class io.prestosql.operator.GroupedTopNBuilder
 
getEstimatedStats() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getEventListenerFiles() - Method in class io.prestosql.eventlistener.EventListenerConfig
 
getExactImplementations() - Method in class io.prestosql.operator.ParametricImplementationsGroup
 
getExchangeDataIntegrityVerification() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getExchangeType() - Method in class io.prestosql.sql.planner.plan.RemoteSourceNode
 
getExclusiveLock() - Method in class io.prestosql.testing.LocalQueryRunner
 
getExclusiveLock() - Method in interface io.prestosql.testing.QueryRunner
 
getExecutionPolicy(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getExecutionStartTime() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getExecutionStartTime() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getExecutionStartTime() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getExecutionStartTime() - Method in class io.prestosql.execution.QueryStateMachine
 
getExecutionStartTime() - Method in class io.prestosql.execution.QueryStats
 
getExecutionStartTime() - Method in interface io.prestosql.execution.QueryTracker.TrackedQuery
 
getExecutionStartTime() - Method in class io.prestosql.execution.SqlQueryExecution
 
getExecutionTime() - Method in class io.prestosql.execution.QueryManagerStats
 
getExecutionTime() - Method in class io.prestosql.execution.QueryStats
 
getExecutionTime() - Method in class io.prestosql.server.BasicQueryStats
 
getExecutor() - Method in class io.prestosql.dispatcher.DispatchExecutor.DispatchExecutorMBeans
 
getExecutor() - Method in class io.prestosql.dispatcher.DispatchExecutor
 
getExecutor() - Method in class io.prestosql.execution.QueryExecutionMBean
 
getExecutor() - Method in class io.prestosql.execution.SqlQueryManager
 
getExecutor() - Method in class io.prestosql.execution.TaskManagementExecutor
 
getExecutor() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector
 
getExecutor() - Method in class io.prestosql.operator.ExchangeClientFactory
 
getExecutor() - Method in class io.prestosql.server.ExchangeExecutionMBean
 
getExecutor() - Method in class io.prestosql.server.HttpRemoteTaskFactory
 
getExecutor() - Method in class io.prestosql.testing.LocalQueryRunner
 
getExistsSubqueries() - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getExistsSubqueries() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getExistsSubqueries(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getExpandableBaseScope(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getExpectedHashCollisions() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
getExpectedHashCollisions() - Method in class io.prestosql.operator.BigintGroupByHash
 
getExpectedHashCollisions() - Method in interface io.prestosql.operator.GroupByHash
 
getExpectedHashCollisions() - Method in class io.prestosql.operator.JoinHashSupplier
 
getExpectedHashCollisions() - Method in interface io.prestosql.operator.LookupSourceSupplier
 
getExpectedHashCollisions() - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
getExpectedHashCollisions() - Method in class io.prestosql.operator.NoChannelGroupByHash
 
getExpectedHashCollisions() - Method in class io.prestosql.operator.PagesHash
 
getExpectedSize() - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
getExpectedSize() - Method in class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
getExpectedSize() - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
getExpirationGraceInterval() - Method in class io.prestosql.failuredetector.FailureDetectorConfig
 
getExpression() - Method in class io.prestosql.metadata.LongVariableConstraint
 
getExpression() - Method in class io.prestosql.sql.analyzer.Analysis.SelectExpression
 
getExpression() - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
getExpressionCacheSize() - Method in class io.prestosql.sql.planner.CompilerConfig
 
getExpressionCoercions() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getExpressionCompiler() - Method in class io.prestosql.testing.LocalQueryRunner
 
getExpressions() - Method in class io.prestosql.sql.planner.plan.Assignments
 
getExpressionTypes() - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getExpressionTypes() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getExternalAddress() - Method in class io.prestosql.server.NodeStatus
 
getExternalFailures() - Method in class io.prestosql.execution.QueryManagerStats
 
getExtraCredentials() - Method in class io.prestosql.server.TaskUpdateRequest
 
getFactory() - Method in class io.prestosql.operator.aggregation.AggregationMetadata.AccumulatorStateDescriptor
 
getFailed() - Method in interface io.prestosql.failuredetector.FailureDetector
 
getFailed() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector
 
getFailed() - Method in class io.prestosql.failuredetector.NoOpFailureDetector
 
getFailed() - Method in class io.prestosql.server.NodeResource
 
getFailedCount() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector
 
getFailedQueries() - Method in class io.prestosql.execution.QueryManagerStats
 
getFailedTasks() - Method in class io.prestosql.execution.SqlTaskManager
 
getFailureCause() - Method in class io.prestosql.execution.StageInfo
 
getFailureCauses() - Method in class io.prestosql.execution.TaskStateMachine
 
getFailureCount() - Method in class io.prestosql.server.remotetask.Backoff
 
getFailureDuration() - Method in class io.prestosql.server.remotetask.Backoff
 
getFailureInfo() - Method in class io.prestosql.dispatcher.DispatchInfo
 
getFailureInfo() - Method in class io.prestosql.execution.QueryInfo
 
getFailureInfo() - Method in class io.prestosql.execution.QueryStateMachine
 
getFailureRatioThreshold() - Method in class io.prestosql.failuredetector.FailureDetectorConfig
 
getFailureRequestTimeTotal() - Method in class io.prestosql.server.remotetask.Backoff
 
getFailures() - Method in class io.prestosql.execution.TaskStatus
 
getFailures() - Method in class io.prestosql.sql.planner.iterative.RuleStats
 
getFailures() - Method in class io.prestosql.sql.planner.optimizations.OptimizerStats
 
getField() - Method in class io.prestosql.sql.analyzer.ResolvedField
 
getField() - Method in class io.prestosql.sql.relational.InputReferenceExpression
 
getField(int) - Method in class io.prestosql.sql.analyzer.Scope
 
getField(int) - Method in class io.prestosql.testing.MaterializedRow
 
getField(Chronology) - Method in class io.prestosql.operator.scalar.QuarterOfYearDateTimeField
 
getFieldByIndex(int) - Method in class io.prestosql.sql.analyzer.RelationType
Gets the field at the specified index.
getFieldCount() - Method in class io.prestosql.testing.MaterializedRow
 
getFieldId() - Method in class io.prestosql.sql.analyzer.ResolvedField
 
getFieldIndex() - Method in class io.prestosql.sql.analyzer.FieldId
Returns field index of the field in the containing relation.
getFieldNames() - Method in class io.prestosql.execution.QueryInfo
 
getFieldNames() - Method in class io.prestosql.sql.planner.StageExecutionPlan
 
getFieldNameToIndex(List<RowType.Field>) - Static method in class io.prestosql.util.JsonUtil
 
getFields() - Method in class io.prestosql.sql.planner.NodeAndMappings
 
getFields() - Method in class io.prestosql.testing.MaterializedRow
 
getFile() - Method in class io.prestosql.server.ThreadResource.StackLine
 
getFile(String, ServletContext) - Method in class io.prestosql.server.ui.WebUiStaticResource
 
getFile(SecurityContext) - Method in class io.prestosql.server.ui.LoginResource
 
getFilter() - Method in class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
getFilter() - Method in class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
getFilter() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getFilter() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getFilter() - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
getFilterAndProjectMinOutputPageRowCount() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getFilterAndProjectMinOutputPageRowCount(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getFilterAndProjectMinOutputPageSize() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getFilterAndProjectMinOutputPageSize(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getFilterCache() - Method in class io.prestosql.sql.gen.PageFunctionCompiler
 
getFilteringSource() - Static method in class io.prestosql.sql.planner.plan.Patterns.SemiJoin
 
getFilteringSource() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getFilteringSourceHashSymbol() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getFilteringSourceJoinSymbol() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getFilters() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
getFinalAggregation() - Method in class io.prestosql.sql.planner.plan.StatisticAggregations.Parts
 
getFinalQueryInfo() - Method in class io.prestosql.execution.QueryStateMachine
 
getFinalType() - Method in interface io.prestosql.operator.aggregation.Accumulator
 
getFinalType() - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
getFinalType() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
getFinishCalls() - Method in class io.prestosql.operator.OperatorStats
 
getFinishCpu() - Method in class io.prestosql.operator.OperatorStats
 
getFinishedFuture() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
getFinishingTime() - Method in class io.prestosql.execution.QueryStats
 
getFinishWall() - Method in class io.prestosql.operator.OperatorStats
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanAndBlockPositionValueState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanBooleanState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanDoubleState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanLongState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleAndBlockPositionValueState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleBooleanState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleDoubleState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleLongState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.LongAndBlockPositionValueState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.LongBooleanState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.LongDoubleState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.LongLongState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectAndBlockPositionValueState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectBooleanState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectDoubleState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectLongState
 
getFirstStartTime() - Method in class io.prestosql.operator.PipelineStats
 
getFirstStartTime() - Method in class io.prestosql.operator.TaskStats
 
getFixedManagementUser() - Method in class io.prestosql.server.security.SecurityConfig
 
getFixedSize() - Method in class io.prestosql.type.IpAddressType
 
getFixedSize() - Method in class io.prestosql.type.UnknownType
 
getFixedSize() - Method in class io.prestosql.type.UuidType
 
getForcedSessionTimeZone() - Method in class io.prestosql.sql.SqlEnvironmentConfig
 
getForm() - Method in class io.prestosql.sql.relational.SpecialForm
 
getFormat() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkEcPublicKey
 
getFormat() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkRsaPublicKey
 
getFormattedSql(Statement, SqlParser) - Static method in class io.prestosql.sql.SqlFormatterUtil
 
getForSubplan(PlanNode) - Method in class io.prestosql.cost.StatsAndCosts
 
getFragment() - Method in class io.prestosql.execution.SqlStageExecution
 
getFragment() - Method in class io.prestosql.execution.StageStateMachine
 
getFragment() - Method in class io.prestosql.server.TaskUpdateRequest
 
getFragment() - Method in class io.prestosql.sql.planner.StageExecutionPlan
 
getFragment() - Method in class io.prestosql.sql.planner.SubPlan
 
getFragmentId() - Method in class io.prestosql.execution.Input
 
getFragmentSymbol() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getFrame() - Method in class io.prestosql.operator.window.FramedWindowFunction
 
getFrame() - Method in class io.prestosql.sql.planner.plan.WindowNode.Function
 
getFrameBoundCalculation(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
getFrameBoundCalculations() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getFrameInfo() - Method in class io.prestosql.operator.WindowFunctionDefinition
 
getFrames() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getFreeBytes() - Method in class io.prestosql.memory.MemoryPool
Returns the number of free bytes.
getFreeDistributedBytes() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getFreeFuture() - Method in class io.prestosql.operator.ReferenceCount
 
getFreeReferencesToLambdaArgument(Node, Analysis) - Static method in class io.prestosql.sql.analyzer.FreeLambdaReferenceExtractor
 
getFromType() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.CastDependency
 
getFromType() - Method in class io.prestosql.operator.annotations.CastImplementationDependency
 
getFullGcCount() - Method in class io.prestosql.execution.TaskStatus
 
getFullGcCount() - Method in class io.prestosql.operator.TaskContext
 
getFullGcCount() - Method in class io.prestosql.operator.TaskStats
 
getFullGcTime() - Method in class io.prestosql.execution.TaskStatus
 
getFullGcTime() - Method in class io.prestosql.operator.TaskContext
 
getFullGcTime() - Method in class io.prestosql.operator.TaskStats
 
getFullInfo() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getFullQueryInfo() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getFullQueryInfo() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getFullQueryInfo() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
getFullQueryInfo(QueryId) - Method in class io.prestosql.dispatcher.DispatchManager
 
getFullQueryInfo(QueryId) - Method in interface io.prestosql.execution.QueryManager
 
getFullQueryInfo(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
getFullQueryInfo(QueryId) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getFullyQualifiedName() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
getFunction() - Method in class io.prestosql.operator.window.FramedWindowFunction
 
getFunction() - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
getFunctionDependencies() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration
 
getFunctionDependencies() - Method in class io.prestosql.metadata.ResolvedFunction
 
getFunctionDependencies() - Method in interface io.prestosql.metadata.SqlFunction
 
getFunctionDependencies() - Method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
getFunctionDependencies() - Method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxBy
 
getFunctionDependencies() - Method in class io.prestosql.operator.aggregation.ParametricAggregation
 
getFunctionDependencies() - Method in class io.prestosql.operator.scalar.AbstractGreatestLeast
 
getFunctionDependencies() - Method in class io.prestosql.operator.scalar.ArrayJoin.ArrayJoinWithNullReplacement
 
getFunctionDependencies() - Method in class io.prestosql.operator.scalar.ArrayJoin
 
getFunctionDependencies() - Method in class io.prestosql.operator.scalar.ArrayToArrayCast
 
getFunctionDependencies() - Method in class io.prestosql.operator.scalar.MapConstructor
 
getFunctionDependencies() - Method in class io.prestosql.operator.scalar.MapElementAtFunction
 
getFunctionDependencies() - Method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
getFunctionDependencies() - Method in class io.prestosql.operator.scalar.MapToMapCast
 
getFunctionDependencies() - Method in class io.prestosql.operator.scalar.ParametricScalar
 
getFunctionDependencies() - Method in class io.prestosql.operator.scalar.TryCastFunction
 
getFunctionDependencies() - Method in class io.prestosql.sql.relational.SpecialForm
 
getFunctionDependencies(FunctionBinding) - Method in class io.prestosql.metadata.FunctionRegistry
 
getFunctionDependencies(FunctionBinding) - Method in interface io.prestosql.metadata.SqlFunction
 
getFunctionDependencies(FunctionBinding) - Method in class io.prestosql.operator.scalar.FormatFunction
 
getFunctionDependencies(FunctionBinding) - Method in class io.prestosql.operator.scalar.RowToRowCast
 
getFunctionId() - Method in class io.prestosql.metadata.FunctionBinding
 
getFunctionId() - Method in class io.prestosql.metadata.FunctionMetadata
 
getFunctionId() - Method in class io.prestosql.metadata.ResolvedFunction
 
getFunctionInvoker(QualifiedName, List<Type>, InvocationConvention) - Method in class io.prestosql.metadata.FunctionDependencies
 
getFunctionMetadata() - Method in class io.prestosql.metadata.SqlAggregationFunction
 
getFunctionMetadata() - Method in interface io.prestosql.metadata.SqlFunction
 
getFunctionMetadata() - Method in class io.prestosql.metadata.SqlScalarFunction
 
getFunctionMetadata() - Method in class io.prestosql.operator.window.SqlWindowFunction
 
getFunctionMetadata(ResolvedFunction) - Method in interface io.prestosql.metadata.Metadata
 
getFunctionMetadata(ResolvedFunction) - Method in class io.prestosql.metadata.MetadataManager
 
getFunctionMetadata(QualifiedName, List<Type>) - Method in class io.prestosql.metadata.FunctionDependencies
 
getFunctions() - Method in class io.prestosql.metadata.FunctionListBuilder
 
getFunctionSignatureInvoker(QualifiedName, List<TypeSignature>, InvocationConvention) - Method in class io.prestosql.metadata.FunctionDependencies
 
getGcInfo() - Method in class io.prestosql.execution.StageStats
 
getGeneralPool() - Method in class io.prestosql.memory.LocalMemoryManager
 
getGenericAccumulatorFactoryBinder() - Method in class io.prestosql.operator.aggregation.LazyAccumulatorFactoryBinder
 
getGenericImplementations() - Method in class io.prestosql.operator.ParametricImplementationsGroup
 
getGeometry() - Method in class io.prestosql.operator.PagesRTreeIndex.GeometryWithPosition
 
getGetOutputCalls() - Method in class io.prestosql.operator.OperatorStats
 
getGetOutputCpu() - Method in class io.prestosql.operator.OperatorStats
 
getGetOutputWall() - Method in class io.prestosql.operator.OperatorStats
 
getGetSplitDistribution() - Method in class io.prestosql.execution.StageStats
 
getGetSplitTime() - Method in class io.prestosql.execution.scheduler.SplitSchedulerStats
 
getGlobalCpuTimeMicros() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getGlobalGroupingSets() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getGlobalGroupingSets() - Method in class io.prestosql.sql.planner.plan.AggregationNode.GroupingSetDescriptor
 
getGlobalScheduledTimeMicros() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getGracefulShutdownHandler() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getGracePeriod() - Method in class io.prestosql.server.ServerConfig
 
getGrantees() - Method in class io.prestosql.connector.informationschema.InformationSchemaTableHandle
 
getGraphvizPlan(Session, Statement, ExplainType.Type, List<Expression>, WarningCollector) - Method in class io.prestosql.sql.analyzer.QueryExplainer
 
getGroupCount() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
getGroupCount() - Method in class io.prestosql.operator.BigintGroupByHash
 
getGroupCount() - Method in interface io.prestosql.operator.GroupByHash
 
getGroupCount() - Method in class io.prestosql.operator.GroupByIdBlock
 
getGroupCount() - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
getGroupCount() - Method in class io.prestosql.operator.NoChannelGroupByHash
 
getGroupCount() - Method in class io.prestosql.sql.planner.iterative.Memo
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.histogram.HistogramStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.type.setdigest.SetDigestStateFactory
 
getGroupId() - Method in class io.prestosql.operator.aggregation.state.AbstractGroupedAccumulatorState
 
getGroupId() - Method in class io.prestosql.sql.planner.iterative.GroupReference
 
getGroupId(int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getGroupIds(Page) - Method in class io.prestosql.operator.BigintGroupByHash
 
getGroupIds(Page) - Method in interface io.prestosql.operator.GroupByHash
 
getGroupIds(Page) - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
getGroupIds(Page) - Method in class io.prestosql.operator.NoChannelGroupByHash
 
getGroupIdsSortingSize() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
building hash sorted results requires memory for sorting group IDs.
getGroupIdSymbol() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getGroupIdSymbol() - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
getGrouping() - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
getGroupingColumns() - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
getGroupingKeys() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getGroupingKeys() - Method in class io.prestosql.sql.planner.plan.AggregationNode.GroupingSetDescriptor
 
getGroupingOperations(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
getGroupingSetCount() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getGroupingSetCount() - Method in class io.prestosql.sql.planner.plan.AggregationNode.GroupingSetDescriptor
 
getGroupingSets() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getGroupingSets() - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
getGroupingSets(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
getGroupingSymbols() - Method in class io.prestosql.sql.planner.plan.StatisticAggregations
 
getGroupProvider() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getGroupProvider() - Method in class io.prestosql.testing.LocalQueryRunner
 
getGroupProvider() - Method in interface io.prestosql.testing.QueryRunner
 
getGroups() - Method in class io.prestosql.SessionRepresentation
 
getGroups(String) - Method in class io.prestosql.security.GroupProviderManager
 
getGroups(String) - Method in class io.prestosql.testing.TestingGroupProvider
 
getGSSName(GSSManager, String, String) - Method in enum io.prestosql.server.security.KerberosNameType
 
getHandle() - Method in class io.prestosql.sql.planner.Partitioning
 
getHandle() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode.WriteStatisticsHandle
 
getHandle() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode.WriteStatisticsReference
 
getHandle() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateTarget
 
getHandle() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.DeleteTarget
 
getHandle() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertReference
 
getHandle() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertTarget
 
getHandleResolver() - Method in class io.prestosql.connector.system.GlobalSystemConnectorFactory
 
getHardConcurrencyLimit() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getHardConcurrencyLimit() - Method in class io.prestosql.server.ResourceGroupInfo
 
getHardCpuLimit() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getHash(long, long) - Static method in class io.prestosql.operator.scalar.CombineHashFunction
 
getHashCodeOperator(Type) - Method in class io.prestosql.type.BlockTypeOperators
 
getHashCollisions() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
getHashCollisions() - Method in class io.prestosql.operator.BigintGroupByHash
 
getHashCollisions() - Method in interface io.prestosql.operator.GroupByHash
 
getHashCollisions() - Method in class io.prestosql.operator.JoinHashSupplier
 
getHashCollisions() - Method in interface io.prestosql.operator.LookupSourceSupplier
 
getHashCollisions() - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
getHashCollisions() - Method in class io.prestosql.operator.NoChannelGroupByHash
 
getHashCollisions() - Method in class io.prestosql.operator.PagesHash
 
getHashColumn() - Method in class io.prestosql.sql.planner.PartitioningScheme
 
getHashCounts() - Method in class io.prestosql.type.setdigest.SetDigest
 
getHashExpression(Metadata, SymbolAllocator, List<Symbol>) - Static method in class io.prestosql.sql.planner.optimizations.HashGenerationOptimizer
 
getHashPartitionCount(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getHashStrategiesStats() - Method in class io.prestosql.sql.gen.JoinCompiler
 
getHashSymbol() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getHashSymbol() - Method in class io.prestosql.sql.planner.plan.DistinctLimitNode
 
getHashSymbol() - Method in class io.prestosql.sql.planner.plan.MarkDistinctNode
 
getHashSymbol() - Method in class io.prestosql.sql.planner.plan.RowNumberNode
 
getHashSymbol() - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
getHashSymbol() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getHaving(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
getHeader() - Method in class io.prestosql.operator.scalar.annotations.ScalarImplementationHeader
 
getHeapAvailable() - Method in class io.prestosql.server.NodeStatus
 
getHeapHeadroom() - Method in class io.prestosql.memory.NodeMemoryConfig
 
getHeapUsed() - Method in class io.prestosql.server.NodeStatus
 
getHeartbeatInterval() - Method in class io.prestosql.failuredetector.FailureDetectorConfig
 
getHierarchyFieldIndex() - Method in class io.prestosql.sql.analyzer.ResolvedField
 
getHigh() - Method in class io.prestosql.cost.StatisticRange
 
getHigh() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedRange
 
getHighValue() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
getHits() - Method in class io.prestosql.sql.planner.iterative.RuleStats
 
getHll() - Method in class io.prestosql.type.setdigest.SetDigest
 
getHost() - Method in class io.prestosql.metadata.InternalNode
 
getHostAndPort() - Method in class io.prestosql.metadata.InternalNode
 
getHttpRequestState() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getHttpResponseThreads() - Method in class io.prestosql.execution.TaskManagerConfig
 
getHttpsAddress() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getHttpsBaseUrl() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getHttpTimeoutThreads() - Method in class io.prestosql.execution.TaskManagerConfig
 
getHttpUri() - Method in class io.prestosql.metadata.InternalNode
Deprecated.
getHyperLogLog() - Method in interface io.prestosql.operator.aggregation.state.HyperLogLogState
 
getHyperLogLog() - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.GroupedHyperLogLogState
 
getHyperLogLog() - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.SingleHyperLogLogState
 
getId() - Method in class io.prestosql.execution.buffer.OutputBuffers.OutputBufferId
 
getId() - Method in class io.prestosql.execution.Lifespan
 
getId() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getId() - Method in class io.prestosql.execution.StageId
 
getId() - Method in class io.prestosql.execution.TaskId
 
getId() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getId() - Method in class io.prestosql.memory.MemoryPool
 
getId() - Method in class io.prestosql.memory.VersionedMemoryPoolId
 
getId() - Method in class io.prestosql.server.ResourceGroupInfo
 
getId() - Method in class io.prestosql.server.ThreadResource.Info
 
getId() - Method in class io.prestosql.sql.DynamicFilters.Descriptor
 
getId() - Method in class io.prestosql.sql.planner.plan.PlanNode
 
getId() - Method in class io.prestosql.sql.planner.PlanFragment
 
getId() - Method in class io.prestosql.sql.planner.planprinter.JsonRenderer.JsonRenderedNode
 
getId() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getId(ColumnHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorIndexHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorInsertTableHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorOutputTableHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorPartitioningHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorSplit) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorTableHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorTableLayoutHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorTransactionHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getIdAllocator() - Method in interface io.prestosql.sql.planner.iterative.Rule.Context
 
getIdColumn() - Method in class io.prestosql.sql.planner.plan.AssignUniqueId
 
getIdentifier() - Method in class io.prestosql.sql.planner.planprinter.JsonRenderer.JsonRenderedNode
 
getIdentifier() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getIdentity() - Method in class io.prestosql.FullConnectorSession
 
getIdentity() - Method in class io.prestosql.security.SecurityContext
 
getIdentity() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getIdentity() - Method in interface io.prestosql.server.SessionContext
 
getIdentity() - Method in class io.prestosql.Session
 
getIdentity() - Method in class io.prestosql.testing.TestingConnectorSession
 
getIdleCheckInterval() - Method in class io.prestosql.transaction.TransactionManagerConfig
 
getIdleTime() - Method in class io.prestosql.transaction.TransactionInfo
 
getIdleTimeout() - Method in class io.prestosql.transaction.TransactionManagerConfig
 
getImplementationDependencyAnnotation(AnnotatedElement) - Static method in interface io.prestosql.operator.annotations.ImplementationDependency
 
getImplementations() - Method in class io.prestosql.operator.aggregation.ParametricAggregation
 
getImplementations() - Method in class io.prestosql.operator.scalar.ParametricScalar
 
getImplicitFromScope(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
getInactiveNodeCount() - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
getInactiveNodes() - Method in class io.prestosql.metadata.AllNodes
 
getIndex() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode.EquiJoinClause
 
getIndex(Session, IndexHandle, List<ColumnHandle>, List<ColumnHandle>) - Method in class io.prestosql.index.IndexManager
 
getIndexedDataForKeys(int, Page) - Method in class io.prestosql.operator.index.IndexLoader
 
getIndexHandle() - Method in class io.prestosql.metadata.ResolvedIndex
 
getIndexHandle() - Method in class io.prestosql.sql.planner.plan.IndexSourceNode
 
getIndexHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getIndexHashSymbol() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode
 
getIndexSnapshot() - Method in class io.prestosql.operator.index.IndexLoader
 
getIndexSource() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode
 
getInfo() - Method in class io.prestosql.connector.informationschema.InformationSchemaSplit
 
getInfo() - Method in class io.prestosql.connector.system.SystemSplit
 
getInfo() - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
getInfo() - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
getInfo() - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
getInfo() - Method in interface io.prestosql.execution.buffer.OutputBuffer
Gets the current state of this buffer.
getInfo() - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
getInfo() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
getInfo() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getInfo() - Method in interface io.prestosql.execution.SplitRunner
 
getInfo() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getInfo() - Method in class io.prestosql.memory.LocalMemoryManager
 
getInfo() - Method in class io.prestosql.memory.MemoryPool
 
getInfo() - Method in class io.prestosql.memory.RemoteNodeMemory
 
getInfo() - Method in class io.prestosql.metadata.Split
 
getInfo() - Method in class io.prestosql.operator.index.IndexSplit
 
getInfo() - Method in class io.prestosql.operator.OperatorStats
 
getInfo() - Method in class io.prestosql.operator.PartitionedOutputOperator
 
getInfo() - Method in class io.prestosql.server.ServerInfoResource
 
getInfo() - Method in class io.prestosql.server.ui.ClusterResource
 
getInfo() - Method in class io.prestosql.split.EmptySplit
 
getInfo() - Method in class io.prestosql.split.RemoteSplit
 
getInfo() - Method in class io.prestosql.testing.TestingSplit
 
getInfo(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
 
getInfo(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getInfoMaxAge() - Method in class io.prestosql.execution.TaskManagerConfig
 
getInformationSchemaId() - Method in class io.prestosql.metadata.Catalog
 
getInfoRoundTripMillis() - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
getInfoUpdateInterval() - Method in class io.prestosql.execution.TaskManagerConfig
 
getInitialHashPartitions() - Method in class io.prestosql.execution.QueryManagerConfig
 
getInitialSplitsPerNode() - Method in class io.prestosql.execution.TaskManagerConfig
 
getInitialSplitsPerNode(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getInMemorySizeInBytes() - Method in class io.prestosql.operator.index.IndexLookupSource
 
getInMemorySizeInBytes() - Method in class io.prestosql.operator.JoinHash
 
getInMemorySizeInBytes() - Method in interface io.prestosql.operator.LookupSource
 
getInMemorySizeInBytes() - Method in class io.prestosql.operator.OuterLookupSource
 
getInMemorySizeInBytes() - Method in class io.prestosql.operator.PagesHash
 
getInMemorySizeInBytes() - Method in class io.prestosql.operator.PartitionedLookupSource
 
getInPredicateSubqueries(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getInput() - Method in class io.prestosql.sql.DynamicFilters.Descriptor
 
getInput() - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
getInput() - Method in class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
getInput() - Method in class io.prestosql.sql.planner.plan.UnnestNode.Mapping
 
getInputBytes() - Method in class io.prestosql.server.QueryProgressStats
 
getInputChannels() - Method in interface io.prestosql.operator.aggregation.AccumulatorFactory
 
getInputChannels() - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
getInputChannels() - Method in class io.prestosql.operator.index.TuplePageFilter
 
getInputChannels() - Method in class io.prestosql.operator.project.ConstantPageProjection
 
getInputChannels() - Method in class io.prestosql.operator.project.DictionaryAwarePageFilter
 
getInputChannels() - Method in class io.prestosql.operator.project.DictionaryAwarePageProjection
 
getInputChannels() - Method in class io.prestosql.operator.project.GeneratedPageProjection
 
getInputChannels() - Method in class io.prestosql.operator.project.InputChannels
 
getInputChannels() - Method in class io.prestosql.operator.project.InputPageProjection
 
getInputChannels() - Method in class io.prestosql.operator.project.PageFieldsToInputParametersRewriter.Result
 
getInputChannels() - Method in interface io.prestosql.operator.project.PageFilter
 
getInputChannels() - Method in interface io.prestosql.operator.project.PageProjection
 
getInputChannels(Page) - Method in class io.prestosql.operator.project.InputChannels
 
getInputDataSize() - Method in class io.prestosql.execution.SqlTaskIoStats
 
getInputDataSize() - Method in class io.prestosql.operator.DriverContext
 
getInputDataSize() - Method in class io.prestosql.operator.OperatorContext
 
getInputDataSize() - Method in class io.prestosql.operator.OperatorStats
 
getInputDataSize() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
getInputDataSize() - Method in class io.prestosql.operator.TableScanWorkProcessorOperator
 
getInputDataSize() - Method in interface io.prestosql.operator.WorkProcessorSourceOperator
 
getInputDependencies() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getInputFunction() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getInputFunction() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getInputParameterMetadataTypes() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getInputPositions() - Method in class io.prestosql.execution.SqlTaskIoStats
 
getInputPositions() - Method in class io.prestosql.operator.DriverContext
 
getInputPositions() - Method in class io.prestosql.operator.OperatorContext
 
getInputPositions() - Method in class io.prestosql.operator.OperatorStats
 
getInputPositions() - Method in class io.prestosql.operator.PipelineContext
 
getInputPositions() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
getInputPositions() - Method in class io.prestosql.operator.TableScanWorkProcessorOperator
 
getInputPositions() - Method in class io.prestosql.operator.TaskContext
 
getInputPositions() - Method in interface io.prestosql.operator.WorkProcessorSourceOperator
 
getInputRows() - Method in class io.prestosql.server.QueryProgressStats
 
getInputs() - Method in class io.prestosql.execution.QueryInfo
 
getInputs() - Method in class io.prestosql.sql.planner.plan.ExchangeNode
 
getInputSymbols() - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
getInputTableColumnInfos() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan
 
getInputTypesSignatures(Method) - Method in class io.prestosql.operator.aggregation.AggregationImplementation.Parser
 
getInsert() - Method in class io.prestosql.sql.analyzer.Analysis
 
getInsertHandle() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewTarget
 
getInsertLayout(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
 
getInsertLayout(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getInsertTableHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
getInsertTableHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getInstalledPluginsDir() - Method in class io.prestosql.server.PluginManagerConfig
 
getInstance(Key<T>) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getInstanceFactory() - Method in class io.prestosql.metadata.FunctionInvoker
 
getInstanceFactory() - Method in class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation.ScalarImplementationChoice
 
getInsufficientResourcesFailures() - Method in class io.prestosql.execution.QueryManagerStats
 
getInt(int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getIntermediateSplitCpuTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getIntermediateSplits() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getIntermediateSplitScheduledTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getIntermediateSplitWaitTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getIntermediateSplitWallTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getIntermediateType() - Method in class io.prestosql.metadata.AggregationFunctionMetadata
 
getIntermediateType() - Method in interface io.prestosql.operator.aggregation.Accumulator
 
getIntermediateType() - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
getIntermediateType() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.metadata.SqlAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.CountColumn
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.DecimalSumAggregation
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.histogram.Histogram
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.MapAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.MapUnionAggregation
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxBy
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.ParametricAggregation
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
getIntermediateTypes(FunctionBinding) - Method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
getInternalAddress() - Method in class io.prestosql.server.NodeStatus
 
getInternalFailureHtml(String) - Method in class io.prestosql.server.security.oauth2.OAuth2Service
 
getInternalFailures() - Method in class io.prestosql.execution.QueryManagerStats
 
getInternalNetworkInputDataSize() - Method in class io.prestosql.execution.BasicStageStats
 
getInternalNetworkInputDataSize() - Method in class io.prestosql.execution.QueryStats
 
getInternalNetworkInputDataSize() - Method in class io.prestosql.execution.StageStats
 
getInternalNetworkInputDataSize() - Method in class io.prestosql.operator.DriverStats
 
getInternalNetworkInputDataSize() - Method in class io.prestosql.operator.OperatorStats
 
getInternalNetworkInputDataSize() - Method in class io.prestosql.operator.PipelineStats
 
getInternalNetworkInputDataSize() - Method in class io.prestosql.operator.TaskStats
 
getInternalNetworkInputDataSize() - Method in interface io.prestosql.operator.WorkProcessorSourceOperator
 
getInternalNetworkInputPositions() - Method in class io.prestosql.execution.BasicStageStats
 
getInternalNetworkInputPositions() - Method in class io.prestosql.execution.QueryStats
 
getInternalNetworkInputPositions() - Method in class io.prestosql.execution.StageStats
 
getInternalNetworkInputPositions() - Method in class io.prestosql.operator.DriverStats
 
getInternalNetworkInputPositions() - Method in class io.prestosql.operator.OperatorStats
 
getInternalNetworkInputPositions() - Method in class io.prestosql.operator.PipelineStats
 
getInternalNetworkInputPositions() - Method in class io.prestosql.operator.TaskStats
 
getInternalNetworkInputReadTime() - Method in class io.prestosql.operator.DriverStats
 
getInternalNetworkPositions() - Method in interface io.prestosql.operator.WorkProcessorSourceOperator
 
getInternalUri() - Method in class io.prestosql.metadata.InternalNode
 
getInvocationConvention() - Method in class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation.ScalarImplementationChoice
 
getInvocations() - Method in class io.prestosql.sql.planner.iterative.RuleStats
 
getInvoker(FunctionBinding, FunctionDependencies, InvocationConvention) - Method in class io.prestosql.operator.annotations.CastImplementationDependency
 
getInvoker(FunctionBinding, FunctionDependencies, InvocationConvention) - Method in class io.prestosql.operator.annotations.FunctionImplementationDependency
 
getInvoker(FunctionBinding, FunctionDependencies, InvocationConvention) - Method in class io.prestosql.operator.annotations.OperatorImplementationDependency
 
getInvoker(FunctionBinding, FunctionDependencies, InvocationConvention) - Method in class io.prestosql.operator.annotations.ScalarImplementationDependency
 
getIoStats() - Method in class io.prestosql.execution.SqlTask
 
getIoStats() - Method in class io.prestosql.execution.SqlTaskManager
 
getIsolationLevel() - Method in class io.prestosql.transaction.TransactionInfo
 
getIterativeOptimizerTimeout() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getJavaType() - Method in class io.prestosql.operator.aggregation.AggregationImplementation.AggregateNativeContainerType
 
getJavaType() - Method in class io.prestosql.type.FunctionType
 
getJmxExport() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getJoinBridge(Lifespan) - Method in class io.prestosql.operator.JoinBridgeManager
 
getJoinCriteria(Join) - Method in class io.prestosql.sql.analyzer.Analysis
 
getJoinDistributionType() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getJoinDistributionType(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getJoinFilterFunctionFactoryStats() - Method in class io.prestosql.sql.gen.JoinFilterFunctionCompiler
 
getJoinLabel() - Method in enum io.prestosql.sql.planner.plan.IndexJoinNode.Type
 
getJoinLabel() - Method in enum io.prestosql.sql.planner.plan.JoinNode.Type
 
getJoinLabel() - Method in enum io.prestosql.sql.planner.plan.SpatialJoinNode.Type
 
getJoinMaxBroadcastTableSize() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getJoinMaxBroadcastTableSize(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getJoinOrder(JoinGraph) - Static method in class io.prestosql.sql.planner.iterative.rule.EliminateCrossJoins
Given JoinGraph determine the order of joins between graph nodes by traversing JoinGraph.
getJoinPosition(int, Page) - Method in interface io.prestosql.operator.index.IndexedData
Returns UNLOADED_INDEX_KEY if the key has not been loaded.
getJoinPosition(int, Page) - Method in class io.prestosql.operator.index.IndexSnapshot
 
getJoinPosition(int, Page) - Method in class io.prestosql.operator.index.StreamingIndexedData
 
getJoinPosition(int, Page, Page) - Method in class io.prestosql.operator.index.IndexLookupSource
 
getJoinPosition(int, Page, Page) - Method in class io.prestosql.operator.JoinHash
 
getJoinPosition(int, Page, Page) - Method in interface io.prestosql.operator.LookupSource
 
getJoinPosition(int, Page, Page) - Method in class io.prestosql.operator.OuterLookupSource
 
getJoinPosition(int, Page, Page) - Method in class io.prestosql.operator.PartitionedLookupSource
 
getJoinPosition(int, Page, Page, long) - Method in class io.prestosql.operator.index.IndexLookupSource
 
getJoinPosition(int, Page, Page, long) - Method in class io.prestosql.operator.JoinHash
 
getJoinPosition(int, Page, Page, long) - Method in interface io.prestosql.operator.LookupSource
 
getJoinPosition(int, Page, Page, long) - Method in class io.prestosql.operator.OuterLookupSource
 
getJoinPosition(int, Page, Page, long) - Method in class io.prestosql.operator.PartitionedLookupSource
 
getJoinPositionCount() - Method in class io.prestosql.operator.index.IndexLookupSource
 
getJoinPositionCount() - Method in class io.prestosql.operator.JoinHash
 
getJoinPositionCount() - Method in interface io.prestosql.operator.LookupSource
 
getJoinPositionCount() - Method in class io.prestosql.operator.OuterLookupSource
 
getJoinPositionCount() - Method in class io.prestosql.operator.PartitionedLookupSource
 
getJoinReorderingStrategy() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getJoinReorderingStrategy(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getJoinType() - Method in class io.prestosql.operator.JoinOperatorInfo
 
getJoinType() - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
getJoinUsing(Join) - Method in class io.prestosql.sql.analyzer.Analysis
 
getJsonOrdinalPosition() - Method in class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
getJsonPlan(Session, Statement, ExplainType.Type, List<Expression>, WarningCollector) - Method in class io.prestosql.sql.analyzer.QueryExplainer
 
getJsonRepresentation() - Method in class io.prestosql.sql.planner.PlanFragment
 
getJsonSerializableGroupedExecutionScanNodes() - Method in class io.prestosql.operator.StageExecutionDescriptor
 
getJsonType() - Method in class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
getJwksUrl() - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
getKdbTree() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getKerberosConfig() - Method in class io.prestosql.server.security.KerberosConfig
 
getKey(String) - Method in class io.prestosql.server.security.jwt.JwkService
 
getKeyChannels() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
getKeyFile() - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
getKeyId() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkEcPublicKey
 
getKeyId() - Method in interface io.prestosql.server.security.jwt.JwkDecoder.JwkPublicKey
 
getKeyId() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkRsaPublicKey
 
getKeyRecordSet() - Method in class io.prestosql.operator.index.IndexSplit
 
getKeys() - Method in class io.prestosql.operator.aggregation.KeyValuePairs
 
getKeys() - Method in class io.prestosql.server.security.jwt.JwkDecoder.Keys
 
getKeys() - Method in class io.prestosql.server.security.jwt.JwkService
 
getKeys(Type, Block) - Static method in class io.prestosql.operator.scalar.MapKeys
 
getKeyStorePassword() - Method in class io.prestosql.server.InternalCommunicationConfig
 
getKeyStorePath() - Method in class io.prestosql.server.InternalCommunicationConfig
 
getKeytab() - Method in class io.prestosql.server.security.KerberosConfig
 
getKeyType() - Method in interface io.prestosql.operator.aggregation.state.KeyValuePairsState
 
getKeyType() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.GroupedState
 
getKeyType() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.SingleState
 
getKillOnOutOfMemoryDelay() - Method in class io.prestosql.memory.MemoryManagerConfig
 
getKillQueryProcedure(KillQueryProcedure) - Static method in class io.prestosql.connector.system.SystemConnectorModule
 
getKind() - Method in class io.prestosql.metadata.FunctionMetadata
 
getLambda() - Method in interface io.prestosql.operator.aggregation.LambdaProvider
 
getLambdaArgumentReference(Identifier) - Method in class io.prestosql.sql.analyzer.Analysis
 
getLambdaArgumentReferences() - Method in class io.prestosql.sql.analyzer.Analysis
 
getLambdaArgumentReferences() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getLambdaInterfaces() - Method in class io.prestosql.metadata.FunctionInvoker
 
getLambdaInterfaces() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getLambdaInterfaces() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
getLambdaInterfaces() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
getLambdaInterfaces() - Method in class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation.ScalarImplementationChoice
 
getLambdaInterfaces() - Method in class io.prestosql.operator.window.AbstractWindowFunctionSupplier
 
getLambdaInterfaces() - Method in interface io.prestosql.operator.window.WindowFunctionSupplier
 
getLanguage() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getLanguage() - Method in interface io.prestosql.server.SessionContext
 
getLargeBroadcastMaxDistinctValuesPerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getLargeBroadcastMaxSizePerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getLargeBroadcastRangeRowLimitPerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getLargePartitionedMaxDistinctValuesPerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getLargePartitionedMaxSizePerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getLargePartitionedRangeRowLimitPerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getLastEndTime() - Method in class io.prestosql.operator.PipelineStats
 
getLastEndTime() - Method in class io.prestosql.operator.TaskStats
 
getLastFailureException() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getLastFailureInfo() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getLastHeartbeat() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getLastHeartbeat() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getLastHeartbeat() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getLastHeartbeat() - Method in class io.prestosql.execution.QueryStateMachine
 
getLastHeartbeat() - Method in class io.prestosql.execution.QueryStats
 
getLastHeartbeat() - Method in interface io.prestosql.execution.QueryTracker.TrackedQuery
 
getLastHeartbeat() - Method in class io.prestosql.execution.SqlQueryExecution
 
getLastHeartbeat() - Method in class io.prestosql.execution.TaskInfo
 
getLastRequestTime() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getLastResponseTime() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getLastStartTime() - Method in class io.prestosql.operator.PipelineStats
 
getLastStartTime() - Method in class io.prestosql.operator.TaskStats
 
getLastUpdate() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getLayout() - Method in class io.prestosql.metadata.NewTableLayout
 
getLayout() - Method in class io.prestosql.metadata.TableHandle
 
getLayout() - Method in class io.prestosql.sql.analyzer.Analysis.Create
 
getLayout() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateReference
 
getLayout(Session, TableHandle, Constraint, Optional<Set<ColumnHandle>>) - Method in interface io.prestosql.metadata.Metadata
Deprecated.
getLayout(Session, TableHandle, Constraint, Optional<Set<ColumnHandle>>) - Method in class io.prestosql.metadata.MetadataManager
 
getLazyDynamicFilters() - Method in class io.prestosql.server.DynamicFilterService.DynamicFiltersStats
 
getLeafSplitCpuTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getLeafSplitScheduledTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getLeafSplitWaitTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getLeafSplitWallTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getLeft() - Method in class io.prestosql.sql.planner.plan.JoinNode.EquiJoinClause
 
getLeft() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getLeft() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getLeftHashSymbol() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getLeftJoinFields() - Method in class io.prestosql.sql.analyzer.Analysis.JoinUsingAnalysis
 
getLeftOutputSymbols() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getLeftPartitionSymbol() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getLevel() - Method in class io.prestosql.execution.executor.Priority
 
getLevel0Time() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getLevel1Time() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getLevel2Time() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getLevel3Time() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getLevel4Time() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getLevelMinPriority(int, long) - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getLevelPriority() - Method in class io.prestosql.execution.executor.Priority
 
getLevelTimeMultiplier() - Method in class io.prestosql.execution.TaskManagerConfig
 
getLifespan() - Method in class io.prestosql.metadata.Split
 
getLifespan() - Method in class io.prestosql.operator.DriverContext
 
getLifespan() - Method in class io.prestosql.operator.DriverStats
 
getLifespan() - Method in class io.prestosql.operator.ProcessorContext
 
getLimit() - Method in class io.prestosql.connector.informationschema.InformationSchemaTableHandle
 
getLimit() - Method in class io.prestosql.sql.planner.plan.DistinctLimitNode
 
getLimit(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getLine() - Method in class io.prestosql.server.ThreadResource.StackLine
 
getLiteral(String) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.SpecializeContext
 
getLoadedBlock() - Method in class io.prestosql.operator.GroupByIdBlock
 
getLocale() - Method in class io.prestosql.FullConnectorSession
 
getLocale() - Method in class io.prestosql.Session
 
getLocale() - Method in class io.prestosql.SessionRepresentation
 
getLocale() - Method in class io.prestosql.testing.TestingConnectorSession
 
getLocalExchange(Lifespan) - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeFactory
 
getLocalExchangeFactory() - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator.LocalExchangeSourceOperatorFactory
 
getLocalMemoryManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getLocalParent() - Method in class io.prestosql.sql.analyzer.Scope
 
getLocalProperties() - Method in class io.prestosql.metadata.TableProperties
 
getLocalProperties() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
getLocalProperties() - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
getLocalScopeFieldCount() - Method in class io.prestosql.sql.analyzer.Scope
 
getLocation() - Method in class io.prestosql.split.RemoteSplit
 
getLocationSegmentNames() - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig
 
getLockOwnerId() - Method in class io.prestosql.server.ThreadResource.Info
 
getLogHistogramOutput() - Method in class io.prestosql.operator.JoinOperatorInfo
 
getLogHistogramProbes() - Method in class io.prestosql.operator.JoinOperatorInfo
 
getLogicalPlan(Session, Statement, List<Expression>, WarningCollector) - Method in class io.prestosql.sql.analyzer.QueryExplainer
 
getLogicalWrittenDataSize() - Method in class io.prestosql.execution.QueryStats
 
getLong() - Method in interface io.prestosql.operator.aggregation.state.LongAndDoubleState
 
getLong() - Method in interface io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongState
 
getLong() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.GroupedLongDecimalWithOverflowAndLongState
 
getLong() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.SingleLongDecimalWithOverflowAndLongState
 
getLong() - Method in interface io.prestosql.operator.aggregation.state.LongState
 
getLong() - Method in interface io.prestosql.operator.aggregation.state.NullableLongState
 
getLong(int) - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
getLong(int) - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
getLong(int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getLong(int, int) - Method in class io.prestosql.operator.PagesIndex
 
getLong(int, int) - Method in class io.prestosql.operator.window.PagesWindowIndex
 
getLong(Block, int) - Method in class io.prestosql.type.FunctionType
 
getLongDecimal() - Method in interface io.prestosql.operator.aggregation.state.LongDecimalWithOverflowState
 
getLongDecimal() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
getLongDecimal() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
getLongVariable(String) - Method in class io.prestosql.metadata.FunctionBinding
 
getLongVariableConstraints() - Method in class io.prestosql.metadata.Signature
 
getLookup() - Method in interface io.prestosql.sql.planner.iterative.Rule.Context
 
getLookupSource() - Method in interface io.prestosql.operator.LookupSourceProvider.LookupSourceLease
 
getLookupSource() - Method in interface io.prestosql.operator.TrackingLookupSourceSupplier
 
getLookupSourcePositions() - Method in class io.prestosql.operator.JoinOperatorInfo
Estimated number of positions in on the build side
getLookupSourceStats() - Method in class io.prestosql.sql.gen.JoinCompiler
 
getLookupSymbols() - Method in class io.prestosql.sql.planner.plan.IndexSourceNode
 
getLow() - Method in class io.prestosql.cost.StatisticRange
 
getLow() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedRange
 
getLowMemoryKillerPolicy() - Method in class io.prestosql.memory.MemoryManagerConfig
 
getLowValue() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
getM1() - Method in interface io.prestosql.operator.aggregation.state.CentralMomentsState
 
getM2() - Method in interface io.prestosql.operator.aggregation.state.CentralMomentsState
 
getM2() - Method in interface io.prestosql.operator.aggregation.state.VarianceState
 
getM2X() - Method in interface io.prestosql.operator.aggregation.state.CorrelationState
 
getM2X() - Method in interface io.prestosql.operator.aggregation.state.RegressionState
 
getM2Y() - Method in interface io.prestosql.operator.aggregation.state.CorrelationState
 
getM3() - Method in interface io.prestosql.operator.aggregation.state.CentralMomentsState
 
getM4() - Method in interface io.prestosql.operator.aggregation.state.CentralMomentsState
 
getManagementExecutor() - Method in class io.prestosql.execution.SqlQueryManager
 
getMap() - Method in class io.prestosql.sql.planner.plan.Assignments
 
getMappings() - Method in class io.prestosql.sql.analyzer.Analysis.UnnestAnalysis
 
getMappings() - Method in class io.prestosql.sql.planner.plan.StatisticAggregations.Parts
 
getMappings() - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
getMarkerSymbol() - Method in class io.prestosql.sql.planner.plan.MarkDistinctNode
 
getMask() - Method in class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
getMaterializedHandle(TableWriterNode.WriterTarget) - Method in class io.prestosql.sql.planner.optimizations.BeginTableWrite.Context
 
getMaterializedResult() - Method in class io.prestosql.testing.QueryRunner.MaterializedResultWithPlan
 
getMaterializedRows() - Method in class io.prestosql.testing.MaterializedResult
 
getMaterializedView(Session, QualifiedObjectName) - Method in interface io.prestosql.metadata.Metadata
Returns the materialized view definition for the specified view name.
getMaterializedView(Session, QualifiedObjectName) - Method in class io.prestosql.metadata.MetadataManager
 
getMaterializedViewFreshness(Session, QualifiedObjectName) - Method in interface io.prestosql.metadata.Metadata
Method to get difference between the states of table at two different points in time/or as of given token-ids.
getMaterializedViewFreshness(Session, QualifiedObjectName) - Method in class io.prestosql.metadata.MetadataManager
 
getMaterializedViewName() - Method in class io.prestosql.sql.analyzer.Analysis.RefreshMaterializedViewAnalysis
 
getMaterializedViewName() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewReference
 
getMavenLocalRepository() - Method in class io.prestosql.server.PluginManagerConfig
 
getMavenRemoteRepository() - Method in class io.prestosql.server.PluginManagerConfig
 
getMaxActiveSplit() - Method in class io.prestosql.server.TaskExecutorResource
 
getMaxActiveSplitsInfo() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getMaxBufferedBytes() - Method in class io.prestosql.operator.ExchangeClientStatus
 
getMaxBufferSize() - Method in class io.prestosql.operator.ExchangeClientConfig
 
getMaxBytes() - Method in class io.prestosql.memory.MemoryPool
 
getMaxBytes() - Method in class io.prestosql.spiller.SpillSpaceTracker
 
getMaxCompare(BlockTypeOperators, Type) - Static method in class io.prestosql.util.MinMaxCompare
 
getMaxConcurrentQueries() - Method in class io.prestosql.execution.QueryManagerConfig
Deprecated.
getMaxDriversPerTask() - Method in class io.prestosql.execution.executor.TaskHandle
 
getMaxDriversPerTask() - Method in class io.prestosql.execution.TaskManagerConfig
 
getMaxDriversPerTask(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getMaxErrorDuration() - Method in class io.prestosql.operator.ExchangeClientConfig
 
getMaxFinishingConcurrency() - Method in class io.prestosql.transaction.TransactionManagerConfig
 
getMaxGroupingSets() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getMaxGroupingSets(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getMaxIndex() - Method in class io.prestosql.GroupByHashPageIndexer
 
getMaxIndexMemoryUsage() - Method in class io.prestosql.execution.TaskManagerConfig
 
getMaxLocalExchangeBufferSize() - Method in class io.prestosql.execution.TaskManagerConfig
 
getMaxMemory() - Method in class io.prestosql.cost.LocalCostEstimate
 
getMaxMemory() - Method in class io.prestosql.cost.PlanCostEstimate
Returns maximal memory usage of a query plan (or subplan).
getMaxMemory() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.EstimatedStatsAndCost
 
getMaxMemoryWhenOutputting() - Method in class io.prestosql.cost.PlanCostEstimate
Returns maximal memory usage of a query plan (or subplan) after a first output row was produced.
getMaxOutputStageJsonSize() - Method in class io.prestosql.event.QueryMonitorConfig
 
getMaxPagePartitioningBufferSize() - Method in class io.prestosql.execution.TaskManagerConfig
 
getMaxPartialAggregationMemoryUsage() - Method in class io.prestosql.execution.TaskManagerConfig
 
getMaxPendingSplitsPerTask() - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
getMaxQueryHistory() - Method in class io.prestosql.execution.QueryManagerConfig
 
getMaxQueryLength() - Method in class io.prestosql.execution.QueryManagerConfig
 
getMaxQueryMemory() - Method in class io.prestosql.memory.MemoryManagerConfig
 
getMaxQueryMemoryPerNode() - Method in class io.prestosql.memory.NodeMemoryConfig
 
getMaxQueryTotalMemory() - Method in class io.prestosql.memory.MemoryManagerConfig
 
getMaxQueryTotalMemoryPerNode() - Method in class io.prestosql.memory.NodeMemoryConfig
 
getMaxQueuedQueries() - Method in class io.prestosql.execution.QueryManagerConfig
Deprecated.
getMaxQueuedQueries() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getMaxQueuedQueries() - Method in class io.prestosql.server.ResourceGroupInfo
 
getMaxRecursionDepth() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getMaxRecursionDepth(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getMaxReorderedJoins() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getMaxReorderedJoins(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getMaxResponseSize() - Method in class io.prestosql.operator.ExchangeClientConfig
 
getMaxRowCountPerPartition() - Method in class io.prestosql.sql.planner.plan.RowNumberNode
 
getMaxRowCountPerPartition() - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
getMaxSpillPerNode() - Method in class io.prestosql.spiller.NodeSpillConfig
 
getMaxSplitsPerNode() - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
getMaxStageCount() - Method in class io.prestosql.execution.QueryManagerConfig
 
getMaxWarnings() - Method in class io.prestosql.execution.warnings.WarningCollectorConfig
 
getMaxWorkerThreads() - Method in class io.prestosql.execution.TaskManagerConfig
 
getMbeans() - Method in class io.prestosql.dispatcher.DispatchExecutor
 
getMbeanServer() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getMean() - Method in interface io.prestosql.operator.aggregation.state.VarianceState
 
getMeanX() - Method in interface io.prestosql.operator.aggregation.state.CovarianceState
 
getMeanY() - Method in interface io.prestosql.operator.aggregation.state.CovarianceState
 
getMemoryCost() - Method in class io.prestosql.cost.PlanNodeStatsAndCostSummary
 
getMemoryCostWeight() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getMemoryInBytes() - Method in class io.prestosql.operator.index.IndexSnapshotBuilder
 
getMemoryInfo() - Method in class io.prestosql.server.NodeStatus
 
getMemoryInfo(MemoryPoolAssignmentsRequest) - Method in class io.prestosql.memory.MemoryResource
 
getMemoryInfo(String) - Method in class io.prestosql.memory.MemoryResource
 
getMemoryPool() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getMemoryPool() - Method in interface io.prestosql.execution.QueryExecution
 
getMemoryPool() - Method in class io.prestosql.execution.QueryInfo
 
getMemoryPool() - Method in class io.prestosql.execution.QueryStateMachine
 
getMemoryPool() - Method in class io.prestosql.execution.SqlQueryExecution
 
getMemoryPool() - Method in class io.prestosql.memory.QueryContext
 
getMemoryPool() - Method in class io.prestosql.server.BasicQueryInfo
 
getMemoryPoolId() - Method in class io.prestosql.memory.LowMemoryKiller.QueryMemoryInfo
 
getMemoryPoolInfo() - Method in class io.prestosql.memory.ClusterMemoryManager
 
getMemoryPoolManager() - Method in class io.prestosql.execution.resourcegroups.ResourceGroupConfigurationManagerContextInstance
 
getMemoryReservation() - Method in class io.prestosql.execution.TaskStatus
 
getMemoryReservation() - Method in class io.prestosql.memory.LowMemoryKiller.QueryMemoryInfo
 
getMemoryReservation() - Method in class io.prestosql.operator.TaskContext
 
getMemoryRevokingTarget() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getMemoryRevokingThreshold() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getMemoryTrackingContext() - Method in class io.prestosql.operator.ProcessorContext
 
getMemoryUsage() - Method in class io.prestosql.operator.DriverContext
 
getMemoryUsage() - Method in class io.prestosql.server.ResourceGroupInfo
 
getMessage() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
getMetadata() - Method in class io.prestosql.metadata.CatalogMetadata
 
getMetadata() - Method in class io.prestosql.metadata.TableMetadata
 
getMetadata() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getMetadata() - Method in class io.prestosql.sql.analyzer.Analysis.Create
 
getMetadata() - Method in class io.prestosql.testing.LocalQueryRunner
 
getMetadata() - Method in interface io.prestosql.testing.QueryRunner
 
getMetadata(ConnectorTransactionHandle) - Method in class io.prestosql.connector.informationschema.InformationSchemaConnector
 
getMetadata(ConnectorTransactionHandle) - Method in class io.prestosql.connector.system.GlobalSystemConnector
 
getMetadata(ConnectorTransactionHandle) - Method in class io.prestosql.connector.system.SystemConnector
 
getMetadataFor(CatalogName) - Method in class io.prestosql.metadata.CatalogMetadata
 
getMethod() - Method in class io.prestosql.server.ThreadResource.StackLine
 
getMethodHandle() - Method in class io.prestosql.metadata.FunctionInvoker
 
getMethodHandle() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
getMethodHandle() - Method in class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation.ScalarImplementationChoice
 
getMethodHandle() - Method in class io.prestosql.sql.gen.VarArgsToArrayAdapterGenerator.MethodHandleAndConstructor
 
getMicrosOfMilli(long) - Static method in class io.prestosql.type.DateTimes
 
getMicrosOfSecond(long) - Static method in class io.prestosql.type.DateTimes
 
getMillis() - Method in class io.prestosql.type.SqlIntervalDayTime
 
getMillisOfSecond(long) - Static method in class io.prestosql.type.DateTimes
 
getMinCandidates() - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
getMinDrivers() - Method in class io.prestosql.execution.TaskManagerConfig
 
getMinDriversPerTask() - Method in class io.prestosql.execution.TaskManagerConfig
 
getMinErrorDuration() - Method in class io.prestosql.operator.ExchangeClientConfig
Deprecated.
getMinimumNumberOfDrivers() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getMinMaxCompare(FunctionDependencies, Type, InvocationConvention, boolean) - Static method in class io.prestosql.util.MinMaxCompare
 
getMinQueryExpireAge() - Method in class io.prestosql.execution.QueryManagerConfig
 
getMinScheduleSplitBatchSize() - Method in class io.prestosql.execution.QueryManagerConfig
 
getMinScheduleSplitBatchSize() - Method in class io.prestosql.split.BufferingSplitSource
 
getMinScheduleSplitBatchSize() - Method in class io.prestosql.split.ConnectorAwareSplitSource
 
getMinScheduleSplitBatchSize() - Method in class io.prestosql.split.SampledSplitSource
 
getMinScheduleSplitBatchSize() - Method in interface io.prestosql.split.SplitSource
 
getModulus() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkRsaPublicKey
 
getMonths() - Method in class io.prestosql.type.SqlIntervalYearMonth
 
getName() - Method in class io.prestosql.connector.system.GlobalSystemConnectorFactory
 
getName() - Method in class io.prestosql.execution.AddColumnTask
 
getName() - Method in class io.prestosql.execution.CallTask
 
getName() - Method in class io.prestosql.execution.Column
 
getName() - Method in class io.prestosql.execution.CommentTask
 
getName() - Method in class io.prestosql.execution.CommitTask
 
getName() - Method in class io.prestosql.execution.CreateMaterializedViewTask
 
getName() - Method in class io.prestosql.execution.CreateRoleTask
 
getName() - Method in class io.prestosql.execution.CreateSchemaTask
 
getName() - Method in class io.prestosql.execution.CreateTableTask
 
getName() - Method in class io.prestosql.execution.CreateViewTask
 
getName() - Method in interface io.prestosql.execution.DataDefinitionTask
 
getName() - Method in class io.prestosql.execution.DeallocateTask
 
getName() - Method in class io.prestosql.execution.DropColumnTask
 
getName() - Method in class io.prestosql.execution.DropMaterializedViewTask
 
getName() - Method in class io.prestosql.execution.DropRoleTask
 
getName() - Method in class io.prestosql.execution.DropSchemaTask
 
getName() - Method in class io.prestosql.execution.DropTableTask
 
getName() - Method in class io.prestosql.execution.DropViewTask
 
getName() - Method in class io.prestosql.execution.GrantRolesTask
 
getName() - Method in class io.prestosql.execution.GrantTask
 
getName() - Method in class io.prestosql.execution.PrepareTask
 
getName() - Method in class io.prestosql.execution.RenameColumnTask
 
getName() - Method in class io.prestosql.execution.RenameSchemaTask
 
getName() - Method in class io.prestosql.execution.RenameTableTask
 
getName() - Method in class io.prestosql.execution.RenameViewTask
 
getName() - Method in class io.prestosql.execution.ResetSessionTask
 
getName() - Method in class io.prestosql.execution.RevokeRolesTask
 
getName() - Method in class io.prestosql.execution.RevokeTask
 
getName() - Method in class io.prestosql.execution.RollbackTask
 
getName() - Method in class io.prestosql.execution.SetPathTask
 
getName() - Method in class io.prestosql.execution.SetRoleTask
 
getName() - Method in class io.prestosql.execution.SetSchemaAuthorizationTask
 
getName() - Method in class io.prestosql.execution.SetSessionTask
 
getName() - Method in class io.prestosql.execution.SetTableAuthorizationTask
 
getName() - Method in class io.prestosql.execution.SetViewAuthorizationTask
 
getName() - Method in class io.prestosql.execution.StartTransactionTask
 
getName() - Method in class io.prestosql.execution.UseTask
 
getName() - Method in class io.prestosql.metadata.BoundSignature
 
getName() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependency
 
getName() - Method in class io.prestosql.metadata.LongVariableConstraint
 
getName() - Method in class io.prestosql.metadata.Signature
 
getName() - Method in class io.prestosql.metadata.TypeVariableConstraint
 
getName() - Method in class io.prestosql.operator.aggregation.AggregationHeader
 
getName() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getName() - Method in class io.prestosql.operator.scalar.annotations.ScalarImplementationHeader
 
getName() - Method in enum io.prestosql.operator.scalar.ColorFunctions.SystemColor
 
getName() - Method in class io.prestosql.server.security.InternalPrincipal
 
getName() - Method in class io.prestosql.server.ThreadResource.Info
 
getName() - Method in class io.prestosql.sql.analyzer.Field
 
getName() - Method in class io.prestosql.sql.planner.planprinter.JsonRenderer.JsonRenderedNode
 
getName() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getName() - Method in class io.prestosql.sql.planner.Symbol
 
getName() - Method in class io.prestosql.sql.relational.VariableReferenceExpression
 
getName() - Method in class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
getName() - Method in class io.prestosql.type.ArrayParametricType
 
getName() - Method in class io.prestosql.type.CharParametricType
 
getName() - Method in class io.prestosql.type.DecimalParametricType
 
getName() - Method in class io.prestosql.type.FunctionParametricType
 
getName() - Method in class io.prestosql.type.MapParametricType
 
getName() - Method in class io.prestosql.type.RowParametricType
 
getName() - Method in class io.prestosql.type.VarcharParametricType
 
getNamedQuery(Table) - Method in class io.prestosql.sql.analyzer.Analysis
 
getNamedQuery(String) - Method in class io.prestosql.sql.analyzer.Scope
 
getNameType() - Method in class io.prestosql.server.security.KerberosConfig
 
getNestedOperatorStats() - Method in class io.prestosql.operator.OperatorContext
 
getNetworkCost() - Method in class io.prestosql.cost.LocalCostEstimate
 
getNetworkCost() - Method in class io.prestosql.cost.PlanCostEstimate
Returns network component of the cost.
getNetworkCost() - Method in class io.prestosql.cost.PlanNodeStatsAndCostSummary
 
getNetworkCost() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.EstimatedStatsAndCost
 
getNetworkCostWeight() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getNetworkTopologyFile() - Method in class io.prestosql.execution.scheduler.TopologyFileConfig
 
getNewTableHandle() - Method in class io.prestosql.metadata.TableLayoutResult
Deprecated.
 
getNewTableLayout() - Method in class io.prestosql.sql.analyzer.Analysis.Insert
 
getNewTableLayout(Session, String, ConnectorTableMetadata) - Method in interface io.prestosql.metadata.Metadata
 
getNewTableLayout(Session, String, ConnectorTableMetadata) - Method in class io.prestosql.metadata.MetadataManager
 
getNewTasks() - Method in class io.prestosql.execution.scheduler.ScheduleResult
 
getNextBatch(ConnectorPartitionHandle, Lifespan, int) - Method in class io.prestosql.split.BufferingSplitSource
 
getNextBatch(ConnectorPartitionHandle, Lifespan, int) - Method in class io.prestosql.split.ConnectorAwareSplitSource
 
getNextBatch(ConnectorPartitionHandle, Lifespan, int) - Method in class io.prestosql.split.SampledSplitSource
 
getNextBatch(ConnectorPartitionHandle, Lifespan, int) - Method in interface io.prestosql.split.SplitSource
 
getNextId() - Method in class io.prestosql.sql.planner.PlanNodeIdAllocator
 
getNextJoinPosition(long) - Method in interface io.prestosql.operator.index.IndexedData
Returns the next address to join.
getNextJoinPosition(long) - Method in class io.prestosql.operator.index.IndexSnapshot
 
getNextJoinPosition(long) - Method in class io.prestosql.operator.index.StreamingIndexedData
 
getNextJoinPosition(long, int, Page) - Method in class io.prestosql.operator.index.IndexLookupSource
 
getNextJoinPosition(long, int, Page) - Method in class io.prestosql.operator.JoinHash
 
getNextJoinPosition(long, int, Page) - Method in interface io.prestosql.operator.LookupSource
 
getNextJoinPosition(long, int, Page) - Method in class io.prestosql.operator.OuterLookupSource
 
getNextJoinPosition(long, int, Page) - Method in class io.prestosql.operator.PartitionedLookupSource
 
getNextPage() - Method in class io.prestosql.connector.informationschema.InformationSchemaPageSource
 
getNextPage() - Method in class io.prestosql.split.MappedPageSource
 
getNextSource() - Method in class io.prestosql.operator.exchange.LocalExchange
 
getNextSplitId() - Method in class io.prestosql.execution.executor.TaskHandle
 
getNextToken() - Method in class io.prestosql.execution.buffer.BufferResult
 
getNextToken() - Method in class io.prestosql.operator.HttpPageBufferClient.PagesResponse
 
getNode() - Method in class io.prestosql.memory.RemoteNodeMemory
 
getNode() - Method in class io.prestosql.sql.analyzer.CanonicalizationAware
 
getNode() - Method in class io.prestosql.sql.planner.NodeAndMappings
 
getNode() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatedNode
 
getNode() - Method in class io.prestosql.sql.planner.ScopeAware
 
getNode(int) - Method in class io.prestosql.sql.planner.iterative.Memo
 
getNode(int) - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
getNode(Split) - Method in class io.prestosql.sql.planner.NodePartitionMap
 
getNodeCount() - Method in class io.prestosql.testing.LocalQueryRunner
 
getNodeCount() - Method in interface io.prestosql.testing.QueryRunner
 
getNodeForBucket(int) - Method in class io.prestosql.execution.scheduler.FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy
 
getNodeId() - Method in interface io.prestosql.execution.RemoteTask
 
getNodeId() - Method in class io.prestosql.execution.TaskStatus
 
getNodeId() - Method in class io.prestosql.server.NodeStatus
 
getNodeId() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
getNodeIdentifier() - Method in class io.prestosql.metadata.InternalNode
 
getNodeManager() - Method in class io.prestosql.connector.ConnectorContextInstance
 
getNodeManager() - Method in class io.prestosql.testing.TestingConnectorContext
 
getNodePartitioning() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
getNodePartitioningManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getNodePartitioningManager() - Method in class io.prestosql.testing.LocalQueryRunner
 
getNodePartitioningManager() - Method in interface io.prestosql.testing.QueryRunner
 
getNodePartitioningMap(Session, PartitioningHandle) - Method in class io.prestosql.sql.planner.NodePartitioningManager
 
getNodePartitionMap(Session, NodeScheduler) - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
getNodes() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getNodes() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
getNodes(NodeState) - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
getNodes(NodeState) - Method in class io.prestosql.metadata.InMemoryNodeManager
 
getNodes(NodeState) - Method in interface io.prestosql.metadata.InternalNodeManager
 
getNodesByHost() - Method in class io.prestosql.execution.scheduler.NodeMap
 
getNodesByHostAndPort() - Method in class io.prestosql.execution.scheduler.NodeMap
 
getNodeSchedulerPolicy() - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
getNodeState() - Method in class io.prestosql.metadata.RemoteNodeState
 
getNodeStats() - Method in class io.prestosql.server.NodeResource
 
getNodeVersion() - Method in class io.prestosql.metadata.InternalNode
 
getNodeVersion() - Method in class io.prestosql.server.NodeStatus
 
getNodeVersion() - Method in class io.prestosql.server.ui.ClusterResource.ClusterInfo
 
getNoMoreSplits() - Method in class io.prestosql.execution.SqlTaskExecution
 
getNoMoreSplits() - Method in class io.prestosql.execution.TaskInfo
 
getNoMoreSplitsForLifespan() - Method in class io.prestosql.execution.TaskSource
 
getNonHeapUsed() - Method in class io.prestosql.server.NodeStatus
 
getNotFullFuture() - Method in class io.prestosql.operator.exchange.LocalExchangeMemoryManager
 
getNotNullColumnSymbols() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getNullsFraction() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
getNumberOfIndexes() - Method in class io.prestosql.operator.WindowInfo.DriverWindowInfo
 
getNumberOfLeakedQueries() - Method in class io.prestosql.memory.ClusterMemoryManager
 
getNumberOfPartitions() - Method in class io.prestosql.operator.WindowInfo.IndexInfo
 
getNumEligibleSubGroups() - Method in class io.prestosql.server.ResourceGroupInfo
 
getNumQueuedQueries() - Method in class io.prestosql.server.ResourceGroupInfo
 
getNumRunningQueries() - Method in class io.prestosql.server.ResourceGroupInfo
 
getObject(int) - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
getObject(int) - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
getObject(int, int) - Method in class io.prestosql.operator.PagesIndex
 
getObject(int, int) - Method in class io.prestosql.operator.window.PagesWindowIndex
 
getObject(int, Class<T>) - Method in class io.prestosql.operator.GroupByIdBlock
 
getObject(Block, int) - Method in class io.prestosql.type.CodePointsType
 
getObject(Block, int) - Method in class io.prestosql.type.FunctionType
 
getObject(Block, int) - Method in class io.prestosql.type.JoniRegexpType
 
getObject(Block, int) - Method in class io.prestosql.type.JsonPathType
 
getObject(Block, int) - Method in class io.prestosql.type.LikePatternType
 
getObject(Block, int) - Method in class io.prestosql.type.Re2JRegexpType
 
getObject(Block, int) - Method in class io.prestosql.type.TDigestType
 
getObjectExtractor() - Method in class io.prestosql.operator.scalar.JsonPath
 
getObjectKey(Block, int) - Method in interface io.prestosql.util.JsonUtil.ObjectKeyProvider
 
getObjectName() - Method in class io.prestosql.metadata.QualifiedObjectName
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.CodePointsType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.ColorType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.FunctionType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.IntervalDayTimeType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.IntervalYearMonthType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.IpAddressType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.JoniRegexpType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.JsonPathType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.JsonType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.LikePatternType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.Re2JRegexpType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.setdigest.SetDigestType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.TDigestType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.UnknownType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.type.UuidType
 
getOffset() - Method in class io.prestosql.operator.project.SelectedPositions
 
getOffset(Offset) - Method in class io.prestosql.sql.analyzer.Analysis
 
getOffsetMinutes(Instant, TimeZoneKey) - Static method in class io.prestosql.type.DateTimes
 
getOnlyColumn() - Method in class io.prestosql.testing.MaterializedResult
 
getOnlyColumnAsSet() - Method in class io.prestosql.testing.MaterializedResult
 
getOnlyValue() - Method in class io.prestosql.testing.MaterializedResult
 
getOperator() - Method in class io.prestosql.operator.annotations.OperatorImplementationDependency
 
getOperator() - Method in class io.prestosql.sql.DynamicFilters.Descriptor
 
getOperatorContext() - Method in class io.prestosql.operator.AggregationOperator
 
getOperatorContext() - Method in class io.prestosql.operator.DeleteOperator
 
getOperatorContext() - Method in class io.prestosql.operator.DevNullOperator
 
getOperatorContext() - Method in class io.prestosql.operator.DistinctLimitOperator
 
getOperatorContext() - Method in class io.prestosql.operator.DynamicFilterSourceOperator
 
getOperatorContext() - Method in class io.prestosql.operator.EnforceSingleRowOperator
 
getOperatorContext() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator
 
getOperatorContext() - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator
 
getOperatorContext() - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator
 
getOperatorContext() - Method in class io.prestosql.operator.ExchangeOperator
 
getOperatorContext() - Method in class io.prestosql.operator.ExplainAnalyzeOperator
 
getOperatorContext() - Method in class io.prestosql.operator.FinishedOperator
 
getOperatorContext() - Method in class io.prestosql.operator.GroupIdOperator
 
getOperatorContext() - Method in class io.prestosql.operator.HashAggregationOperator
 
getOperatorContext() - Method in class io.prestosql.operator.HashBuilderOperator
 
getOperatorContext() - Method in class io.prestosql.operator.index.IndexSourceOperator
 
getOperatorContext() - Method in class io.prestosql.operator.index.PageBufferOperator
 
getOperatorContext() - Method in class io.prestosql.operator.index.PagesIndexBuilderOperator
 
getOperatorContext() - Method in class io.prestosql.operator.LimitOperator
 
getOperatorContext() - Method in class io.prestosql.operator.LookupOuterOperator
 
getOperatorContext() - Method in class io.prestosql.operator.MarkDistinctOperator
 
getOperatorContext() - Method in class io.prestosql.operator.MergeOperator
 
getOperatorContext() - Method in class io.prestosql.operator.NestedLoopBuildOperator
 
getOperatorContext() - Method in class io.prestosql.operator.NestedLoopJoinOperator
 
getOperatorContext() - Method in interface io.prestosql.operator.Operator
 
getOperatorContext() - Method in class io.prestosql.operator.OrderByOperator
 
getOperatorContext() - Method in class io.prestosql.operator.PageSourceOperator
 
getOperatorContext() - Method in class io.prestosql.operator.PartitionedOutputOperator
 
getOperatorContext() - Method in class io.prestosql.operator.RowNumberOperator
 
getOperatorContext() - Method in class io.prestosql.operator.SetBuilderOperator
 
getOperatorContext() - Method in class io.prestosql.operator.SpatialIndexBuilderOperator
 
getOperatorContext() - Method in class io.prestosql.operator.SpatialJoinOperator
 
getOperatorContext() - Method in class io.prestosql.operator.StatisticsWriterOperator
 
getOperatorContext() - Method in class io.prestosql.operator.TableDeleteOperator
 
getOperatorContext() - Method in class io.prestosql.operator.TableFinishOperator
 
getOperatorContext() - Method in class io.prestosql.operator.TableScanOperator
 
getOperatorContext() - Method in class io.prestosql.operator.TableWriterOperator
 
getOperatorContext() - Method in class io.prestosql.operator.TaskOutputOperator
 
getOperatorContext() - Method in class io.prestosql.operator.TopNRowNumberOperator
 
getOperatorContext() - Method in class io.prestosql.operator.unnest.UnnestOperator
 
getOperatorContext() - Method in class io.prestosql.operator.ValuesOperator
 
getOperatorContext() - Method in class io.prestosql.operator.WindowOperator
 
getOperatorContext() - Method in class io.prestosql.operator.WorkProcessorOperatorAdapter
 
getOperatorContext() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
getOperatorContext() - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
getOperatorContext() - Method in class io.prestosql.testing.NullOutputOperator
 
getOperatorContext() - Method in class io.prestosql.testing.PageConsumerOperator
 
getOperatorContexts() - Method in class io.prestosql.operator.DriverContext
 
getOperatorDependencies() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration
 
getOperatorDependency(OperatorType) - Method in class io.prestosql.sql.relational.SpecialForm
 
getOperatorExpectedCollisionsAverages() - Method in class io.prestosql.sql.planner.planprinter.HashCollisionPlanNodeStats
 
getOperatorFactories() - Method in class io.prestosql.operator.DriverFactory
 
getOperatorHashCollisionsAverages() - Method in class io.prestosql.sql.planner.planprinter.HashCollisionPlanNodeStats
 
getOperatorHashCollisionsStdDevs() - Method in class io.prestosql.sql.planner.planprinter.HashCollisionPlanNodeStats
 
getOperatorId() - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
getOperatorId() - Method in class io.prestosql.operator.LookupOuterOperator.LookupOuterOperatorFactory
 
getOperatorId() - Method in class io.prestosql.operator.OperatorContext
 
getOperatorId() - Method in class io.prestosql.operator.OperatorStats
 
getOperatorId() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory
 
getOperatorId() - Method in class io.prestosql.operator.TableScanOperator.TableScanOperatorFactory
 
getOperatorId() - Method in interface io.prestosql.operator.WorkProcessorOperatorFactory
 
getOperatorId() - Method in interface io.prestosql.operator.WorkProcessorSourceOperatorFactory
 
getOperatorInfo() - Method in class io.prestosql.operator.BasicWorkProcessorOperatorAdapter
 
getOperatorInfo() - Method in class io.prestosql.operator.LookupJoinOperator
 
getOperatorInfo() - Method in interface io.prestosql.operator.WorkProcessorOperator
Returns OperatorInfo.
getOperatorInputPositionsAverages() - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
getOperatorInputPositionsStdDevs() - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
getOperatorInvoker(OperatorType, List<Type>, InvocationConvention) - Method in class io.prestosql.metadata.FunctionDependencies
 
getOperatorMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
getOperatorMetadata(OperatorType, List<Type>) - Method in class io.prestosql.metadata.FunctionDependencies
 
getOperatorSignatureInvoker(OperatorType, List<TypeSignature>, InvocationConvention) - Method in class io.prestosql.metadata.FunctionDependencies
 
getOperatorStats() - Method in class io.prestosql.operator.DriverContext
 
getOperatorStats() - Method in class io.prestosql.operator.DriverStats
 
getOperatorStats() - Method in class io.prestosql.operator.OperatorContext
 
getOperatorSummaries() - Method in class io.prestosql.execution.QueryStats
 
getOperatorSummaries() - Method in class io.prestosql.execution.StageStats
 
getOperatorSummaries() - Method in class io.prestosql.operator.PipelineStats
 
getOperatorType() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.OperatorDependency
 
getOperatorType() - Method in exception io.prestosql.metadata.OperatorNotFoundException
 
getOperatorType() - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
getOperatorType() - Method in class io.prestosql.operator.OperatorContext
 
getOperatorType() - Method in class io.prestosql.operator.OperatorStats
 
getOperatorType() - Method in class io.prestosql.operator.scalar.annotations.ScalarImplementationHeader
 
getOperatorType() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory
 
getOperatorType() - Method in class io.prestosql.operator.TableScanOperator.TableScanOperatorFactory
 
getOperatorType() - Method in interface io.prestosql.operator.WorkProcessorOperatorFactory
 
getOperatorType() - Method in interface io.prestosql.operator.WorkProcessorSourceOperatorFactory
 
getOperatorTypes() - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
getOptimizedLocalScheduling() - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
getOptimizerTimeout(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getOptionalCatalogMetadata(TransactionId, String) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getOptionalCatalogMetadata(TransactionId, String) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getOptionalCatalogMetadata(TransactionId, String) - Method in interface io.prestosql.transaction.TransactionManager
 
getOrCreateSubGroup(String) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getOrDefault(long, long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
getOrDefault(long, long, long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
getOrderBy() - Method in class io.prestosql.sql.planner.OrderingScheme
 
getOrderByAggregates(OrderBy) - Method in class io.prestosql.sql.analyzer.Analysis
 
getOrderByExpressions(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getOrderByWindowFunctions(OrderBy) - Method in class io.prestosql.sql.analyzer.Analysis
 
getOrdering() - Method in class io.prestosql.operator.window.FrameInfo
 
getOrdering(Symbol) - Method in class io.prestosql.sql.planner.OrderingScheme
 
getOrderingList() - Method in class io.prestosql.sql.planner.OrderingScheme
 
getOrderings() - Method in class io.prestosql.sql.planner.OrderingScheme
 
getOrderingScheme() - Method in class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
getOrderingScheme() - Method in class io.prestosql.sql.planner.plan.ExchangeNode
 
getOrderingScheme() - Method in class io.prestosql.sql.planner.plan.RemoteSourceNode
 
getOrderingScheme() - Method in class io.prestosql.sql.planner.plan.SortNode
 
getOrderingScheme() - Method in class io.prestosql.sql.planner.plan.TopNNode
 
getOrderingScheme() - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
getOrderingScheme() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getOrderingScheme() - Method in class io.prestosql.sql.planner.plan.WindowNode.Specification
 
getOrdinalityField() - Method in class io.prestosql.sql.analyzer.Analysis.UnnestAnalysis
 
getOrdinalitySymbol() - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
getOrdinalPosition() - Method in class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
getOrdinarySets() - Method in class io.prestosql.sql.analyzer.Analysis.GroupingSetAnalysis
 
getOriginalEndValue() - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
getOriginalExpressions() - Method in class io.prestosql.sql.analyzer.Analysis.GroupingSetAnalysis
 
getOriginalStartValue() - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
getOriginColumnName() - Method in class io.prestosql.sql.analyzer.Field
 
getOriginSubquery() - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
getOriginSubquery() - Method in class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
getOriginTable() - Method in class io.prestosql.sql.analyzer.Field
 
getOtherLeftFields() - Method in class io.prestosql.sql.analyzer.Analysis.JoinUsingAnalysis
 
getOtherRightFields() - Method in class io.prestosql.sql.analyzer.Analysis.JoinUsingAnalysis
 
getOuterOperatorFactory() - Method in class io.prestosql.operator.JoinOperatorFactory.OuterOperatorFactoryResult
 
getOuterPositionIterator() - Method in class io.prestosql.operator.index.IndexLookupSourceFactory
 
getOuterPositionIterator() - Method in interface io.prestosql.operator.JoinBridge
Can be called only after build and probe are finished.
getOuterPositionIterator() - Method in interface io.prestosql.operator.LookupSourceFactory
Can be called only after LookupSourceFactory.createLookupSourceProvider() is done and all users of LookupSource-s finished.
getOuterPositionIterator() - Method in interface io.prestosql.operator.NestedLoopJoinBridge
 
getOuterPositionIterator() - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
getOuterPositionIterator() - Method in interface io.prestosql.operator.TrackingLookupSourceSupplier
 
getOuterPositionsFuture(Lifespan) - Method in class io.prestosql.operator.JoinBridgeManager
 
getOuterQueryParent() - Method in class io.prestosql.sql.analyzer.Scope
 
getOutput() - Method in class io.prestosql.execution.QueryInfo
 
getOutput() - Method in class io.prestosql.operator.AggregationOperator
 
getOutput() - Method in class io.prestosql.operator.DeleteOperator
 
getOutput() - Method in class io.prestosql.operator.DevNullOperator
 
getOutput() - Method in class io.prestosql.operator.DistinctLimitOperator
 
getOutput() - Method in class io.prestosql.operator.DynamicFilterSourceOperator
 
getOutput() - Method in class io.prestosql.operator.EnforceSingleRowOperator
 
getOutput() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator
 
getOutput() - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator
 
getOutput() - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator
 
getOutput() - Method in class io.prestosql.operator.ExchangeOperator
 
getOutput() - Method in class io.prestosql.operator.ExplainAnalyzeOperator
 
getOutput() - Method in class io.prestosql.operator.FinishedOperator
 
getOutput() - Method in class io.prestosql.operator.GroupIdOperator
 
getOutput() - Method in class io.prestosql.operator.HashAggregationOperator
 
getOutput() - Method in class io.prestosql.operator.HashBuilderOperator
 
getOutput() - Method in class io.prestosql.operator.index.IndexSourceOperator
 
getOutput() - Method in class io.prestosql.operator.index.PageBufferOperator
 
getOutput() - Method in class io.prestosql.operator.index.PagesIndexBuilderOperator
 
getOutput() - Method in class io.prestosql.operator.LimitOperator
 
getOutput() - Method in class io.prestosql.operator.LookupOuterOperator
 
getOutput() - Method in class io.prestosql.operator.MarkDistinctOperator
 
getOutput() - Method in class io.prestosql.operator.MergeOperator
 
getOutput() - Method in class io.prestosql.operator.NestedLoopBuildOperator
 
getOutput() - Method in class io.prestosql.operator.NestedLoopJoinOperator
 
getOutput() - Method in interface io.prestosql.operator.Operator
Gets an output page from the operator.
getOutput() - Method in class io.prestosql.operator.OrderByOperator
 
getOutput() - Method in class io.prestosql.operator.PageSourceOperator
 
getOutput() - Method in class io.prestosql.operator.PartitionedOutputOperator
 
getOutput() - Method in class io.prestosql.operator.RowNumberOperator
 
getOutput() - Method in class io.prestosql.operator.SetBuilderOperator
 
getOutput() - Method in class io.prestosql.operator.SpatialIndexBuilderOperator
 
getOutput() - Method in class io.prestosql.operator.SpatialJoinOperator
 
getOutput() - Method in class io.prestosql.operator.StatisticsWriterOperator
 
getOutput() - Method in class io.prestosql.operator.TableDeleteOperator
 
getOutput() - Method in class io.prestosql.operator.TableFinishOperator
 
getOutput() - Method in class io.prestosql.operator.TableScanOperator
 
getOutput() - Method in class io.prestosql.operator.TableWriterOperator
 
getOutput() - Method in class io.prestosql.operator.TaskOutputOperator
 
getOutput() - Method in class io.prestosql.operator.TopNProcessor
 
getOutput() - Method in class io.prestosql.operator.TopNRowNumberOperator
 
getOutput() - Method in class io.prestosql.operator.unnest.UnnestOperator
 
getOutput() - Method in class io.prestosql.operator.ValuesOperator
 
getOutput() - Method in class io.prestosql.operator.WindowOperator
 
getOutput() - Method in class io.prestosql.operator.WorkProcessorOperatorAdapter
 
getOutput() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
getOutput() - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
getOutput() - Method in class io.prestosql.sql.planner.plan.TableDeleteNode
 
getOutput() - Method in class io.prestosql.testing.NullOutputOperator
 
getOutput() - Method in class io.prestosql.testing.PageConsumerOperator
 
getOutputBufferPeakMemoryUsage() - Method in class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputInfo
 
getOutputBuffers() - Method in class io.prestosql.execution.SqlStageExecution
 
getOutputBuffers() - Method in class io.prestosql.execution.TaskInfo
 
getOutputChannels() - Method in class io.prestosql.operator.JoinProbe
 
getOutputDataSize() - Method in class io.prestosql.execution.QueryStats
 
getOutputDataSize() - Method in class io.prestosql.execution.SqlTaskIoStats
 
getOutputDataSize() - Method in class io.prestosql.execution.StageStats
 
getOutputDataSize() - Method in class io.prestosql.operator.DriverContext
 
getOutputDataSize() - Method in class io.prestosql.operator.DriverStats
 
getOutputDataSize() - Method in class io.prestosql.operator.OperatorContext
 
getOutputDataSize() - Method in class io.prestosql.operator.OperatorStats
 
getOutputDataSize() - Method in class io.prestosql.operator.PipelineContext
 
getOutputDataSize() - Method in class io.prestosql.operator.PipelineStats
 
getOutputDataSize() - Method in class io.prestosql.operator.TaskContext
 
getOutputDataSize() - Method in class io.prestosql.operator.TaskStats
 
getOutputDependencies() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getOutputDescriptor() - Method in class io.prestosql.sql.analyzer.Analysis
 
getOutputDescriptor(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getOutputFunction() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getOutputFunction() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getOutputIds() - Method in class io.prestosql.server.TaskUpdateRequest
 
getOutputLayout() - Method in class io.prestosql.sql.planner.PartitioningScheme
 
getOutputPages() - Method in class io.prestosql.operator.AssignUniqueIdOperator
 
getOutputPages() - Method in class io.prestosql.operator.BasicWorkProcessorOperatorAdapter
 
getOutputPages() - Method in class io.prestosql.operator.FilterAndProjectOperator
 
getOutputPages() - Method in class io.prestosql.operator.HashSemiJoinOperator
 
getOutputPages() - Method in class io.prestosql.operator.LookupJoinOperator
 
getOutputPages() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
getOutputPages() - Method in class io.prestosql.operator.StreamingAggregationOperator
 
getOutputPages() - Method in class io.prestosql.operator.TableScanWorkProcessorOperator
 
getOutputPages() - Method in class io.prestosql.operator.TopNOperator
 
getOutputPages() - Method in interface io.prestosql.operator.WorkProcessorOperator
 
getOutputPositions() - Method in class io.prestosql.execution.QueryStats
 
getOutputPositions() - Method in class io.prestosql.execution.SqlTaskIoStats
 
getOutputPositions() - Method in class io.prestosql.execution.StageStats
 
getOutputPositions() - Method in class io.prestosql.operator.DriverContext
 
getOutputPositions() - Method in class io.prestosql.operator.DriverStats
 
getOutputPositions() - Method in class io.prestosql.operator.OperatorContext
 
getOutputPositions() - Method in class io.prestosql.operator.OperatorStats
 
getOutputPositions() - Method in class io.prestosql.operator.PipelineContext
 
getOutputPositions() - Method in class io.prestosql.operator.PipelineStats
 
getOutputPositions() - Method in class io.prestosql.operator.TaskContext
 
getOutputPositions() - Method in class io.prestosql.operator.TaskStats
 
getOutputRowCount() - Method in class io.prestosql.cost.PlanNodeStatsAndCostSummary
 
getOutputRowCount() - Method in class io.prestosql.cost.PlanNodeStatsEstimate
Returns estimated number of rows.
getOutputRowCount() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.EstimatedStatsAndCost
 
getOutputs() - Method in class io.prestosql.sql.planner.plan.Assignments
 
getOutputs() - Method in class io.prestosql.sql.planner.plan.UnnestNode.Mapping
 
getOutputs() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getOutputSizeInBytes() - Method in class io.prestosql.cost.PlanNodeStatsAndCostSummary
 
getOutputSizeInBytes() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.EstimatedStatsAndCost
 
getOutputSizeInBytes(Collection<Symbol>, TypeProvider) - Method in class io.prestosql.cost.PlanNodeStatsEstimate
Returns estimated data size.
getOutputStage() - Method in class io.prestosql.execution.QueryInfo
 
getOutputSymbol() - Method in class io.prestosql.sql.planner.plan.ExplainAnalyzeNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.iterative.GroupReference
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.AssignUniqueId
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.DeleteNode
Aggregate information about deleted data
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.DistinctLimitNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.EnforceSingleRowNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.ExchangeNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.ExplainAnalyzeNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.FilterNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.IndexSourceNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.LimitNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.MarkDistinctNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.OffsetNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.OutputNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.PlanNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.ProjectNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.RemoteSourceNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.RowNumberNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.SampleNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.SetOperationNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.SortNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.TableDeleteNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.TableFinishNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.TableScanNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.TopNNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.ValuesNode
 
getOutputSymbols() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getOutputTable() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan
 
getOutputTableHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
getOutputTableHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getOutputType() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getOutputType() - Method in class io.prestosql.sql.planner.StatisticsAggregationPlanner.ColumnStatisticsAggregation
 
getOutputTypes() - Method in class io.prestosql.operator.index.IndexBuildDriverFactoryProvider
 
getOutputTypes() - Method in class io.prestosql.operator.index.IndexLoader
 
getOutputTypes() - Method in class io.prestosql.operator.index.IndexLookupSourceFactory
 
getOutputTypes() - Method in class io.prestosql.operator.index.IndexSnapshotBuilder
 
getOutputTypes() - Method in interface io.prestosql.operator.LookupSourceFactory
 
getOutputTypes() - Method in class io.prestosql.operator.PagesSpatialIndexFactory
 
getOutputTypes() - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
getOverflow() - Method in interface io.prestosql.operator.aggregation.state.LongDecimalWithOverflowState
 
getOverflow() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
getOverflow() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
getPage() - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
getPage() - Method in class io.prestosql.operator.JoinProbe
 
getPage() - Method in class io.prestosql.util.MergeSortedPages.PageWithPosition
 
getPage(long) - Method in class io.prestosql.operator.RowReferencePageManager
 
getPageBufferClientMaxCallbackThreads() - Method in class io.prestosql.operator.ExchangeClientConfig
 
getPageBufferClientStatuses() - Method in class io.prestosql.operator.ExchangeClientStatus
 
getPageBufferInfo() - Method in class io.prestosql.execution.buffer.BufferInfo
 
getPageBuilder() - Method in class io.prestosql.operator.scalar.MapConstructor.State
 
getPageCodecMarkers() - Method in class io.prestosql.execution.buffer.SerializedPage
 
getPageIndexerFactory() - Method in class io.prestosql.connector.ConnectorContextInstance
 
getPageIndexerFactory() - Method in class io.prestosql.testing.TestingConnectorContext
 
getPages() - Method in class io.prestosql.metadata.InternalTable
 
getPages() - Method in class io.prestosql.operator.HttpPageBufferClient.PagesResponse
 
getPages() - Method in class io.prestosql.operator.NestedLoopJoinPages
 
getPages() - Method in class io.prestosql.operator.PagesIndex
 
getPagesAdded() - Method in class io.prestosql.execution.buffer.PageBufferInfo
 
getPagesAdded() - Method in class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputInfo
 
getPagesFuture() - Method in interface io.prestosql.operator.NestedLoopJoinBridge
 
getPagesFuture() - Method in class io.prestosql.operator.NestedLoopJoinPagesSupplier
 
getPagesIndexOrderingsStats() - Method in class io.prestosql.sql.gen.OrderingCompiler
 
getPageSinkPeakMemoryUsage() - Method in class io.prestosql.operator.TableWriterOperator.TableWriterInfo
 
getPageSorter() - Method in class io.prestosql.connector.ConnectorContextInstance
 
getPageSorter() - Method in class io.prestosql.testing.TestingConnectorContext
 
getPageSourceManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getPageSourceManager() - Method in class io.prestosql.testing.LocalQueryRunner
 
getPageSourceManager() - Method in interface io.prestosql.testing.QueryRunner
 
getPageSourceProvider() - Method in class io.prestosql.connector.informationschema.InformationSchemaConnector
 
getPageSourceProvider() - Method in class io.prestosql.connector.system.SystemConnector
 
getPagesReceived() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getPagesRejected() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getPagesSent() - Method in class io.prestosql.execution.buffer.BufferInfo
 
getPagesSpatialIndexFactory() - Method in class io.prestosql.operator.SpatialIndexBuilderOperator.SpatialIndexBuilderOperatorFactory
 
getPageWithPositionsComparatorsStats() - Method in class io.prestosql.sql.gen.OrderingCompiler
 
getParameterCount(Statement) - Static method in class io.prestosql.execution.ParameterExtractor
 
getParameterizedType(String, List<TypeSignatureParameter>) - Method in interface io.prestosql.metadata.Metadata
 
getParameters() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getParameters() - Method in class io.prestosql.execution.QueryPreparer.PreparedQuery
 
getParameters() - Method in class io.prestosql.sql.analyzer.Analysis
 
getParameters(Statement) - Static method in class io.prestosql.execution.ParameterExtractor
 
getParameterType() - Method in class io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata
 
getParameterTypes() - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.SpecializeContext
 
getParameterTypes() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
getParametricTypes() - Method in interface io.prestosql.metadata.Metadata
 
getParametricTypes() - Method in class io.prestosql.metadata.MetadataManager
 
getParams() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkEcPublicKey
 
getParsedPath() - Method in class io.prestosql.sql.SqlPath
 
getPartialAggregation() - Method in class io.prestosql.sql.planner.plan.StatisticAggregations.Parts
 
getPartition() - Method in class io.prestosql.execution.buffer.PageBufferInfo
 
getPartition() - Method in class io.prestosql.operator.PagesRTreeIndex.GeometryWithPosition
 
getPartition(int, int, Page) - Method in interface io.prestosql.operator.HashGenerator
 
getPartition(long) - Method in class io.prestosql.operator.exchange.LocalPartitionGenerator
 
getPartition(Page, int) - Method in class io.prestosql.operator.BucketPartitionFunction
 
getPartition(Page, int) - Method in class io.prestosql.operator.exchange.LocalPartitionGenerator
 
getPartition(Page, int) - Method in interface io.prestosql.operator.PartitionFunction
 
getPartitionBy() - Method in class io.prestosql.sql.planner.plan.RowNumberNode
 
getPartitionBy() - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
getPartitionBy() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getPartitionBy() - Method in class io.prestosql.sql.planner.plan.WindowNode.Specification
 
getPartitionColumns() - Method in class io.prestosql.metadata.NewTableLayout
 
getPartitionCount() - Method in class io.prestosql.operator.BucketPartitionFunction
 
getPartitionCount() - Method in class io.prestosql.operator.exchange.LocalPartitionGenerator
 
getPartitionCount() - Method in interface io.prestosql.operator.PartitionFunction
 
getPartitionedSourceNodes() - Method in class io.prestosql.sql.planner.PlanFragment
 
getPartitionedSourceOrder() - Method in class io.prestosql.sql.planner.LocalExecutionPlanner.LocalExecutionPlan
 
getPartitionedSources() - Method in class io.prestosql.sql.planner.PlanFragment
 
getPartitionedSplitCount() - Method in interface io.prestosql.execution.RemoteTask
 
getPartitionedSplitCount() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
getPartitionedSplitsOnNode(InternalNode) - Method in class io.prestosql.execution.NodeTaskMap
 
getPartitionEnd() - Method in class io.prestosql.operator.window.WindowPartition
 
getPartitionFunction(Session, PartitioningScheme, List<Type>) - Method in class io.prestosql.sql.planner.NodePartitioningManager
 
getPartitionFunction(List<Type>, boolean, int[], BlockTypeOperators) - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
getPartitioning() - Method in class io.prestosql.metadata.NewTableLayout
 
getPartitioning() - Method in class io.prestosql.sql.planner.PartitioningScheme
 
getPartitioning() - Method in class io.prestosql.sql.planner.PlanFragment
 
getPartitioning() - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
getPartitioningColumns() - Method in class io.prestosql.metadata.TableProperties.TablePartitioning
 
getPartitioningColumns() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
getPartitioningColumns() - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
getPartitioningHandle() - Method in class io.prestosql.metadata.TableProperties.TablePartitioning
 
getPartitioningHandleClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getPartitioningHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getPartitioningScheme() - Method in class io.prestosql.sql.planner.plan.ExchangeNode
 
getPartitioningScheme() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getPartitioningScheme() - Method in class io.prestosql.sql.planner.PlanFragment
 
getPartitionStart() - Method in class io.prestosql.operator.window.WindowPartition
 
getPartitionToNode() - Method in class io.prestosql.sql.planner.NodePartitionMap
 
getPassword() - Method in class io.prestosql.server.security.BasicAuthCredentials
 
getPath() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getPath() - Method in interface io.prestosql.server.SessionContext
 
getPath() - Method in class io.prestosql.Session
 
getPath() - Method in class io.prestosql.SessionRepresentation
 
getPath() - Method in class io.prestosql.sql.SqlEnvironmentConfig
 
getPathToRoot() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getPathToRoot() - Method in class io.prestosql.server.QueryStateInfo
 
getPattern() - Method in class io.prestosql.cost.AggregationStatsRule
 
getPattern() - Method in class io.prestosql.cost.AssignUniqueIdStatsRule
 
getPattern() - Method in interface io.prestosql.cost.ComposableStatsCalculator.Rule
 
getPattern() - Method in class io.prestosql.cost.EnforceSingleRowStatsRule
 
getPattern() - Method in class io.prestosql.cost.ExchangeStatsRule
 
getPattern() - Method in class io.prestosql.cost.FilterStatsRule
 
getPattern() - Method in class io.prestosql.cost.JoinStatsRule
 
getPattern() - Method in class io.prestosql.cost.LimitStatsRule
 
getPattern() - Method in class io.prestosql.cost.OutputStatsRule
 
getPattern() - Method in class io.prestosql.cost.ProjectStatsRule
 
getPattern() - Method in class io.prestosql.cost.RowNumberStatsRule
 
getPattern() - Method in class io.prestosql.cost.SemiJoinStatsRule
 
getPattern() - Method in class io.prestosql.cost.SimpleFilterProjectSemiJoinStatsRule
 
getPattern() - Method in class io.prestosql.cost.SortStatsRule
 
getPattern() - Method in class io.prestosql.cost.SpatialJoinStatsRule
 
getPattern() - Method in class io.prestosql.cost.TableScanStatsRule
 
getPattern() - Method in class io.prestosql.cost.TopNStatsRule
 
getPattern() - Method in class io.prestosql.cost.UnionStatsRule
 
getPattern() - Method in class io.prestosql.cost.ValuesStatsRule
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.AddIntermediateAggregations
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ApplyTableScanRedirection
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.CreatePartialTopN
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.DetermineJoinDistributionType
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.DetermineSemiJoinDistributionType
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.EliminateCrossJoins
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.EvaluateZeroSample
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ExtractDereferencesFromFilterAboveScan
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins.ExtractSpatialInnerJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins.ExtractSpatialLeftJoin
 
getPattern() - Method in interface io.prestosql.sql.planner.iterative.Rule
Returns a pattern to which plan nodes this rule applies.
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ImplementBernoulliSampleAsFilter
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ImplementExceptAll
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ImplementExceptDistinctAsUnion
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ImplementFilteredAggregations
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ImplementIntersectAll
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ImplementIntersectDistinctAsUnion
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ImplementLimitWithTies
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ImplementOffset
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.InlineProjections
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MergeExcept
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MergeFilters
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MergeIntersect
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MergeLimitOverProjectWithSort
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MergeLimits
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MergeLimitWithDistinct
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MergeLimitWithSort
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MergeLimitWithTopN
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MergeUnion
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MultipleDistinctAggregationToMarkDistinct
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ProjectOffPushDownRule
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneAggregationSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneApplyCorrelation
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneApplySourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneCorrelatedJoinCorrelation
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneCountAggregationOverScalar
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneDeleteSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneDistinctAggregation
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneDistinctLimitSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneExceptSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneExchangeSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneExplainAnalyzeSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneGroupIdSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneIntersectSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneJoinChildrenColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneOrderByInAggregation
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneOutputSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneSemiJoinFilteringSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneSpatialJoinChildrenColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneTableWriterSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneUnionSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneUnnestSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushAggregationIntoTableScan
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushAggregationThroughOuterJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDeleteIntoConnector
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDistinctLimitIntoTableScan
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughAssignUniqueId
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughLimit
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughMarkDistinct
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughRowNumber
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughSort
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughTopN
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughTopNRowNumber
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughWindow
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughFilter
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughProject
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughSemiJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughUnnest
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitIntoTableScan
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughMarkDistinct
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughOffset
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughOuterJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughProject
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughSemiJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitThroughUnion
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushOffsetThroughProject
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushPartialAggregationThroughExchange
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushPartialAggregationThroughJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushPredicateIntoTableScan
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushPredicateThroughProjectIntoRowNumber
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushPredicateThroughProjectIntoWindow
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushProjectionIntoTableScan
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushProjectionThroughExchange
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushProjectionThroughUnion
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushRemoteExchangeThroughAssignUniqueId
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushSampleIntoTableScan
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushTableWriteThroughUnion
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushTopNIntoTableScan
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushTopNThroughOuterJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushTopNThroughProject
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushTopNThroughUnion
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveAggregationInSemiJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveEmptyDelete
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveFullSample
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantCrossJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantDistinctLimit
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantEnforceSingleRowNode
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantExists
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantIdentityProjections
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantLimit
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantOffset
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantSort
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantTableScanPredicate
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantTopN
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveTrivialFilters
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveUnreferencedScalarApplyNodes
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RemoveUnreferencedScalarSubqueries
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.ReorderJoins
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.RewriteSpatialPartitioningAggregation
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.SimplifyCountOverConstant
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.SingleDistinctAggregationToGroupBy
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedDistinctAggregationWithoutProjection
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedDistinctAggregationWithProjection
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGlobalAggregationWithoutProjection
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGlobalAggregationWithProjection
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGroupedAggregationWithoutProjection
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGroupedAggregationWithProjection
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedJoinToJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedScalarSubquery
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedSingleRowSubqueryToProject
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformExistsApplyToCorrelatedJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformFilteringSemiJoinToInnerJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedInPredicateSubqueryToSemiJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedSubqueryToJoin
 
getPeakMemoryBytes() - Method in class io.prestosql.server.QueryProgressStats
 
getPeakMemoryUsage() - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
getPeakMemoryUsage() - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
getPeakMemoryUsage() - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
getPeakMemoryUsage() - Method in interface io.prestosql.execution.buffer.OutputBuffer
 
getPeakMemoryUsage() - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
getPeakNonRevocableMemoryInBytes() - Method in class io.prestosql.execution.QueryStateMachine
 
getPeakNonRevocableMemoryReservation() - Method in class io.prestosql.execution.QueryStats
 
getPeakRevocableMemoryInBytes() - Method in class io.prestosql.execution.QueryStateMachine
 
getPeakRevocableMemoryReservation() - Method in class io.prestosql.execution.QueryStats
 
getPeakRevocableMemoryReservation() - Method in class io.prestosql.execution.StageStats
 
getPeakRevocableMemoryReservation() - Method in class io.prestosql.operator.OperatorStats
 
getPeakSystemMemoryReservation() - Method in class io.prestosql.operator.OperatorStats
 
getPeakTaskRevocableMemory() - Method in class io.prestosql.execution.QueryStateMachine
 
getPeakTaskRevocableMemory() - Method in class io.prestosql.execution.QueryStats
 
getPeakTaskTotalMemory() - Method in class io.prestosql.execution.QueryStateMachine
 
getPeakTaskTotalMemory() - Method in class io.prestosql.execution.QueryStats
 
getPeakTaskUserMemory() - Method in class io.prestosql.execution.QueryStateMachine
 
getPeakTaskUserMemory() - Method in class io.prestosql.execution.QueryStats
 
getPeakTotalMemoryInBytes() - Method in class io.prestosql.execution.QueryStateMachine
 
getPeakTotalMemoryReservation() - Method in class io.prestosql.execution.QueryStats
 
getPeakTotalMemoryReservation() - Method in class io.prestosql.operator.OperatorStats
 
getPeakTotalMemoryReservation() - Method in class io.prestosql.server.BasicQueryStats
 
getPeakUserMemoryInBytes() - Method in class io.prestosql.execution.QueryStateMachine
 
getPeakUserMemoryReservation() - Method in class io.prestosql.execution.QueryStats
 
getPeakUserMemoryReservation() - Method in class io.prestosql.execution.StageStats
 
getPeakUserMemoryReservation() - Method in class io.prestosql.operator.OperatorStats
 
getPeakUserMemoryReservation() - Method in class io.prestosql.server.BasicQueryStats
 
getPercentile() - Method in interface io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileState
 
getPercentile() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.GroupedQuantileDigestAndPercentileState
 
getPercentile() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.SingleQuantileDigestAndPercentileState
 
getPercentile() - Method in interface io.prestosql.operator.aggregation.state.TDigestAndPercentileState
 
getPercentile() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.GroupedTDigestAndPercentileState
 
getPercentile() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.SingleTDigestAndPercentileState
 
getPercentiles() - Method in interface io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayState
 
getPercentiles() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.GroupedTDigestAndPercentileArrayState
 
getPercentiles() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.SingleTDigestAndPercentileArrayState
 
getPhysicalInputDataSize() - Method in class io.prestosql.execution.BasicStageStats
 
getPhysicalInputDataSize() - Method in class io.prestosql.execution.QueryStats
 
getPhysicalInputDataSize() - Method in class io.prestosql.execution.StageStats
 
getPhysicalInputDataSize() - Method in class io.prestosql.operator.DriverStats
 
getPhysicalInputDataSize() - Method in class io.prestosql.operator.OperatorStats
 
getPhysicalInputDataSize() - Method in class io.prestosql.operator.PipelineStats
 
getPhysicalInputDataSize() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
getPhysicalInputDataSize() - Method in class io.prestosql.operator.TableScanWorkProcessorOperator
 
getPhysicalInputDataSize() - Method in class io.prestosql.operator.TaskStats
 
getPhysicalInputDataSize() - Method in interface io.prestosql.operator.WorkProcessorSourceOperator
 
getPhysicalInputDataSize() - Method in class io.prestosql.server.BasicQueryStats
 
getPhysicalInputPositions() - Method in class io.prestosql.execution.BasicStageStats
 
getPhysicalInputPositions() - Method in class io.prestosql.execution.QueryStats
 
getPhysicalInputPositions() - Method in class io.prestosql.execution.StageStats
 
getPhysicalInputPositions() - Method in class io.prestosql.operator.DriverStats
 
getPhysicalInputPositions() - Method in class io.prestosql.operator.OperatorStats
 
getPhysicalInputPositions() - Method in class io.prestosql.operator.PipelineStats
 
getPhysicalInputPositions() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
getPhysicalInputPositions() - Method in class io.prestosql.operator.TableScanWorkProcessorOperator
 
getPhysicalInputPositions() - Method in class io.prestosql.operator.TaskStats
 
getPhysicalInputPositions() - Method in interface io.prestosql.operator.WorkProcessorSourceOperator
 
getPhysicalInputReadTime() - Method in class io.prestosql.execution.BasicStageStats
 
getPhysicalInputReadTime() - Method in class io.prestosql.execution.QueryStats
 
getPhysicalInputReadTime() - Method in class io.prestosql.execution.StageStats
 
getPhysicalInputReadTime() - Method in class io.prestosql.operator.DriverStats
 
getPhysicalInputReadTime() - Method in class io.prestosql.operator.PipelineStats
 
getPhysicalInputReadTime() - Method in class io.prestosql.operator.TaskStats
 
getPhysicalWrittenDataSize() - Method in class io.prestosql.execution.QueryStats
 
getPhysicalWrittenDataSize() - Method in class io.prestosql.execution.StageStats
 
getPhysicalWrittenDataSize() - Method in class io.prestosql.execution.TaskStatus
 
getPhysicalWrittenDataSize() - Method in class io.prestosql.operator.DriverContext
 
getPhysicalWrittenDataSize() - Method in class io.prestosql.operator.DriverStats
 
getPhysicalWrittenDataSize() - Method in class io.prestosql.operator.OperatorContext
 
getPhysicalWrittenDataSize() - Method in class io.prestosql.operator.OperatorStats
 
getPhysicalWrittenDataSize() - Method in class io.prestosql.operator.PipelineContext
 
getPhysicalWrittenDataSize() - Method in class io.prestosql.operator.PipelineStats
 
getPhysicalWrittenDataSize() - Method in class io.prestosql.operator.TaskStats
 
getPipelineContext() - Method in class io.prestosql.operator.DriverContext
 
getPipelineContexts() - Method in class io.prestosql.operator.TaskContext
 
getPipelineExecutionStrategy() - Method in class io.prestosql.operator.DriverFactory
 
getPipelineId() - Method in class io.prestosql.operator.DriverFactory
 
getPipelineId() - Method in class io.prestosql.operator.index.IndexBuildDriverFactoryProvider
 
getPipelineId() - Method in class io.prestosql.operator.OperatorStats
 
getPipelineId() - Method in class io.prestosql.operator.PipelineContext
 
getPipelineId() - Method in class io.prestosql.operator.PipelineStats
 
getPipelineMemoryContext() - Method in class io.prestosql.operator.PipelineContext
 
getPipelines() - Method in class io.prestosql.operator.TaskStats
 
getPipelineStats() - Method in class io.prestosql.operator.PipelineContext
 
getPipelineStatus() - Method in class io.prestosql.operator.PipelineContext
 
getPlacementCountersByName() - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorFactory
 
getPlan() - Method in class io.prestosql.execution.StageInfo
 
getPlan(Session, Statement, ExplainType.Type, List<Expression>, WarningCollector) - Method in class io.prestosql.sql.analyzer.QueryExplainer
 
getPlanningTime() - Method in class io.prestosql.execution.QueryStats
 
getPlanNode() - Method in class io.prestosql.sql.planner.iterative.rule.PlanNodeWithCost
 
getPlanNode() - Method in class io.prestosql.sql.planner.iterative.rule.SetOperationNodeTranslator.TranslationResult
 
getPlanNodeCpuTime() - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
getPlanNodeId() - Method in class io.prestosql.execution.Input
 
getPlanNodeId() - Method in class io.prestosql.execution.ScheduledSplit
 
getPlanNodeId() - Method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
 
getPlanNodeId() - Method in interface io.prestosql.execution.scheduler.SourceScheduler
 
getPlanNodeId() - Method in class io.prestosql.execution.TaskSource
 
getPlanNodeId() - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
getPlanNodeId() - Method in class io.prestosql.operator.OperatorStats
 
getPlanNodeId() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory
 
getPlanNodeId() - Method in class io.prestosql.operator.TableScanOperator.TableScanOperatorFactory
 
getPlanNodeId() - Method in interface io.prestosql.operator.WorkProcessorOperatorFactory
 
getPlanNodeId() - Method in interface io.prestosql.operator.WorkProcessorSourceOperatorFactory
 
getPlanNodeId() - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
getPlanNodeInputDataSize() - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
getPlanNodeInputPositions() - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
getPlanNodeOutputDataSize() - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
getPlanNodeOutputPositions() - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
getPlanNodeScheduledTime() - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
getPlanOptimizers(boolean) - Method in class io.prestosql.testing.LocalQueryRunner
 
getPlugins() - Method in class io.prestosql.server.PluginManagerConfig
 
getPoolId() - Method in class io.prestosql.memory.MemoryPoolAssignment
 
getPools() - Method in class io.prestosql.memory.LocalMemoryManager
 
getPools() - Method in class io.prestosql.memory.MemoryInfo
 
getPosition() - Method in interface io.prestosql.operator.aggregation.state.BlockPositionState
 
getPosition() - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
getPosition() - Method in class io.prestosql.operator.JoinProbe
 
getPosition() - Method in class io.prestosql.operator.PagesRTreeIndex.GeometryWithPosition
 
getPosition() - Method in class io.prestosql.util.MergeSortedPages.PageWithPosition
 
getPosition(long) - Method in class io.prestosql.operator.RowReferencePageManager
 
getPositionCount() - Method in class io.prestosql.execution.buffer.SerializedPage
 
getPositionCount() - Method in class io.prestosql.operator.GroupByIdBlock
 
getPositionCount() - Method in class io.prestosql.operator.PagesHash
 
getPositionCount() - Method in class io.prestosql.operator.PagesIndex
 
getPositions() - Method in class io.prestosql.operator.project.SelectedPositions
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.operator.GroupByIdBlock
 
getPrecision() - Method in class io.prestosql.testing.MaterializedRow
 
getPredicate() - Method in class io.prestosql.execution.TableInfo
 
getPredicate() - Method in class io.prestosql.metadata.TableProperties
 
getPredicate() - Method in class io.prestosql.sql.planner.plan.FilterNode
 
getPrefixes() - Method in class io.prestosql.connector.informationschema.InformationSchemaTableHandle
 
getPreGroupedSymbols() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getPreloadedWarnings() - Method in class io.prestosql.testing.TestingWarningCollectorConfig
 
getPreparedQuery() - Method in class io.prestosql.execution.QueryInfo
 
getPreparedQuery() - Method in class io.prestosql.server.BasicQueryInfo
 
getPreparedStatement(String) - Method in class io.prestosql.Session
 
getPreparedStatementFromExecute(Execute) - Method in class io.prestosql.Session
 
getPreparedStatements() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getPreparedStatements() - Method in interface io.prestosql.server.SessionContext
 
getPreparedStatements() - Method in class io.prestosql.Session
 
getPreparedStatements() - Method in class io.prestosql.SessionRepresentation
 
getPrepareSql() - Method in class io.prestosql.execution.QueryPreparer.PreparedQuery
 
getPrePartitionedInputs() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getPreSortedOrderPrefix() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getPrincipal() - Method in class io.prestosql.SessionRepresentation
 
getPrincipalHostname() - Method in class io.prestosql.server.security.KerberosConfig
 
getPriority() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
getPriority() - Method in class io.prestosql.execution.executor.TaskHandle
 
getProbe() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode.EquiJoinClause
 
getProbeHashSymbol() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode
 
getProbeSource() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode
 
getProcedure() - Method in class io.prestosql.connector.system.KillQueryProcedure
 
getProcedureRegistry() - Method in interface io.prestosql.metadata.Metadata
 
getProcedureRegistry() - Method in class io.prestosql.metadata.MetadataManager
 
getProcedures() - Method in class io.prestosql.connector.system.GlobalSystemConnector
 
getProcedureTester() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getProcessCpuLoad() - Method in class io.prestosql.server.NodeStatus
 
getProcessedInputDataSize() - Method in class io.prestosql.execution.QueryStats
 
getProcessedInputDataSize() - Method in class io.prestosql.execution.StageStats
 
getProcessedInputDataSize() - Method in class io.prestosql.operator.DriverStats
 
getProcessedInputDataSize() - Method in class io.prestosql.operator.PipelineContext
 
getProcessedInputDataSize() - Method in class io.prestosql.operator.PipelineStats
 
getProcessedInputDataSize() - Method in class io.prestosql.operator.TaskContext
 
getProcessedInputDataSize() - Method in class io.prestosql.operator.TaskStats
 
getProcessedInputPositions() - Method in class io.prestosql.execution.QueryStats
 
getProcessedInputPositions() - Method in class io.prestosql.execution.StageStats
 
getProcessedInputPositions() - Method in class io.prestosql.operator.DriverStats
 
getProcessedInputPositions() - Method in class io.prestosql.operator.PipelineStats
 
getProcessedInputPositions() - Method in class io.prestosql.operator.TaskStats
 
getProcessedRows() - Method in class io.prestosql.operator.project.CursorProcessorOutput
 
getProcessorExecutor() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getProcessors() - Method in class io.prestosql.server.NodeStatus
 
getProgress() - Method in class io.prestosql.server.QueryStateInfo
 
getProgressPercentage() - Method in class io.prestosql.execution.BasicStageStats
 
getProgressPercentage() - Method in class io.prestosql.execution.QueryStats
 
getProgressPercentage() - Method in class io.prestosql.server.BasicQueryStats
 
getProgressPercentage() - Method in class io.prestosql.server.QueryProgressStats
 
getProjectionCache() - Method in class io.prestosql.sql.gen.PageFunctionCompiler
 
getProjections() - Method in class io.prestosql.operator.project.PageProcessor
 
getProperty(String, Class<T>) - Method in class io.prestosql.FullConnectorSession
 
getProperty(String, Class<T>) - Method in class io.prestosql.testing.TestingConnectorSession
 
getPropertyName() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
getPublicExponent() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkRsaPublicKey
 
getQualifiedName() - Method in class io.prestosql.metadata.TableMetadata
 
getQuantifiedComparisons() - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getQuantifiedComparisons() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getQuantifiedComparisonSubqueries(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getQuantileDigest() - Method in interface io.prestosql.operator.aggregation.state.QuantileDigestState
 
getQuantileDigest() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.GroupedQuantileDigestState
 
getQuantileDigest() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.SingleQuantileDigestState
 
getQueries() - Method in class io.prestosql.dispatcher.DispatchManager
 
getQueries() - Method in interface io.prestosql.execution.QueryManager
 
getQueries() - Method in class io.prestosql.execution.SqlQueryManager
 
getQueriesKilledDueToOutOfMemory() - Method in class io.prestosql.memory.ClusterMemoryManager
 
getQueriesQueuedOnInternal() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
getQuery() - Method in class io.prestosql.execution.QueryInfo
 
getQuery() - Method in class io.prestosql.server.BasicQueryInfo
 
getQuery() - Method in class io.prestosql.server.QueryStateInfo
 
getQuery() - Method in class io.prestosql.sql.analyzer.Analysis.RefreshMaterializedViewAnalysis
 
getQuery(QueryId) - Method in class io.prestosql.dispatcher.DispatchManager
 
getQuery(QueryId) - Method in class io.prestosql.execution.QueryTracker
 
getQuery(QueryId, String, long) - Method in class io.prestosql.server.protocol.ExecutingStatementResource
 
getQueryBoundaryScope() - Method in class io.prestosql.sql.analyzer.Scope
 
getQueryContext() - Method in class io.prestosql.execution.SqlTask
 
getQueryContext() - Method in class io.prestosql.operator.TaskContext
 
getQueryContext(QueryId) - Method in class io.prestosql.execution.SqlTaskManager
 
getQueryExecutionPolicy() - Method in class io.prestosql.execution.QueryManagerConfig
 
getQueryId() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getQueryId() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getQueryId() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getQueryId() - Method in class io.prestosql.execution.QueryInfo
 
getQueryId() - Method in class io.prestosql.execution.QueryStateMachine
 
getQueryId() - Method in interface io.prestosql.execution.QueryTracker.TrackedQuery
 
getQueryId() - Method in class io.prestosql.execution.SqlQueryExecution
 
getQueryId() - Method in class io.prestosql.execution.StageId
 
getQueryId() - Method in class io.prestosql.execution.TaskId
 
getQueryId() - Method in class io.prestosql.FullConnectorSession
 
getQueryId() - Method in class io.prestosql.memory.LowMemoryKiller.QueryMemoryInfo
 
getQueryId() - Method in class io.prestosql.memory.MemoryPoolAssignment
 
getQueryId() - Method in class io.prestosql.security.SecurityContext
 
getQueryId() - Method in class io.prestosql.server.BasicQueryInfo
 
getQueryId() - Method in class io.prestosql.server.QueryStateInfo
 
getQueryId() - Method in class io.prestosql.Session
 
getQueryId() - Method in class io.prestosql.SessionRepresentation
 
getQueryId() - Method in class io.prestosql.testing.TestingConnectorSession
 
getQueryInfo() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getQueryInfo() - Method in interface io.prestosql.execution.QueryExecution
 
getQueryInfo() - Method in class io.prestosql.execution.SqlQueryExecution
 
getQueryInfo(QueryId) - Method in class io.prestosql.dispatcher.DispatchManager
 
getQueryInfo(QueryId) - Method in interface io.prestosql.execution.QueryManager
 
getQueryInfo(QueryId) - Method in interface io.prestosql.execution.QueryPerformanceFetcher
 
getQueryInfo(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
getQueryInfo(QueryId, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.QueryResource
 
getQueryInfo(QueryId, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.ui.UiQueryResource
 
getQueryManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getQueryManagerExecutorPoolSize() - Method in class io.prestosql.execution.QueryManagerConfig
 
getQueryMaxCpuTime() - Method in class io.prestosql.execution.QueryManagerConfig
 
getQueryMaxCpuTime(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryMaxExecutionTime() - Method in class io.prestosql.execution.QueryManagerConfig
 
getQueryMaxExecutionTime(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryMaxMemory(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryMaxMemoryPerNode(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryMaxRunTime() - Method in class io.prestosql.execution.QueryManagerConfig
 
getQueryMaxRunTime(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryMaxScanPhysicalBytes() - Method in class io.prestosql.execution.QueryManagerConfig
 
getQueryMaxScanPhysicalBytes(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryMaxSpillPerNode() - Method in class io.prestosql.spiller.NodeSpillConfig
 
getQueryMaxStageCount(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryMaxTotalMemory(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryMaxTotalMemoryPerNode(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryMemoryReservations() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getQueryMemoryRevocableReservations() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getQueryPerformanceFetcher() - Method in class io.prestosql.execution.ExplainAnalyzeContext
 
getQueryPlan() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getQueryPlan() - Method in interface io.prestosql.execution.QueryExecution
 
getQueryPlan() - Method in class io.prestosql.execution.SqlQueryExecution
 
getQueryPlan() - Method in class io.prestosql.testing.QueryRunner.MaterializedResultWithPlan
 
getQueryPlan(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
getQueryPlan(QueryId) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getQueryPriority(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryResults(QueryId, String, long, Duration, DataSize, UriInfo, AsyncResponse) - Method in class io.prestosql.server.protocol.ExecutingStatementResource
 
getQuerySession(QueryId) - Method in interface io.prestosql.execution.QueryManager
 
getQuerySession(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
getQuerySlug(QueryId) - Method in interface io.prestosql.execution.QueryManager
 
getQuerySlug(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
getQueryState() - Method in class io.prestosql.execution.QueryStateMachine
 
getQueryState() - Method in class io.prestosql.server.QueryStateInfo
 
getQueryState(QueryId) - Method in interface io.prestosql.execution.QueryManager
 
getQueryState(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
getQueryStateInfo(String, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.QueryStateInfoResource
 
getQueryStateInfos(String) - Method in class io.prestosql.server.ResourceGroupStateInfoResource
 
getQueryStateInfos(String, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.QueryStateInfoResource
 
getQueryStats() - Method in class io.prestosql.execution.QueryInfo
 
getQueryStats() - Method in class io.prestosql.server.BasicQueryInfo
 
getQueryType() - Method in class io.prestosql.execution.QueryInfo
 
getQueryType() - Method in class io.prestosql.server.BasicQueryInfo
 
getQueryType(Class<? extends Statement>) - Static method in class io.prestosql.util.StatementUtils
 
getQueuedDrivers() - Method in class io.prestosql.execution.BasicStageStats
 
getQueuedDrivers() - Method in class io.prestosql.execution.QueryStats
 
getQueuedDrivers() - Method in class io.prestosql.execution.StageStats
 
getQueuedDrivers() - Method in class io.prestosql.operator.PipelineStats
 
getQueuedDrivers() - Method in class io.prestosql.operator.PipelineStatus
 
getQueuedDrivers() - Method in class io.prestosql.operator.TaskStats
 
getQueuedDrivers() - Method in class io.prestosql.server.BasicQueryStats
 
getQueuedPartitionedDrivers() - Method in class io.prestosql.execution.TaskStatus
 
getQueuedPartitionedDrivers() - Method in class io.prestosql.operator.PipelineStats
 
getQueuedPartitionedDrivers() - Method in class io.prestosql.operator.PipelineStatus
 
getQueuedPartitionedDrivers() - Method in class io.prestosql.operator.TaskStats
 
getQueuedPartitionedSplitCount() - Method in interface io.prestosql.execution.RemoteTask
 
getQueuedPartitionedSplitCount() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
getQueuedQueries() - Method in class io.prestosql.dispatcher.DispatchManager
 
getQueuedQueries() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getQueuedQueries() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getQueuedSplitCountForStage(InternalNode) - Method in class io.prestosql.execution.scheduler.NodeAssignmentStats
 
getQueuedTime() - Method in class io.prestosql.dispatcher.DispatchInfo
 
getQueuedTime() - Method in class io.prestosql.execution.QueryManagerStats
 
getQueuedTime() - Method in class io.prestosql.execution.QueryStats
 
getQueuedTime() - Method in class io.prestosql.operator.DriverStats
 
getQueuedTime() - Method in class io.prestosql.operator.PipelineStats
 
getQueuedTime() - Method in class io.prestosql.operator.TaskStats
 
getQueuedTime() - Method in class io.prestosql.server.BasicQueryStats
 
getQueuedTimeMillis() - Method in class io.prestosql.server.QueryProgressStats
 
getRangeCount() - Method in class io.prestosql.server.DynamicFilterService.DynamicFilterDomainStats
 
getRangeDurationType() - Method in class io.prestosql.operator.scalar.QuarterOfYearDateTimeField
 
getRanges() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedDomain
 
getRawHash(int) - Method in class io.prestosql.operator.BigintGroupByHash
 
getRawHash(int) - Method in interface io.prestosql.operator.GroupByHash
 
getRawHash(int) - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
getRawHash(int) - Method in class io.prestosql.operator.NoChannelGroupByHash
 
getRawHash(Page, int) - Method in class io.prestosql.operator.exchange.LocalPartitionGenerator
 
getRawInputDataSize() - Method in class io.prestosql.execution.BasicStageStats
 
getRawInputDataSize() - Method in class io.prestosql.execution.QueryStats
 
getRawInputDataSize() - Method in class io.prestosql.execution.StageStats
 
getRawInputDataSize() - Method in class io.prestosql.operator.DriverStats
 
getRawInputDataSize() - Method in class io.prestosql.operator.OperatorStats
 
getRawInputDataSize() - Method in class io.prestosql.operator.PipelineStats
 
getRawInputDataSize() - Method in class io.prestosql.operator.TaskStats
 
getRawInputDataSize() - Method in class io.prestosql.server.BasicQueryStats
 
getRawInputPositions() - Method in class io.prestosql.execution.BasicStageStats
 
getRawInputPositions() - Method in class io.prestosql.execution.QueryStats
 
getRawInputPositions() - Method in class io.prestosql.execution.StageStats
 
getRawInputPositions() - Method in class io.prestosql.operator.DriverStats
 
getRawInputPositions() - Method in class io.prestosql.operator.PipelineStats
 
getRawInputPositions() - Method in class io.prestosql.operator.TaskStats
 
getRawInputPositions() - Method in class io.prestosql.server.BasicQueryStats
 
getRawInputReadTime() - Method in class io.prestosql.operator.DriverStats
 
getRawPath() - Method in class io.prestosql.sql.SqlPath
 
getRe2JDfaRetries() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getRe2JDfaStatesLimit() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getReadFromOutputBufferTime() - Method in class io.prestosql.server.TaskResource
 
getReadTime() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
getReadTime() - Method in class io.prestosql.operator.TableScanWorkProcessorOperator
 
getReadTime() - Method in interface io.prestosql.operator.WorkProcessorSourceOperator
 
getReadTimeNanos() - Method in class io.prestosql.connector.informationschema.InformationSchemaPageSource
 
getReadTimeNanos() - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
getReadTimeNanos() - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
getReadTimeNanos() - Method in class io.prestosql.split.MappedPageSource
 
getRecentFailureRatio() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getRecentFailures() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getRecentFailuresByType() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getRecentRequests() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getRecentSuccesses() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getRecursiveReference(Query) - Method in class io.prestosql.sql.analyzer.Analysis
 
getReferencedFields() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getReferencedTables() - Method in class io.prestosql.execution.QueryInfo
 
getReferencedTables() - Method in class io.prestosql.sql.analyzer.Analysis
 
getRefreshMaterializedView() - Method in class io.prestosql.sql.analyzer.Analysis
 
getRefreshPeriod() - Method in class io.prestosql.execution.scheduler.TopologyFileConfig
 
getRegexLibrary() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getRegion(int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getRegressionIntercept(RegressionState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
getRegressionSlope(RegressionState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
getRehashCount() - Method in class io.prestosql.operator.aggregation.histogram.ValueStore
 
getRelationAlias() - Method in class io.prestosql.sql.analyzer.Field
 
getRelationCoercion(Relation) - Method in class io.prestosql.sql.analyzer.Analysis
 
getRelationFieldIndex() - Method in class io.prestosql.sql.analyzer.ResolvedField
 
getRelationId() - Method in class io.prestosql.sql.analyzer.FieldId
 
getRelationId() - Method in class io.prestosql.sql.analyzer.Scope
 
getRelationType() - Method in class io.prestosql.sql.analyzer.Scope.AsteriskedIdentifierChainBasis
 
getRelationType() - Method in class io.prestosql.sql.analyzer.Scope
 
getRemainingExpression() - Method in class io.prestosql.sql.planner.DomainTranslator.ExtractionResult
 
getRemoteHost() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
getRemoteSourceNodes() - Method in class io.prestosql.sql.planner.PlanFragment
 
getRemoteSources() - Method in class io.prestosql.sql.planner.planprinter.JsonRenderer.JsonRenderedNode
 
getRemoteSources() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getRemoteTaskMaxCallbackThreads() - Method in class io.prestosql.execution.QueryManagerConfig
 
getRemoteTaskMaxErrorDuration() - Method in class io.prestosql.execution.QueryManagerConfig
 
getRemoteTaskMinErrorDuration() - Method in class io.prestosql.execution.QueryManagerConfig
Deprecated.
getRemoteUserAddress() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getRemoteUserAddress() - Method in interface io.prestosql.server.SessionContext
 
getRemoteUserAddress() - Method in class io.prestosql.Session
 
getRemoteUserAddress() - Method in class io.prestosql.SessionRepresentation
 
getRemoveInputDependencies() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getRemoveInputFunction() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getRemoveInputFunction() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getReorderJoinStatsAndCost() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getReorderJoinStatsAndCost() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getReplicatedDynamicFilters() - Method in class io.prestosql.server.DynamicFilterService.DynamicFiltersStats
 
getReplicateSymbols() - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
getRequestFailure() - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
getRequestsCompleted() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getRequestsFailed() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getRequestsScheduled() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getRequestSuccess() - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
getRequiredAudience() - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
getRequiredIssuer() - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
getRequiredTransactionId() - Method in class io.prestosql.Session
 
getRequiredWorkers() - Method in class io.prestosql.execution.ClusterSizeMonitor
 
getRequiredWorkers() - Method in class io.prestosql.execution.QueryManagerConfig
 
getRequiredWorkers(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getRequiredWorkersMaxWait() - Method in class io.prestosql.execution.QueryManagerConfig
 
getRequiredWorkersMaxWait(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getReservedBytes() - Method in class io.prestosql.memory.MemoryPool
 
getReservedDistributedBytes() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getReservedMemory() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getReservedPool() - Method in class io.prestosql.memory.LocalMemoryManager
 
getReservedRevocableBytes() - Method in class io.prestosql.memory.MemoryPool
 
getReservedRevocableBytes() - Method in class io.prestosql.operator.OperatorContext
 
getReservedRevocableDistributedBytes() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getResetSessionProperties() - Method in class io.prestosql.execution.QueryInfo
 
getResetSessionProperties() - Method in class io.prestosql.execution.QueryStateMachine
 
getResetSessionProperties() - Method in class io.prestosql.testing.MaterializedResult
 
getResolvedField(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
getResolvedFunction() - Method in class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
getResolvedFunction() - Method in class io.prestosql.sql.planner.plan.WindowNode.Function
 
getResolvedFunction() - Method in class io.prestosql.sql.relational.CallExpression
 
getResolvedFunction(FunctionCall) - Method in class io.prestosql.sql.analyzer.Analysis
 
getResolvedFunctions() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getResourceEstimates() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getResourceEstimates() - Method in interface io.prestosql.server.SessionContext
 
getResourceEstimates() - Method in class io.prestosql.Session
 
getResourceEstimates() - Method in class io.prestosql.SessionRepresentation
 
getResourceGroup() - Method in exception io.prestosql.execution.resourcegroups.QueryQueueFullException
 
getResourceGroupId() - Method in class io.prestosql.execution.QueryInfo
 
getResourceGroupId() - Method in class io.prestosql.server.BasicQueryInfo
 
getResourceGroupId() - Method in class io.prestosql.server.QueryStateInfo
 
getResourceGroupManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getResourceGroupManager(ResourceGroupManager) - Static method in class io.prestosql.server.CoordinatorModule
 
getResourceGroupManager(ResourceGroupManager) - Static method in class io.prestosql.server.WorkerModule
 
getResourceWaitingTime() - Method in class io.prestosql.execution.QueryStats
 
getResponseExecutor() - Method in class io.prestosql.server.AsyncHttpExecutionMBean
 
getResponseExecutor() - Method in class io.prestosql.server.StatementHttpExecutionMBean
 
getResponseSizeBytes() - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
getResult() - Method in class io.prestosql.operator.CompletedWork
 
getResult() - Method in class io.prestosql.operator.TransformWork
 
getResult() - Method in interface io.prestosql.operator.Work
Get the result once the work is done.
getResult() - Method in interface io.prestosql.operator.WorkProcessor
Get the result once the unit of work is done and the processor hasn't finished.
getResult() - Method in class io.prestosql.operator.WorkProcessor.ProcessState
 
getResults(TaskId, OutputBuffers.OutputBufferId, long, DataSize, AsyncResponse) - Method in class io.prestosql.server.TaskResource
 
getResultsRequestTime() - Method in class io.prestosql.server.TaskResource
 
getRetained() - Method in class io.prestosql.spiller.PartitioningSpiller.PartitioningSpillResult
 
getRetainedSizeInBytes() - Method in class io.prestosql.execution.buffer.SerializedPage
 
getRetainedSizeInBytes() - Method in class io.prestosql.operator.aggregation.TypedSet
 
getRetainedSizeInBytes() - Method in class io.prestosql.operator.GroupByIdBlock
 
getReturnConvention() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
getReturnNativeContainerType() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.Parser
 
getReturnType() - Method in class io.prestosql.metadata.BoundSignature
 
getReturnType() - Method in exception io.prestosql.metadata.OperatorNotFoundException
 
getReturnType() - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.SpecializeContext
 
getReturnType() - Method in class io.prestosql.metadata.Signature
 
getReturnType() - Method in class io.prestosql.type.FunctionType
 
getRevocableMemoryReservation() - Method in class io.prestosql.execution.QueryStats
 
getRevocableMemoryReservation() - Method in class io.prestosql.execution.StageStats
 
getRevocableMemoryReservation() - Method in class io.prestosql.execution.TaskStatus
 
getRevocableMemoryReservation() - Method in class io.prestosql.operator.DriverStats
 
getRevocableMemoryReservation() - Method in class io.prestosql.operator.OperatorStats
 
getRevocableMemoryReservation() - Method in class io.prestosql.operator.PipelineStats
 
getRevocableMemoryReservation() - Method in class io.prestosql.operator.TaskContext
 
getRevocableMemoryReservation() - Method in class io.prestosql.operator.TaskStats
 
getRevocableMemoryUsage() - Method in class io.prestosql.operator.DriverContext
 
getRewrittenExpression() - Method in class io.prestosql.operator.project.PageFieldsToInputParametersRewriter.Result
 
getRight() - Method in class io.prestosql.sql.planner.plan.JoinNode.EquiJoinClause
 
getRight() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getRight() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getRightHashSymbol() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getRightJoinFields() - Method in class io.prestosql.sql.analyzer.Analysis.JoinUsingAnalysis
 
getRightOutputSymbols() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getRightPartitionSymbol() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getRoles() - Method in class io.prestosql.connector.informationschema.InformationSchemaTableHandle
 
getRoles() - Method in class io.prestosql.SessionRepresentation
 
getRollups() - Method in class io.prestosql.sql.analyzer.Analysis.GroupingSetAnalysis
 
getRoot() - Method in class io.prestosql.server.ui.WebUiStaticResource
 
getRoot() - Method in class io.prestosql.sql.planner.Plan
 
getRoot() - Method in class io.prestosql.sql.planner.PlanFragment
 
getRootGroup() - Method in class io.prestosql.sql.planner.iterative.Memo
 
getRootId() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
getRootNodeLocalCostEstimate() - Method in class io.prestosql.cost.PlanCostEstimate
Returns local cost estimate for the root plan node.
getRootScope() - Method in class io.prestosql.sql.analyzer.Analysis
 
getRoutines() - Method in class io.prestosql.execution.QueryInfo
 
getRoutines() - Method in class io.prestosql.sql.analyzer.Analysis
 
getRowCount() - Method in class io.prestosql.sql.planner.plan.ValuesNode
 
getRowCount() - Method in class io.prestosql.testing.MaterializedResult
 
getRowCountSymbol() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
getRowCountSymbol() - Method in class io.prestosql.sql.planner.plan.TableFinishNode
 
getRowCountSymbol() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getRowFilter(ConnectorSecurityContext, SchemaTableName) - Method in class io.prestosql.security.InjectedConnectorAccessControl
 
getRowFilters(SecurityContext, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
 
getRowFilters(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
getRowFilters(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ForwardingAccessControl
 
getRowFilters(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.security.ViewAccessControl
 
getRowFilters(SecurityContext, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
getRowFilters(Table) - Method in class io.prestosql.sql.analyzer.Analysis
 
getRowId() - Method in class io.prestosql.sql.planner.plan.DeleteNode
 
getRowIdField(Table) - Method in class io.prestosql.sql.analyzer.Analysis
 
getRowNumberSymbol() - Method in class io.prestosql.sql.planner.iterative.rule.SetOperationNodeTranslator.TranslationResult
 
getRowNumberSymbol() - Method in class io.prestosql.sql.planner.plan.RowNumberNode
 
getRowNumberSymbol() - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
getRows() - Method in class io.prestosql.sql.planner.plan.ValuesNode
 
getRowsAdded() - Method in class io.prestosql.execution.buffer.PageBufferInfo
 
getRowsAdded() - Method in class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputInfo
 
getRowsReceived() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getRowsRejected() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getRules() - Method in class io.prestosql.server.security.UserMapping.UserMappingRules
 
getRunAwaySplitCount() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getRunnerThreads() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getRunningDrivers() - Method in class io.prestosql.execution.BasicStageStats
 
getRunningDrivers() - Method in class io.prestosql.execution.QueryStats
 
getRunningDrivers() - Method in class io.prestosql.execution.StageStats
 
getRunningDrivers() - Method in class io.prestosql.operator.PipelineStats
 
getRunningDrivers() - Method in class io.prestosql.operator.PipelineStatus
 
getRunningDrivers() - Method in class io.prestosql.operator.TaskStats
 
getRunningDrivers() - Method in class io.prestosql.server.BasicQueryStats
 
getRunningDrivers() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getRunningPartitionedDrivers() - Method in class io.prestosql.execution.TaskStatus
 
getRunningPartitionedDrivers() - Method in class io.prestosql.operator.PipelineStats
 
getRunningPartitionedDrivers() - Method in class io.prestosql.operator.PipelineStatus
 
getRunningPartitionedDrivers() - Method in class io.prestosql.operator.TaskStats
 
getRunningQueries() - Method in class io.prestosql.dispatcher.DispatchManager
 
getRunningQueries() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getRunningQueries() - Method in class io.prestosql.server.ResourceGroupInfo
 
getRunningQueries() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getRunningSplits() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getRunningTasks() - Method in class io.prestosql.execution.QueryStats
 
getRunningTasks() - Method in class io.prestosql.execution.StageStats
 
getRunningTasksLevel0() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getRunningTasksLevel1() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getRunningTasksLevel2() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getRunningTasksLevel3() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getRunningTasksLevel4() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getSampleRatio() - Method in class io.prestosql.sql.planner.plan.SampleNode
 
getSampleRatio(SampledRelation) - Method in class io.prestosql.sql.analyzer.Analysis
 
getSampleType() - Method in class io.prestosql.sql.planner.plan.SampleNode
 
getScalarExtractor() - Method in class io.prestosql.operator.scalar.JsonPath
 
getScalarFunctionInvoker(FunctionBinding, FunctionDependencies, InvocationConvention) - Method in class io.prestosql.metadata.FunctionRegistry
 
getScalarFunctionInvoker(ResolvedFunction, InvocationConvention) - Method in interface io.prestosql.metadata.Metadata
 
getScalarFunctionInvoker(ResolvedFunction, InvocationConvention) - Method in class io.prestosql.metadata.MetadataManager
 
getScalarFunctionInvoker(ResolvedFunction, InvocationConvention) - Method in class io.prestosql.sql.gen.BytecodeGeneratorContext
 
getScalarFunctionInvoker(InvocationConvention) - Method in class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation
 
getScalarFunctionInvoker(InvocationConvention) - Method in interface io.prestosql.operator.scalar.ScalarFunctionImplementation
 
getScalarSubqueries() - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getScalarSubqueries() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getScalarSubqueries(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getScheduledExecutor() - Method in class io.prestosql.dispatcher.DispatchExecutor.DispatchExecutorMBeans
 
getScheduledExecutor() - Method in class io.prestosql.dispatcher.DispatchExecutor
 
getScheduledNanos() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
getScheduledNanos() - Method in class io.prestosql.execution.executor.TaskHandle
 
getScheduledNodes() - Method in class io.prestosql.execution.SqlStageExecution
 
getScheduledTimeMillis() - Method in class io.prestosql.server.QueryProgressStats
 
getScheduler() - Method in class io.prestosql.testing.LocalQueryRunner
 
getScheduleSplitBatchSize() - Method in class io.prestosql.execution.QueryManagerConfig
 
getSchedulingComplete() - Method in class io.prestosql.execution.StageStats
 
getSchedulingPolicy() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getSchedulingPolicy() - Method in class io.prestosql.server.ResourceGroupInfo
 
getSchedulingWeight() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getSchedulingWeight() - Method in class io.prestosql.server.ResourceGroupInfo
 
getSchema() - Method in class io.prestosql.execution.Input
 
getSchema() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getSchema() - Method in class io.prestosql.server.QueryStateInfo
 
getSchema() - Method in interface io.prestosql.server.SessionContext
 
getSchema() - Method in class io.prestosql.Session
 
getSchema() - Method in class io.prestosql.SessionRepresentation
 
getSchema() - Method in class io.prestosql.sql.analyzer.Output
 
getSchema() - Method in class io.prestosql.sql.SqlPathElement
 
getSchemaName() - Method in class io.prestosql.connector.system.SystemTableHandle
 
getSchemaName() - Method in class io.prestosql.metadata.QualifiedObjectName
 
getSchemaName() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
getSchemaOwner(Session, CatalogSchemaName) - Method in interface io.prestosql.metadata.Metadata
Gets the schema owner for the specified schema.
getSchemaOwner(Session, CatalogSchemaName) - Method in class io.prestosql.metadata.MetadataManager
 
getSchemaProperties(Session, CatalogSchemaName) - Method in interface io.prestosql.metadata.Metadata
Gets the schema properties for the specified schema.
getSchemaProperties(Session, CatalogSchemaName) - Method in class io.prestosql.metadata.MetadataManager
 
getSchemaPropertyManager() - Method in interface io.prestosql.metadata.Metadata
 
getSchemaPropertyManager() - Method in class io.prestosql.metadata.MetadataManager
 
getSchemaTableName() - Method in enum io.prestosql.connector.informationschema.InformationSchemaTable
 
getSchemaTableName() - Method in class io.prestosql.connector.system.SystemTableHandle
 
getSchemaTableName() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateTarget
 
getSchemaTableName() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.DeleteTarget
 
getSchemaTableName() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertTarget
 
getSchemaTableName() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewTarget
 
getScope() - Method in class io.prestosql.sql.analyzer.ResolvedField
 
getScope() - Method in class io.prestosql.sql.analyzer.Scope.AsteriskedIdentifierChainBasis
 
getScope() - Method in class io.prestosql.sql.gen.BytecodeGeneratorContext
 
getScope() - Method in class io.prestosql.sql.planner.plan.ExchangeNode
 
getScope(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getScopeComplementEqualities() - Method in class io.prestosql.sql.planner.EqualityInference.EqualityPartition
 
getScopeEqualities() - Method in class io.prestosql.sql.planner.EqualityInference.EqualityPartition
 
getScopeStraddlingEqualities() - Method in class io.prestosql.sql.planner.EqualityInference.EqualityPartition
 
getScore() - Method in class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation.ScalarImplementationChoice
 
getSearchExpressions() - Method in class io.prestosql.sql.planner.SortExpressionContext
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanBooleanState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanDoubleState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanLongState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleBooleanState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleDoubleState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleLongState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.LongBooleanState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.LongDoubleState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.LongLongState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectBooleanState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectDoubleState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectLongState
 
getSecondBlock() - Method in interface io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueState
 
getSecondPosition() - Method in interface io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueState
 
getSecurityContext(TransactionId, QueryId) - Method in class io.prestosql.sql.analyzer.Analysis.AccessControlInfo
 
getSegments() - Method in class io.prestosql.execution.scheduler.NetworkLocation
 
getSelectAllResultFields(AllColumns) - Method in class io.prestosql.sql.analyzer.Analysis
 
getSelectedCountLevel0() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getSelectedCountLevel1() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getSelectedCountLevel2() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getSelectedCountLevel3() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getSelectedCountLevel4() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
getSelectExpressions(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getSelf() - Method in class io.prestosql.execution.QueryInfo
 
getSelf() - Method in class io.prestosql.execution.TaskStatus
 
getSelf() - Method in class io.prestosql.server.BasicQueryInfo
 
getSemiJoinOutput() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getSequenceId() - Method in class io.prestosql.execution.ScheduledSplit
 
getSerializedPages() - Method in class io.prestosql.execution.buffer.BufferResult
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.histogram.HistogramStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.BlockPositionStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.BlockStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.DoubleHistogramStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.NullableBooleanStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.NullableDoubleStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.NullableLongStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.TDigestStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.TriStateBooleanStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateSerializer
 
getSerializedType() - Method in class io.prestosql.type.setdigest.SetDigestStateSerializer
 
getSerializedType(Type, Type) - Static method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
getSerializedType(Class<?>) - Static method in class io.prestosql.operator.aggregation.state.StateCompiler
 
getSerializedType(Class<?>, Map<String, Type>) - Static method in class io.prestosql.operator.aggregation.state.StateCompiler
 
getSerializer() - Method in class io.prestosql.operator.aggregation.AggregationMetadata.AccumulatorStateDescriptor
 
getServerCoordinator() - Method in class io.prestosql.server.ServerInfoResource
 
getServerState() - Method in class io.prestosql.server.ServerInfoResource
 
getServiceName() - Method in class io.prestosql.server.security.KerberosConfig
 
getServiceThreadCount() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getSession() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getSession() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getSession() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getSession() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
getSession() - Method in class io.prestosql.execution.QueryInfo
 
getSession() - Method in class io.prestosql.execution.QueryStateMachine
 
getSession() - Method in interface io.prestosql.execution.QueryTracker.TrackedQuery
 
getSession() - Method in class io.prestosql.execution.SqlQueryExecution
 
getSession() - Method in class io.prestosql.execution.StageStateMachine
 
getSession() - Method in class io.prestosql.FullConnectorSession
 
getSession() - Method in class io.prestosql.operator.DriverContext
 
getSession() - Method in class io.prestosql.operator.OperatorContext
 
getSession() - Method in class io.prestosql.operator.PipelineContext
 
getSession() - Method in class io.prestosql.operator.ProcessorContext
 
getSession() - Method in class io.prestosql.operator.TaskContext
 
getSession() - Method in class io.prestosql.server.BasicQueryInfo
 
getSession() - Method in class io.prestosql.server.TaskUpdateRequest
 
getSession() - Method in interface io.prestosql.sql.planner.iterative.Rule.Context
 
getSessionCatalog(Metadata, Session, Node) - Static method in class io.prestosql.metadata.MetadataUtil
 
getSessionProperties() - Method in class io.prestosql.SystemSessionProperties
 
getSessionPropertyDefaults() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getSessionPropertyManager() - Method in interface io.prestosql.metadata.Metadata
 
getSessionPropertyManager() - Method in class io.prestosql.metadata.MetadataManager
 
getSessionTimeout() - Method in class io.prestosql.server.ui.FormWebUiConfig
 
getSetCatalog() - Method in class io.prestosql.execution.QueryInfo
 
getSetPath() - Method in class io.prestosql.execution.QueryInfo
 
getSetPath() - Method in class io.prestosql.execution.QueryStateMachine
 
getSetProvider() - Method in class io.prestosql.operator.SetBuilderOperator.SetBuilderOperatorFactory
 
getSetRoles() - Method in class io.prestosql.execution.QueryInfo
 
getSetSchema() - Method in class io.prestosql.execution.QueryInfo
 
getSetSessionProperties() - Method in class io.prestosql.execution.QueryInfo
 
getSetSessionProperties() - Method in class io.prestosql.execution.QueryStateMachine
 
getSetSessionProperties() - Method in class io.prestosql.testing.MaterializedResult
 
getSharedSecret() - Method in class io.prestosql.server.InternalCommunicationConfig
 
getSharedSecret() - Method in class io.prestosql.server.ui.FormWebUiConfig
 
getShort(int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getShutdownAction() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getShuttingDownNodeCount() - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
getShuttingDownNodes() - Method in class io.prestosql.metadata.AllNodes
 
getSignature() - Method in class io.prestosql.metadata.FunctionMetadata
 
getSignature() - Method in class io.prestosql.metadata.ResolvedFunction
 
getSignature() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getSignature() - Method in interface io.prestosql.operator.ParametricImplementation
 
getSignature() - Method in class io.prestosql.operator.ParametricImplementationsGroup
 
getSignature() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation
 
getSignature() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.Parser
 
getSignature() - Method in class io.prestosql.operator.window.AbstractWindowFunctionSupplier
 
getSignature() - Method in interface io.prestosql.operator.window.WindowFunctionSupplier
 
getSimplifiedDomain() - Method in class io.prestosql.server.DynamicFilterService.DynamicFilterDomainStats
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.histogram.HistogramStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory
 
getSingleStateClass() - Method in class io.prestosql.type.setdigest.SetDigestStateFactory
 
getSingleValueBlock(int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getSingleValueBlock(int, int) - Method in class io.prestosql.operator.PagesIndex
 
getSingleValueBlock(int, int) - Method in class io.prestosql.operator.window.PagesWindowIndex
 
getSinkFactory(LocalExchange.LocalExchangeSinkFactoryId) - Method in class io.prestosql.operator.exchange.LocalExchange
 
getSinkMaxBroadcastBufferSize() - Method in class io.prestosql.execution.TaskManagerConfig
 
getSinkMaxBufferSize() - Method in class io.prestosql.execution.TaskManagerConfig
 
getSize(List<SerializedPage>, Class<?>, Type, Annotation[], MediaType) - Method in class io.prestosql.server.PagesResponseWriter
 
getSizeExtractor() - Method in class io.prestosql.operator.scalar.JsonPath
 
getSizeInBytes() - Method in class io.prestosql.execution.buffer.SerializedPage
 
getSizeInBytes() - Method in class io.prestosql.operator.ArrayPositionLinks
 
getSizeInBytes() - Method in class io.prestosql.operator.GroupByIdBlock
 
getSizeInBytes() - Method in interface io.prestosql.operator.PagesHashStrategy
Get the total of allocated size
getSizeInBytes() - Method in interface io.prestosql.operator.PositionLinks
 
getSizeInBytes() - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
getSizeInBytes() - Method in class io.prestosql.operator.SortedPositionLinks
 
getSizeInBytes() - Method in class io.prestosql.operator.WindowInfo.IndexInfo
 
getSizeInMemory() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
getSleepTime() - Method in class io.prestosql.execution.scheduler.SplitSchedulerStats
 
getSlice() - Method in class io.prestosql.execution.buffer.SerializedPage
 
getSlice() - Method in interface io.prestosql.operator.aggregation.state.SliceState
 
getSlice(int) - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
getSlice(int) - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
getSlice(int, int) - Method in class io.prestosql.operator.PagesIndex
 
getSlice(int, int) - Method in class io.prestosql.operator.window.PagesWindowIndex
 
getSlice(int, int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getSlice(Block, int) - Method in class io.prestosql.type.FunctionType
 
getSlice(Block, int) - Method in class io.prestosql.type.IpAddressType
 
getSlice(Block, int) - Method in class io.prestosql.type.JsonType
 
getSlice(Block, int) - Method in class io.prestosql.type.setdigest.SetDigestType
 
getSlice(Block, int) - Method in class io.prestosql.type.UuidType
 
getSliceLength(int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getSlug() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getSlug() - Method in interface io.prestosql.execution.QueryExecution
 
getSlug() - Method in class io.prestosql.execution.SqlQueryExecution
 
getSmallBroadcastMaxDistinctValuesPerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getSmallBroadcastMaxSizePerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getSmallBroadcastRangeRowLimitPerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getSmallPartitionedMaxDistinctValuesPerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getSmallPartitionedMaxSizePerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getSmallPartitionedRangeRowLimitPerDriver() - Method in class io.prestosql.execution.DynamicFilterConfig
 
getSoftConcurrencyLimit() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getSoftConcurrencyLimit() - Method in class io.prestosql.server.ResourceGroupInfo
 
getSoftCpuLimit() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getSoftMemoryLimit() - Method in class io.prestosql.server.ResourceGroupInfo
 
getSoftMemoryLimitBytes() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getSortedPages() - Method in class io.prestosql.operator.PagesIndex
 
getSortExpression() - Method in class io.prestosql.sql.planner.SortExpressionContext
 
getSortItemsFromOrderBy(Optional<OrderBy>) - Static method in class io.prestosql.sql.NodeUtils
 
getSortKeyChannel() - Method in class io.prestosql.operator.window.FrameInfo
 
getSortKeyChannelForEndComparison() - Method in class io.prestosql.operator.window.FrameInfo
 
getSortKeyChannelForStartComparison() - Method in class io.prestosql.operator.window.FrameInfo
 
getSortKeyCoercedForFrameEndComparison() - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
getSortKeyCoercedForFrameStartComparison() - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
getSortKeyCoercionForFrameBoundCalculation(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
getSortKeyCoercionForFrameBoundComparison(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
getSortKeyCoercionsForFrameBoundCalculation() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getSortKeyCoercionsForFrameBoundComparison() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getSource() - Method in class io.prestosql.FullConnectorSession
 
getSource() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getSource() - Method in class io.prestosql.server.QueryStateInfo
 
getSource() - Method in interface io.prestosql.server.SessionContext
 
getSource() - Method in class io.prestosql.Session
 
getSource() - Method in class io.prestosql.SessionRepresentation
 
getSource() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.AssignUniqueId
 
getSource() - Method in class io.prestosql.sql.planner.plan.DeleteNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.DistinctLimitNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.EnforceSingleRowNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.ExplainAnalyzeNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.FilterNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.LimitNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.MarkDistinctNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.OffsetNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.OutputNode
 
getSource() - Static method in class io.prestosql.sql.planner.plan.Patterns.SemiJoin
 
getSource() - Method in class io.prestosql.sql.planner.plan.ProjectNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.RowNumberNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.SampleNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.SortNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.TableFinishNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.TopNNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
getSource() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getSource() - Method in class io.prestosql.testing.TestingConnectorSession
 
getSourceFragmentIds() - Method in class io.prestosql.sql.planner.plan.RemoteSourceNode
 
getSourceHashSymbol() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getSourceId() - Method in class io.prestosql.operator.Driver
 
getSourceId() - Method in class io.prestosql.operator.DriverFactory
return the sourceId of this DriverFactory.
getSourceId() - Method in class io.prestosql.operator.ExchangeOperator.ExchangeOperatorFactory
 
getSourceId() - Method in class io.prestosql.operator.ExchangeOperator
 
getSourceId() - Method in class io.prestosql.operator.index.IndexSourceOperator
 
getSourceId() - Method in class io.prestosql.operator.index.IndexSourceOperator.IndexSourceOperatorFactory
 
getSourceId() - Method in class io.prestosql.operator.MergeOperator
 
getSourceId() - Method in class io.prestosql.operator.MergeOperator.MergeOperatorFactory
 
getSourceId() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory
 
getSourceId() - Method in interface io.prestosql.operator.SourceOperator
 
getSourceId() - Method in interface io.prestosql.operator.SourceOperatorFactory
 
getSourceId() - Method in class io.prestosql.operator.TableScanOperator
 
getSourceId() - Method in class io.prestosql.operator.TableScanOperator.TableScanOperatorFactory
 
getSourceId() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
getSourceId() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator.WorkProcessorPipelineSourceOperatorFactory
 
getSourceId() - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
getSourceId() - Method in interface io.prestosql.operator.WorkProcessorSourceOperatorFactory
 
getSourceJoinSymbol() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getSourceNode() - Method in class io.prestosql.sql.analyzer.RelationId
 
getSources() - Method in class io.prestosql.server.TaskUpdateRequest
 
getSources() - Method in class io.prestosql.sql.planner.iterative.GroupReference
 
getSources() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.AssignUniqueId
 
getSources() - Method in class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.DeleteNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.DistinctLimitNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.EnforceSingleRowNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.ExchangeNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.ExplainAnalyzeNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.FilterNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.IndexSourceNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.LimitNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.MarkDistinctNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.OffsetNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.OutputNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.PlanNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.ProjectNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.RemoteSourceNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.RowNumberNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.SampleNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.SetOperationNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.SortNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.TableDeleteNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.TableFinishNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.TableScanNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.TopNNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.ValuesNode
 
getSources() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getSourceSymbol() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph.Edge
 
getSourceTableHandles() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewReference
 
getSourceTableHandles() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewTarget
 
getSourceTablesSizeInBytes(PlanNode, Rule.Context) - Static method in class io.prestosql.sql.planner.iterative.rule.DetermineJoinDistributionType
 
getSpatialPartitioningTableName(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getSpecializedImplementations() - Method in class io.prestosql.operator.ParametricImplementationsGroup
 
getSpecializedSignature() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.Parser
 
getSpecializedTypeParameters() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.Parser
 
getSpecification() - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
getSpecification() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getSpillContext() - Method in class io.prestosql.operator.OperatorContext
 
getSpillContext() - Method in class io.prestosql.operator.ProcessorContext
 
getSpilledDataSize() - Method in class io.prestosql.execution.QueryStats
 
getSpilledDataSize() - Method in class io.prestosql.operator.OperatorStats
 
getSpilledPages() - Method in class io.prestosql.spiller.FileSingleStreamSpiller
 
getSpilledPages() - Method in interface io.prestosql.spiller.SingleStreamSpiller
Returns list of previously spilled Pages as a single stream.
getSpilledPages(int) - Method in class io.prestosql.spiller.GenericPartitioningSpiller
 
getSpilledPages(int) - Method in interface io.prestosql.spiller.PartitioningSpiller
Returns iterator of previously spilled pages from given partition.
getSpilledPagesInMemorySize() - Method in class io.prestosql.spiller.FileSingleStreamSpiller
 
getSpilledPagesInMemorySize() - Method in interface io.prestosql.spiller.SingleStreamSpiller
Returns estimate size of pages that would be returned by SingleStreamSpiller.getAllSpilledPages().
getSpillEpoch() - Method in class io.prestosql.operator.LookupJoinOperator.SpillInfoSnapshot
 
getSpillerSpillPaths() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getSpillerThreads() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getSpillingFuture() - Method in class io.prestosql.spiller.PartitioningSpiller.PartitioningSpillResult
 
getSpillMask() - Method in class io.prestosql.operator.LookupJoinOperator.SpillInfoSnapshot
 
getSpillMask() - Method in interface io.prestosql.operator.LookupSourceProvider.LookupSourceLease
 
getSpillMaxUsedSpaceThreshold() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getSpills() - Method in class io.prestosql.spiller.GenericSpiller
 
getSpills() - Method in interface io.prestosql.spiller.Spiller
Returns list of previously spilled Pages streams.
getSpillSpaceTracker() - Method in class io.prestosql.spiller.LocalSpillManager
 
getSplit() - Method in class io.prestosql.execution.ScheduledSplit
 
getSplitClass() - Method in class io.prestosql.connector.informationschema.InformationSchemaHandleResolver
 
getSplitClass() - Method in class io.prestosql.connector.system.SystemHandleResolver
 
getSplitClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getSplitClass() - Method in class io.prestosql.split.EmptySplitHandleResolver
 
getSplitClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
getSplitClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getSplitConcurrencyAdjustmentInterval() - Method in class io.prestosql.execution.TaskManagerConfig
 
getSplitConcurrencyAdjustmentInterval(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getSplitId() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
getSplitInfo() - Method in class io.prestosql.operator.SplitOperatorInfo
 
getSplitManager() - Method in class io.prestosql.connector.informationschema.InformationSchemaConnector
 
getSplitManager() - Method in class io.prestosql.connector.system.SystemConnector
 
getSplitManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getSplitManager() - Method in class io.prestosql.testing.LocalQueryRunner
 
getSplitManager() - Method in interface io.prestosql.testing.QueryRunner
 
getSplitQueuedTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getSplitQueuesFull() - Method in class io.prestosql.execution.scheduler.SplitSchedulerStats
 
getSplits() - Method in class io.prestosql.execution.TaskSource
 
getSplits() - Method in class io.prestosql.split.SplitSource.SplitBatch
 
getSplits(Session, TableHandle, ConnectorSplitManager.SplitSchedulingStrategy, DynamicFilter) - Method in class io.prestosql.split.SplitManager
 
getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableHandle, ConnectorSplitManager.SplitSchedulingStrategy, DynamicFilter) - Method in class io.prestosql.connector.informationschema.InformationSchemaSplitManager
 
getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableHandle, ConnectorSplitManager.SplitSchedulingStrategy, DynamicFilter) - Method in class io.prestosql.connector.system.SystemSplitManager
 
getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableHandle, ConnectorSplitManager.SplitSchedulingStrategy, DynamicFilter) - Method in class io.prestosql.testing.TestingSplitManager
 
getSplitSources() - Method in class io.prestosql.sql.planner.StageExecutionPlan
 
getSplitsScheduled() - Method in class io.prestosql.execution.scheduler.ScheduleResult
 
getSplitsScheduledPerIteration() - Method in class io.prestosql.execution.scheduler.SplitSchedulerStats
 
getSplitWallTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getSqlParser() - Method in class io.prestosql.testing.LocalQueryRunner
 
getSqlType() - Method in class io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata
 
getStack() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
getStackTrace() - Method in class io.prestosql.server.ThreadResource.Info
 
getStageCountWarningThreshold() - Method in class io.prestosql.execution.QueryManagerConfig
 
getStageExecutionDescriptor() - Method in class io.prestosql.sql.planner.LocalExecutionPlanner.LocalExecutionPlan
 
getStageExecutionDescriptor() - Method in class io.prestosql.sql.planner.PlanFragment
 
getStageExecutionStrategy() - Method in class io.prestosql.operator.StageExecutionDescriptor
 
getStageGcStatistics() - Method in class io.prestosql.execution.QueryStats
 
getStageId() - Method in class io.prestosql.execution.SqlStageExecution
 
getStageId() - Method in class io.prestosql.execution.StageInfo
 
getStageId() - Method in class io.prestosql.execution.StageStateMachine
 
getStageId() - Method in class io.prestosql.execution.TaskId
 
getStageId() - Method in class io.prestosql.operator.OperatorStats
 
getStageInfo() - Method in class io.prestosql.execution.scheduler.SqlQueryScheduler
 
getStageInfo() - Method in class io.prestosql.execution.SqlStageExecution
 
getStageInfo(Supplier<Iterable<TaskInfo>>) - Method in class io.prestosql.execution.StageStateMachine
 
getStageStats() - Method in class io.prestosql.execution.StageInfo
 
getStagesToSchedule() - Method in class io.prestosql.execution.scheduler.AllAtOnceExecutionSchedule
 
getStagesToSchedule() - Method in interface io.prestosql.execution.scheduler.ExecutionSchedule
 
getStagesToSchedule() - Method in class io.prestosql.execution.scheduler.PhasedExecutionSchedule
 
getStart() - Method in class io.prestosql.FullConnectorSession
 
getStart() - Method in class io.prestosql.Session
 
getStart() - Method in class io.prestosql.SessionRepresentation
 
getStart() - Method in class io.prestosql.testing.TestingConnectorSession
 
getStartChannel() - Method in class io.prestosql.operator.window.FrameInfo
 
getStartedQueries() - Method in class io.prestosql.execution.QueryManagerStats
 
getStartedTransactionId() - Method in class io.prestosql.execution.QueryInfo
 
getStartTime() - Method in class io.prestosql.operator.DriverStats
 
getStartType() - Method in class io.prestosql.operator.window.FrameInfo
 
getStartType() - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
getStartValue() - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
getState() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getState() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getState() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
getState() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getState() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
getState() - Method in interface io.prestosql.execution.QueryExecution
 
getState() - Method in class io.prestosql.execution.QueryInfo
 
getState() - Method in class io.prestosql.execution.SqlQueryExecution
 
getState() - Method in class io.prestosql.execution.SqlStageExecution
 
getState() - Method in class io.prestosql.execution.StageInfo
 
getState() - Method in class io.prestosql.execution.StageStateMachine
 
getState() - Method in class io.prestosql.execution.TaskStateMachine
 
getState() - Method in class io.prestosql.execution.TaskStatus
 
getState() - Method in class io.prestosql.operator.HashBuilderOperator
 
getState() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getState() - Method in class io.prestosql.operator.TaskContext
 
getState() - Method in class io.prestosql.server.BasicQueryInfo
 
getState() - Method in class io.prestosql.server.ResourceGroupInfo
 
getState() - Method in class io.prestosql.server.ThreadResource.Info
 
getState(HostAddress) - Method in interface io.prestosql.failuredetector.FailureDetector
 
getState(HostAddress) - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector
 
getState(HostAddress) - Method in class io.prestosql.failuredetector.NoOpFailureDetector
 
getStateChange(QueryState) - Method in class io.prestosql.execution.DataDefinitionExecution
 
getStateChange(QueryState) - Method in interface io.prestosql.execution.QueryExecution
 
getStateChange(QueryState) - Method in class io.prestosql.execution.QueryStateMachine
 
getStateChange(QueryState) - Method in class io.prestosql.execution.SqlQueryExecution
 
getStateChange(TaskState) - Method in class io.prestosql.execution.TaskStateMachine
 
getStateChange(QueryId, QueryState) - Method in interface io.prestosql.execution.QueryManager
Gets a future that completes when the query changes from the specified current state or immediately if the query is already in a final state.
getStateChange(QueryId, QueryState) - Method in class io.prestosql.execution.SqlQueryManager
 
getStateChange(T) - Method in class io.prestosql.execution.StateMachine
Gets a future that completes when the state is no longer .equals() to currentState).
getStateClass() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getStateClass(Class<?>, Class<?>) - Static method in class io.prestosql.operator.aggregation.minmaxby.TwoNullableValueStateMapping
 
getStateDescriptors() - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactoryBinder
 
getStateInterface() - Method in class io.prestosql.operator.aggregation.AggregationMetadata.AccumulatorStateDescriptor
 
getStateKey() - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
getStatement() - Method in class io.prestosql.execution.QueryPreparer.PreparedQuery
 
getStatement() - Method in class io.prestosql.sql.analyzer.Analysis
 
getStateSerializer(Type, Type) - Static method in class io.prestosql.operator.aggregation.minmaxby.TwoNullableValueStateMapping
 
getStaticConjuncts() - Method in class io.prestosql.sql.DynamicFilters.ExtractResult
 
getStatisticsAggregation() - Method in class io.prestosql.sql.planner.plan.TableFinishNode
 
getStatisticsAggregation() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getStatisticsAggregationDescriptor() - Method in class io.prestosql.sql.planner.plan.TableFinishNode
 
getStatisticsAggregationDescriptor() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getStatisticsCollectionMetadata(Session, String, ConnectorTableMetadata) - Method in interface io.prestosql.metadata.Metadata
Describe statistics that must be collected during a statistics collection
getStatisticsCollectionMetadata(Session, String, ConnectorTableMetadata) - Method in class io.prestosql.metadata.MetadataManager
 
getStatisticsCollectionMetadataForWrite(Session, String, ConnectorTableMetadata) - Method in interface io.prestosql.metadata.Metadata
Describes statistics that must be collected during a write.
getStatisticsCollectionMetadataForWrite(Session, String, ConnectorTableMetadata) - Method in class io.prestosql.metadata.MetadataManager
 
getStatisticsCpuTime() - Method in class io.prestosql.operator.TableFinishInfo
 
getStatisticsCpuTime() - Method in class io.prestosql.operator.TableWriterOperator.TableWriterInfo
 
getStatisticsMetadata() - Method in class io.prestosql.metadata.AnalyzeMetadata
 
getStatisticsWallTime() - Method in class io.prestosql.operator.TableFinishInfo
 
getStatisticsWallTime() - Method in class io.prestosql.operator.TableWriterOperator.TableWriterInfo
 
getStats() - Method in class io.prestosql.cost.StatsAndCosts
 
getStats() - Method in class io.prestosql.dispatcher.DispatchManager
 
getStats() - Method in class io.prestosql.execution.TaskInfo
 
getStats() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector
 
getStats() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getStats() - Method in class io.prestosql.sql.planner.RuleStatsRecorder
 
getStats(int) - Method in class io.prestosql.sql.planner.iterative.Memo
 
getStats(PlanNode) - Method in class io.prestosql.cost.CachingStatsProvider
 
getStats(PlanNode) - Method in interface io.prestosql.cost.StatsProvider
 
getStatsAndCosts() - Method in class io.prestosql.sql.planner.Plan
 
getStatsAndCosts() - Method in class io.prestosql.sql.planner.PlanFragment
 
getStatsCalculator() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getStatsCalculator() - Method in class io.prestosql.testing.LocalQueryRunner
 
getStatsCalculator() - Method in interface io.prestosql.testing.QueryRunner
 
getStatsProvider() - Method in interface io.prestosql.sql.planner.iterative.Rule.Context
 
getStatus() - Method in class io.prestosql.operator.ExchangeClient
 
getStatus() - Method in class io.prestosql.operator.HttpPageBufferClient
 
getStatus() - Method in class io.prestosql.server.StatusResource
 
getStatus(QueryId, String, long, Duration, UriInfo, AsyncResponse) - Method in class io.prestosql.dispatcher.QueuedStatementResource
 
getStatus(String) - Method in class io.prestosql.server.ui.WorkerResource
 
getStatusRefreshMaxWait() - Method in class io.prestosql.execution.TaskManagerConfig
 
getStatusRoundTripMillis() - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
getStep() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getStep() - Method in class io.prestosql.sql.planner.plan.TopNNode
 
getStorageTableHandle() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewReference
 
getStreamedIndexJoinLookups() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
getStreamPartitioningColumns() - Method in class io.prestosql.metadata.TableProperties
 
getSubGroups() - Method in class io.prestosql.server.ResourceGroupInfo
 
getSubmittedQueries() - Method in class io.prestosql.execution.QueryManagerStats
 
getSubquery() - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
getSubquery() - Method in class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
getSubqueryAssignments() - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
getSubqueryInPredicates() - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getSubqueryInPredicates() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getSubStages() - Method in class io.prestosql.execution.StageInfo
 
getSubStages() - Method in class io.prestosql.sql.planner.StageExecutionPlan
 
getSuccessfulIndexJoinLookupsByCacheReset() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
getSuccessfulIndexJoinLookupsByLimitedRequest() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
getSuccessfulIndexJoinLookupsBySingleRequest() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
getSuccessfulRequestsCount() - Method in class io.prestosql.operator.ExchangeClientStatus
 
getSumSquaredDifferencesPositionsOfIndex() - Method in class io.prestosql.operator.WindowInfo.DriverWindowInfo
 
getSumSquaredDifferencesSizeInPartition() - Method in class io.prestosql.operator.WindowInfo.DriverWindowInfo
 
getSumSquaredDifferencesSizeInPartition() - Method in class io.prestosql.operator.WindowInfo.IndexInfo
 
getSumSquaredDifferencesSizeOfIndex() - Method in class io.prestosql.operator.WindowInfo.DriverWindowInfo
 
getSumSquaredInputPositions() - Method in class io.prestosql.operator.OperatorStats
 
getSuppressed() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
getSymbol() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation.TypedSymbol
 
getSymbolAllocator() - Method in interface io.prestosql.sql.planner.iterative.Rule.Context
 
getSymbolMapping() - Method in class io.prestosql.sql.planner.plan.SetOperationNode
 
getSymbols() - Method in class io.prestosql.sql.planner.plan.Assignments
 
getSymbols() - Method in class io.prestosql.sql.planner.PlanFragment
 
getSymbolStatistics() - Method in class io.prestosql.cost.PlanNodeStatsEstimate
 
getSymbolStatistics(Symbol) - Method in class io.prestosql.cost.PlanNodeStatsEstimate
 
getSymbolsWithKnownStatistics() - Method in class io.prestosql.cost.PlanNodeStatsEstimate
 
getSystemCpuLoad() - Method in class io.prestosql.server.NodeStatus
 
getSystemMemoryReservation() - Method in class io.prestosql.execution.TaskStatus
 
getSystemMemoryReservation() - Method in class io.prestosql.operator.DriverStats
 
getSystemMemoryReservation() - Method in class io.prestosql.operator.OperatorStats
 
getSystemMemoryReservation() - Method in class io.prestosql.operator.PipelineStats
 
getSystemMemoryReservation() - Method in class io.prestosql.operator.TaskContext
 
getSystemMemoryReservation() - Method in class io.prestosql.operator.TaskStats
 
getSystemMemoryUsage() - Method in class io.prestosql.connector.informationschema.InformationSchemaPageSource
 
getSystemMemoryUsage() - Method in class io.prestosql.operator.DriverContext
 
getSystemMemoryUsage() - Method in class io.prestosql.split.MappedPageSource
 
getSystemProperties() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getSystemProperties() - Method in interface io.prestosql.server.SessionContext
 
getSystemProperties() - Method in class io.prestosql.Session
 
getSystemProperties() - Method in class io.prestosql.SessionRepresentation
 
getSystemProperty(String, Class<T>) - Method in class io.prestosql.Session
 
getSystemSessionPropertyMetadata(String) - Method in class io.prestosql.metadata.SessionPropertyManager
 
getSystemTable(Session, QualifiedObjectName) - Method in interface io.prestosql.metadata.Metadata
 
getSystemTable(Session, QualifiedObjectName) - Method in class io.prestosql.metadata.MetadataManager
 
getSystemTable(ConnectorSession, SchemaTableName) - Method in class io.prestosql.connector.system.CoordinatorSystemTablesProvider
 
getSystemTable(ConnectorSession, SchemaTableName) - Method in class io.prestosql.connector.system.StaticSystemTablesProvider
 
getSystemTable(ConnectorSession, SchemaTableName) - Method in interface io.prestosql.connector.system.SystemTablesProvider
Resolves table name.
getSystemTables() - Method in class io.prestosql.connector.system.GlobalSystemConnector
 
getSystemTablesId() - Method in class io.prestosql.metadata.Catalog
 
getTable() - Method in class io.prestosql.connector.informationschema.InformationSchemaTableHandle
 
getTable() - Method in class io.prestosql.execution.Input
 
getTable() - Method in class io.prestosql.metadata.TableMetadata
 
getTable() - Method in class io.prestosql.sql.analyzer.Output
 
getTable() - Method in class io.prestosql.sql.planner.plan.TableScanNode
 
getTable() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan.TableColumnInfo
 
getTableColumnReferences() - Method in class io.prestosql.sql.analyzer.Analysis
 
getTableColumnReferences() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getTableHandle() - Method in class io.prestosql.metadata.AnalyzeMetadata
 
getTableHandle() - Method in class io.prestosql.sql.planner.plan.IndexSourceNode
 
getTableHandle() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewTarget
 
getTableHandle(Session, QualifiedObjectName) - Method in interface io.prestosql.metadata.Metadata
Returns a table handle for the specified table name.
getTableHandle(Session, QualifiedObjectName) - Method in class io.prestosql.metadata.MetadataManager
 
getTableHandle(ConnectorSession, SchemaTableName) - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
getTableHandle(ConnectorSession, SchemaTableName) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
getTableHandle(ConnectorSession, SchemaTableName) - Method in class io.prestosql.testing.TestingMetadata
 
getTableHandle(Table) - Method in class io.prestosql.sql.analyzer.Analysis
 
getTableHandleClass() - Method in class io.prestosql.connector.informationschema.InformationSchemaHandleResolver
 
getTableHandleClass() - Method in class io.prestosql.connector.system.SystemHandleResolver
 
getTableHandleClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getTableHandleClass() - Method in class io.prestosql.split.EmptySplitHandleResolver
 
getTableHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
getTableHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getTableHandleForStatisticsCollection(Session, QualifiedObjectName, Map<String, Object>) - Method in interface io.prestosql.metadata.Metadata
 
getTableHandleForStatisticsCollection(Session, QualifiedObjectName, Map<String, Object>) - Method in class io.prestosql.metadata.MetadataManager
 
getTableHandleForStatisticsCollection(ConnectorSession, SchemaTableName, Map<String, Object>) - Method in class io.prestosql.testing.TestingMetadata
 
getTableLayoutHandleClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getTableLayoutHandleClass() - Method in class io.prestosql.split.EmptySplitHandleResolver
 
getTableLayoutHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
getTableLayoutHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getTableMetadata() - Method in enum io.prestosql.connector.informationschema.InformationSchemaTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.CatalogSystemTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.AttributeJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.CatalogJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.ColumnJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.ProcedureColumnJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.ProcedureJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.PseudoColumnJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.SchemaJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.SuperTableJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.SuperTypeJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.TableJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.TableTypeJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.TypesJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.jdbc.UdtJdbcTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.NodeSystemTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.QuerySystemTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.RuleStatsSystemTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.TableCommentSystemTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.TaskSystemTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.TransactionsSystemTable
 
getTableMetadata() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateReference
 
getTableMetadata(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Return the metadata for the specified table handle.
getTableMetadata(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.testing.TestingMetadata
 
getTableName() - Method in class io.prestosql.connector.system.SystemTableHandle
 
getTableName() - Method in class io.prestosql.execution.TableInfo
 
getTableName() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
getTableName() - Method in class io.prestosql.testing.TestingMetadata.TestingTableHandle
 
getTablePartitioning() - Method in class io.prestosql.metadata.TableProperties
 
getTableProperties() - Method in class io.prestosql.metadata.TableLayoutResult
Deprecated.
 
getTableProperties(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
 
getTableProperties(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getTableProperties(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
getTableProperties(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
getTableProperties(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.testing.TestingMetadata
 
getTablePropertyManager() - Method in interface io.prestosql.metadata.Metadata
 
getTablePropertyManager() - Method in class io.prestosql.metadata.MetadataManager
 
getTables() - Method in class io.prestosql.execution.StageInfo
 
getTables() - Method in class io.prestosql.sql.analyzer.Analysis
 
getTables() - Method in class io.prestosql.sql.planner.StageExecutionPlan
 
getTableStatistics() - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
getTableStatistics(Session, TableHandle, Constraint) - Method in interface io.prestosql.metadata.Metadata
Return statistics for specified table for given filtering contraint.
getTableStatistics(Session, TableHandle, Constraint) - Method in class io.prestosql.metadata.MetadataManager
 
getTarget() - Method in class io.prestosql.sql.analyzer.Analysis
 
getTarget() - Method in class io.prestosql.sql.analyzer.Analysis.Insert
 
getTarget() - Method in class io.prestosql.sql.analyzer.Analysis.RefreshMaterializedViewAnalysis
 
getTarget() - Method in class io.prestosql.sql.planner.plan.DeleteNode
 
getTarget() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
getTarget() - Method in class io.prestosql.sql.planner.plan.TableDeleteNode
 
getTarget() - Method in class io.prestosql.sql.planner.plan.TableFinishNode
 
getTarget() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
getTargetConcurrency() - Method in class io.prestosql.execution.SplitConcurrencyController
 
getTargetNode() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph.Edge
 
getTargetSymbol() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph.Edge
 
getTaskConcurrency() - Method in class io.prestosql.execution.TaskManagerConfig
 
getTaskConcurrency(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getTaskContext() - Method in class io.prestosql.execution.SqlTaskExecution
 
getTaskContext() - Method in class io.prestosql.operator.PipelineContext
 
getTaskContextByTaskId(TaskId) - Method in class io.prestosql.memory.QueryContext
 
getTaskHandle() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
getTaskId() - Method in class io.prestosql.execution.executor.TaskHandle
 
getTaskId() - Method in interface io.prestosql.execution.RemoteTask
 
getTaskId() - Method in class io.prestosql.execution.SqlTask
 
getTaskId() - Method in class io.prestosql.execution.SqlTaskExecution
 
getTaskId() - Method in class io.prestosql.execution.TaskStateMachine
 
getTaskId() - Method in class io.prestosql.execution.TaskStatus
 
getTaskId() - Method in class io.prestosql.operator.DriverContext
 
getTaskId() - Method in class io.prestosql.operator.PipelineContext
 
getTaskId() - Method in class io.prestosql.operator.ProcessorContext
 
getTaskId() - Method in class io.prestosql.operator.TaskContext
 
getTaskId() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
getTaskInfo() - Method in interface io.prestosql.execution.RemoteTask
 
getTaskInfo() - Method in class io.prestosql.execution.SqlTask
 
getTaskInfo() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
getTaskInfo() - Method in class io.prestosql.server.remotetask.TaskInfoFetcher
 
getTaskInfo(long) - Method in class io.prestosql.execution.SqlTask
 
getTaskInfo(TaskId) - Method in class io.prestosql.execution.SqlTaskManager
 
getTaskInfo(TaskId) - Method in interface io.prestosql.execution.TaskManager
Gets the info for the specified task.
getTaskInfo(TaskId, long) - Method in class io.prestosql.execution.SqlTaskManager
 
getTaskInfo(TaskId, long) - Method in interface io.prestosql.execution.TaskManager
Gets future info for the task after the state changes from current state.
getTaskInfo(TaskId, Long, Duration, UriInfo, AsyncResponse) - Method in class io.prestosql.server.TaskResource
 
getTaskInstanceId() - Method in class io.prestosql.execution.buffer.BufferResult
 
getTaskInstanceId() - Method in class io.prestosql.execution.SqlTask
 
getTaskInstanceId() - Method in class io.prestosql.execution.TaskStatus
 
getTaskInstanceId() - Method in class io.prestosql.operator.HttpPageBufferClient.PagesResponse
 
getTaskInstanceId(TaskId) - Method in class io.prestosql.execution.SqlTaskManager
 
getTaskInstanceId(TaskId) - Method in interface io.prestosql.execution.TaskManager
Gets the unique instance id of a task.
getTaskManagementExecutor() - Method in class io.prestosql.execution.TaskManagementExecutor
 
getTaskManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getTaskMemoryContext() - Method in class io.prestosql.operator.TaskContext
 
getTaskNotificationExecutor() - Method in class io.prestosql.execution.SqlTaskManager
 
getTaskNotificationThreads() - Method in class io.prestosql.execution.TaskManagerConfig
 
getTaskResults(OutputBuffers.OutputBufferId, long, DataSize) - Method in class io.prestosql.execution.SqlTask
 
getTaskResults(TaskId, OutputBuffers.OutputBufferId, long, DataSize) - Method in class io.prestosql.execution.SqlTaskManager
 
getTaskResults(TaskId, OutputBuffers.OutputBufferId, long, DataSize) - Method in interface io.prestosql.execution.TaskManager
Gets results from a task either immediately or in the future.
getTasks() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getTasks() - Method in class io.prestosql.execution.StageInfo
 
getTaskStats() - Method in class io.prestosql.operator.TaskContext
 
getTaskStatus() - Method in interface io.prestosql.execution.RemoteTask
 
getTaskStatus() - Method in class io.prestosql.execution.SqlTask
 
getTaskStatus() - Method in class io.prestosql.execution.TaskInfo
 
getTaskStatus() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
getTaskStatus(long) - Method in class io.prestosql.execution.SqlTask
 
getTaskStatus(TaskId) - Method in class io.prestosql.execution.SqlTaskManager
 
getTaskStatus(TaskId) - Method in interface io.prestosql.execution.TaskManager
Gets the status for the specified task.
getTaskStatus(TaskId, long) - Method in class io.prestosql.execution.SqlTaskManager
 
getTaskStatus(TaskId, long) - Method in interface io.prestosql.execution.TaskManager
Gets future status for the task after the state changes from current state.
getTaskStatus(TaskId, Long, Duration, UriInfo, AsyncResponse) - Method in class io.prestosql.server.TaskResource
 
getTaskStatuses() - Method in class io.prestosql.execution.SqlStageExecution
 
getTaskWriterCount(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getTaskYieldThreads() - Method in class io.prestosql.execution.TaskManagerConfig
 
getTDigest() - Method in interface io.prestosql.operator.aggregation.state.TDigestState
 
getTDigest() - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory.GroupedTDigestState
 
getTDigest() - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory.SingleTDigestState
 
getThreadInfo() - Method in class io.prestosql.server.ThreadResource
 
getThreads(TaskId, String, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.ui.WorkerResource
 
getThreads(String) - Method in class io.prestosql.server.ui.WorkerResource
 
getTiesResolvingScheme() - Method in class io.prestosql.sql.planner.plan.LimitNode
 
getTime() - Method in class io.prestosql.sql.planner.iterative.RuleStats
 
getTime() - Method in class io.prestosql.sql.planner.optimizations.OptimizerStats
 
getTimeBetweenStartsSec() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getTimeoutExecutor() - Method in class io.prestosql.server.AsyncHttpExecutionMBean
 
getTimeoutExecutor() - Method in class io.prestosql.server.StatementHttpExecutionMBean
 
getTimestampField(ISOChronology, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
getTimeZoneId() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getTimeZoneId() - Method in interface io.prestosql.server.SessionContext
 
getTimeZoneKey() - Method in class io.prestosql.FullConnectorSession
 
getTimeZoneKey() - Method in class io.prestosql.Session
 
getTimeZoneKey() - Method in class io.prestosql.SessionRepresentation
 
getTimeZoneKey() - Method in class io.prestosql.testing.TestingConnectorSession
 
getToken() - Method in class io.prestosql.execution.buffer.BufferResult
 
getToken() - Method in class io.prestosql.operator.HttpPageBufferClient.PagesResponse
 
getTokenExpiration() - Method in class io.prestosql.server.security.oauth2.OAuth2Service.OAuthResult
 
getTokenUrl() - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
getTotalAvailableProcessors() - Method in class io.prestosql.memory.ClusterMemoryManager
 
getTotalAvailableProcessors() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getTotalBlockedTime() - Method in class io.prestosql.execution.QueryStats
 
getTotalBlockedTime() - Method in class io.prestosql.execution.StageStats
 
getTotalBlockedTime() - Method in class io.prestosql.operator.DriverStats
 
getTotalBlockedTime() - Method in class io.prestosql.operator.PipelineStats
 
getTotalBlockedTime() - Method in class io.prestosql.operator.TaskStats
 
getTotalBufferedBytes() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
getTotalBufferedPages() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
getTotalCount() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector
 
getTotalCpuTime() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getTotalCpuTime() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getTotalCpuTime() - Method in class io.prestosql.execution.BasicStageStats
 
getTotalCpuTime() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getTotalCpuTime() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
getTotalCpuTime() - Method in interface io.prestosql.execution.QueryExecution
 
getTotalCpuTime() - Method in class io.prestosql.execution.QueryStats
 
getTotalCpuTime() - Method in class io.prestosql.execution.scheduler.SqlQueryScheduler
 
getTotalCpuTime() - Method in class io.prestosql.execution.SqlQueryExecution
 
getTotalCpuTime() - Method in class io.prestosql.execution.SqlStageExecution
 
getTotalCpuTime() - Method in class io.prestosql.execution.StageStats
 
getTotalCpuTime() - Method in class io.prestosql.operator.DriverStats
 
getTotalCpuTime() - Method in class io.prestosql.operator.PipelineStats
 
getTotalCpuTime() - Method in class io.prestosql.operator.TaskStats
 
getTotalCpuTime() - Method in class io.prestosql.server.BasicQueryStats
 
getTotalCpuTimeSecs() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getTotalDistributedBytes() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getTotalDrivers() - Method in class io.prestosql.execution.BasicStageStats
 
getTotalDrivers() - Method in class io.prestosql.execution.QueryStats
 
getTotalDrivers() - Method in class io.prestosql.execution.StageStats
 
getTotalDrivers() - Method in class io.prestosql.operator.OperatorStats
 
getTotalDrivers() - Method in class io.prestosql.operator.PipelineStats
 
getTotalDrivers() - Method in class io.prestosql.operator.TaskStats
 
getTotalDrivers() - Method in class io.prestosql.server.BasicQueryStats
 
getTotalDynamicFilters() - Method in class io.prestosql.server.DynamicFilterService.DynamicFiltersStats
 
getTotalIndexJoinLookups() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
getTotalInputBytes() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getTotalInputRows() - Method in class io.prestosql.server.ui.ClusterStatsResource.ClusterStats
 
getTotalMemoryReservation() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getTotalMemoryReservation() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.BasicStageStats
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getTotalMemoryReservation() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
getTotalMemoryReservation() - Method in interface io.prestosql.execution.QueryExecution
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.QueryStats
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.scheduler.SqlQueryScheduler
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.SqlQueryExecution
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.SqlStageExecution
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.StageStateMachine
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.StageStats
 
getTotalMemoryReservation() - Method in class io.prestosql.server.BasicQueryStats
 
getTotalNodeMemory() - Method in class io.prestosql.memory.MemoryInfo
 
getTotalPagesSent() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
getTotalPartitions() - Method in class io.prestosql.operator.TaskContext
 
getTotalPartitions() - Method in class io.prestosql.server.TaskUpdateRequest
 
getTotalPartitionsCount() - Method in class io.prestosql.operator.WindowInfo.DriverWindowInfo
 
getTotalRowsCount() - Method in class io.prestosql.operator.WindowInfo.DriverWindowInfo
 
getTotalRowsCount() - Method in class io.prestosql.operator.WindowInfo.IndexInfo
 
getTotalRowsCount() - Method in class io.prestosql.server.protocol.QueryResultRows
Returns expected row count (we don't know yet if every row is serializable).
getTotalRowsSent() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
getTotalScheduledTime() - Method in class io.prestosql.execution.BasicStageStats
 
getTotalScheduledTime() - Method in class io.prestosql.execution.QueryStats
 
getTotalScheduledTime() - Method in class io.prestosql.execution.StageStats
 
getTotalScheduledTime() - Method in class io.prestosql.operator.DriverStats
 
getTotalScheduledTime() - Method in class io.prestosql.operator.PipelineStats
 
getTotalScheduledTime() - Method in class io.prestosql.operator.TaskStats
 
getTotalScheduledTime() - Method in class io.prestosql.server.BasicQueryStats
 
getTotalSpilledBytes() - Method in class io.prestosql.spiller.SpillerStats
 
getTotalSplitCount(InternalNode) - Method in class io.prestosql.execution.scheduler.NodeAssignmentStats
 
getTotalSplits() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getTotalTasks() - Method in class io.prestosql.execution.QueryStats
 
getTotalTasks() - Method in class io.prestosql.execution.StageStats
 
getToType() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.CastDependency
 
getToType() - Method in class io.prestosql.operator.annotations.CastImplementationDependency
 
getTraceToken() - Method in class io.prestosql.FullConnectorSession
 
getTraceToken() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getTraceToken() - Method in interface io.prestosql.server.SessionContext
 
getTraceToken() - Method in class io.prestosql.Session
 
getTraceToken() - Method in class io.prestosql.SessionRepresentation
 
getTraceToken() - Method in class io.prestosql.testing.TestingConnectorSession
 
getTransaction() - Method in class io.prestosql.metadata.TableHandle
 
getTransactionHandle() - Method in class io.prestosql.metadata.AnalyzeTableHandle
 
getTransactionHandle() - Method in class io.prestosql.metadata.IndexHandle
 
getTransactionHandle() - Method in class io.prestosql.metadata.InsertTableHandle
 
getTransactionHandle() - Method in class io.prestosql.metadata.OutputTableHandle
 
getTransactionHandle() - Method in class io.prestosql.sql.planner.PartitioningHandle
 
getTransactionHandleClass() - Method in class io.prestosql.connector.informationschema.InformationSchemaHandleResolver
 
getTransactionHandleClass() - Method in class io.prestosql.connector.system.GlobalSystemHandleResolver
 
getTransactionHandleClass() - Method in class io.prestosql.connector.system.SystemHandleResolver
 
getTransactionHandleClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getTransactionHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
getTransactionHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getTransactionHandleFor(CatalogName) - Method in class io.prestosql.metadata.CatalogMetadata
 
getTransactionId() - Method in class io.prestosql.connector.informationschema.InformationSchemaTransactionHandle
 
getTransactionId() - Method in class io.prestosql.connector.system.GlobalSystemTransactionHandle
 
getTransactionId() - Method in class io.prestosql.connector.system.SystemTransactionHandle
 
getTransactionId() - Method in class io.prestosql.security.SecurityContext
 
getTransactionId() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getTransactionId() - Method in interface io.prestosql.server.SessionContext
 
getTransactionId() - Method in class io.prestosql.Session
 
getTransactionId() - Method in class io.prestosql.SessionRepresentation
 
getTransactionId() - Method in class io.prestosql.transaction.TransactionInfo
 
getTransactionInfo(TransactionId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getTransactionInfo(TransactionId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getTransactionInfo(TransactionId) - Method in interface io.prestosql.transaction.TransactionManager
 
getTransactionManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getTransactionManager() - Method in class io.prestosql.testing.LocalQueryRunner
 
getTransactionManager() - Method in interface io.prestosql.testing.QueryRunner
 
getTransformedPlan() - Method in class io.prestosql.sql.planner.iterative.Rule.Result
 
getTrustStorePassword() - Method in class io.prestosql.server.InternalCommunicationConfig
 
getTrustStorePath() - Method in class io.prestosql.server.InternalCommunicationConfig
 
getTupleDomain() - Method in class io.prestosql.sql.planner.DomainTranslator.ExtractionResult
 
getTupleDomainConsumer() - Method in class io.prestosql.sql.planner.LocalDynamicFilterConsumer
 
getType() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
getType() - Method in class io.prestosql.execution.buffer.OutputBuffers
 
getType() - Method in class io.prestosql.execution.Column
 
getType() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
getType() - Method in exception io.prestosql.execution.Failure
 
getType() - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig
 
getType() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
getType() - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
getType() - Method in class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
getType() - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
getType() - Method in class io.prestosql.operator.ChannelSet
 
getType() - Method in class io.prestosql.operator.project.ConstantPageProjection
 
getType() - Method in class io.prestosql.operator.project.DictionaryAwarePageProjection
 
getType() - Method in class io.prestosql.operator.project.GeneratedPageProjection
 
getType() - Method in class io.prestosql.operator.project.InputPageProjection
 
getType() - Method in interface io.prestosql.operator.project.PageProjection
 
getType() - Method in class io.prestosql.operator.SetBuilderOperator.SetSupplier
 
getType() - Method in class io.prestosql.operator.window.FrameInfo
 
getType() - Method in class io.prestosql.operator.WindowFunctionDefinition
 
getType() - Method in class io.prestosql.operator.WorkProcessor.ProcessState
 
getType() - Method in class io.prestosql.sql.analyzer.Field
 
getType() - Method in class io.prestosql.sql.analyzer.ResolvedField
 
getType() - Method in class io.prestosql.sql.gen.Binding
 
getType() - Method in class io.prestosql.sql.planner.ExpressionInterpreter
 
getType() - Method in class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
getType() - Method in class io.prestosql.sql.planner.plan.ExchangeNode
 
getType() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode
 
getType() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getType() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getType() - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
getType() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint
 
getType() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
getType() - Method in class io.prestosql.sql.planner.planprinter.NodeRepresentation.TypedSymbol
 
getType() - Method in class io.prestosql.sql.relational.CallExpression
 
getType() - Method in class io.prestosql.sql.relational.ConstantExpression
 
getType() - Method in class io.prestosql.sql.relational.InputReferenceExpression
 
getType() - Method in class io.prestosql.sql.relational.LambdaDefinitionExpression
 
getType() - Method in class io.prestosql.sql.relational.RowExpression
 
getType() - Method in class io.prestosql.sql.relational.SpecialForm
 
getType() - Method in class io.prestosql.sql.relational.VariableReferenceExpression
 
getType() - Method in class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
getType(int) - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
getType(int) - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
getType(int) - Method in class io.prestosql.operator.PagesIndex
 
getType(Session, TypeProvider, Expression) - Method in class io.prestosql.sql.planner.TypeAnalyzer
 
getType(TypeId) - Method in interface io.prestosql.metadata.Metadata
 
getType(TypeId) - Method in class io.prestosql.metadata.MetadataManager
 
getType(TypeId) - Method in class io.prestosql.type.InternalTypeManager
 
getType(TypeSignature) - Method in class io.prestosql.metadata.FunctionDependencies
 
getType(TypeSignature) - Method in interface io.prestosql.metadata.Metadata
 
getType(TypeSignature) - Method in class io.prestosql.metadata.MetadataManager
 
getType(TypeSignature) - Method in class io.prestosql.type.InternalTypeManager
 
getType(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
getType(Expression) - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getType(String) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.SpecializeContext
 
getTypeDependencies() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration
 
getTypeDependencies() - Method in class io.prestosql.metadata.ResolvedFunction
 
getTypedHeap() - Method in interface io.prestosql.operator.aggregation.state.MinMaxNState
 
getTypedHeap() - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.GroupedMinMaxNState
 
getTypedHeap() - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.SingleMinMaxNState
 
getTypedKeyValueHeap() - Method in interface io.prestosql.operator.aggregation.minmaxby.MinMaxByNState
 
getTypedKeyValueHeap() - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.GroupedMinMaxByNState
 
getTypedKeyValueHeap() - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.SingleMinMaxByNState
 
getTypeManager() - Method in class io.prestosql.connector.ConnectorContextInstance
 
getTypeManager() - Method in class io.prestosql.testing.TestingConnectorContext
 
getTypeOnlyCoercions() - Method in class io.prestosql.sql.analyzer.Analysis
 
getTypeOnlyCoercions() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getTypeOperatorDeclaration(TypeOperators) - Method in class io.prestosql.type.IpAddressType
 
getTypeOperatorDeclaration(TypeOperators) - Method in class io.prestosql.type.JsonType
 
getTypeOperatorDeclaration(TypeOperators) - Method in class io.prestosql.type.UnknownType
 
getTypeOperatorDeclaration(TypeOperators) - Method in class io.prestosql.type.UuidType
 
getTypeOperators() - Method in class io.prestosql.testing.LocalQueryRunner
 
getTypeOperators() - Method in class io.prestosql.type.InternalTypeManager
 
getTypeParameters() - Method in class io.prestosql.type.FunctionType
 
getTypes() - Method in class io.prestosql.execution.StageInfo
 
getTypes() - Method in interface io.prestosql.metadata.Metadata
 
getTypes() - Method in class io.prestosql.metadata.MetadataManager
 
getTypes() - Method in class io.prestosql.operator.BigintGroupByHash
 
getTypes() - Method in interface io.prestosql.operator.GroupByHash
 
getTypes() - Method in class io.prestosql.operator.index.IndexLookupSourceFactory
 
getTypes() - Method in interface io.prestosql.operator.LookupSourceFactory
 
getTypes() - Method in class io.prestosql.operator.MultiChannelGroupByHash
 
getTypes() - Method in class io.prestosql.operator.NoChannelGroupByHash
 
getTypes() - Method in class io.prestosql.operator.PagesIndex
 
getTypes() - Method in class io.prestosql.operator.PagesSpatialIndexFactory
 
getTypes() - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
getTypes() - Method in class io.prestosql.sql.analyzer.Analysis
 
getTypes() - Method in class io.prestosql.sql.planner.Plan
 
getTypes() - Method in class io.prestosql.sql.planner.PlanFragment
 
getTypes() - Method in class io.prestosql.sql.planner.SymbolAllocator
 
getTypes() - Method in class io.prestosql.testing.MaterializedResult
 
getTypes(Session, TypeProvider, Expression) - Method in class io.prestosql.sql.planner.TypeAnalyzer
 
getTypes(Session, TypeProvider, Iterable<Expression>) - Method in class io.prestosql.sql.planner.TypeAnalyzer
 
getTypeSignature() - Method in class io.prestosql.sql.analyzer.TypeSignatureProvider
 
getTypeSignature() - Method in class io.prestosql.type.FunctionType
 
getTypeSignature(List<Type>) - Method in class io.prestosql.sql.analyzer.TypeSignatureProvider
 
getTypeVariable(String) - Method in class io.prestosql.metadata.FunctionBinding
 
getTypeVariableConstraints() - Method in class io.prestosql.metadata.Signature
 
getUi() - Method in class io.prestosql.server.ui.WebUiStaticResource
 
getUnblockedQuantaWallTime() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getUncompressedSizeInBytes() - Method in class io.prestosql.execution.buffer.SerializedPage
 
getUnenforcedConstraint() - Method in class io.prestosql.metadata.TableLayoutResult
Deprecated.
 
getUnfoldedExpressions() - Method in class io.prestosql.sql.analyzer.Analysis.SelectExpression
 
getUnnest(Unnest) - Method in class io.prestosql.sql.analyzer.Analysis
 
getUnprocessedCatalogProperties() - Method in class io.prestosql.Session
 
getUnprocessedCatalogProperties() - Method in class io.prestosql.SessionRepresentation
 
getUnresolvedTupleDomain() - Method in class io.prestosql.metadata.ResolvedIndex
 
getUpdatablePageSourceSupplier() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
getUpdatablePageSourceSupplier() - Method in class io.prestosql.operator.TableScanWorkProcessorOperator
 
getUpdatablePageSourceSupplier() - Method in interface io.prestosql.operator.WorkProcessorSourceOperator
 
getUpdateCount() - Method in class io.prestosql.server.protocol.QueryResultRows
 
getUpdateCount() - Method in class io.prestosql.testing.MaterializedResult
 
getUpdateRoundTripMillis() - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
getUpdateRowIdColumnHandle(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Get the row ID column handle used with UpdatablePageSource.
getUpdateRowIdColumnHandle(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getUpdateType() - Method in class io.prestosql.execution.QueryInfo
 
getUpdateType() - Method in class io.prestosql.server.BasicQueryInfo
 
getUpdateType() - Method in class io.prestosql.sql.analyzer.Analysis
 
getUpdateType() - Method in class io.prestosql.testing.MaterializedResult
 
getUpdateWithPlanBytes() - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
getUptime() - Method in class io.prestosql.server.NodeStatus
 
getUptime() - Method in class io.prestosql.server.ui.ClusterResource.ClusterInfo
 
getUri() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
getUri() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getUri(UriInfo) - Method in interface io.prestosql.dispatcher.CoordinatorLocation
 
getUri(UriInfo) - Method in class io.prestosql.dispatcher.LocalCoordinatorLocation
 
getUser() - Method in class io.prestosql.server.QueryStateInfo
 
getUser() - Method in class io.prestosql.server.security.BasicAuthCredentials
 
getUser() - Method in class io.prestosql.Session
 
getUser() - Method in class io.prestosql.SessionRepresentation
 
getUserAgent() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getUserAgent() - Method in interface io.prestosql.server.SessionContext
 
getUserAgent() - Method in class io.prestosql.Session
 
getUserAgent() - Method in class io.prestosql.SessionRepresentation
 
getUserErrorFailures() - Method in class io.prestosql.execution.QueryManagerStats
 
getUserMappingFile() - Method in class io.prestosql.server.security.CertificateConfig
 
getUserMappingFile() - Method in class io.prestosql.server.security.InsecureAuthenticatorConfig
 
getUserMappingFile() - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
getUserMappingFile() - Method in class io.prestosql.server.security.KerberosConfig
 
getUserMappingFile() - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
getUserMappingFile() - Method in class io.prestosql.server.security.PasswordAuthenticatorConfig
 
getUserMappingPattern() - Method in class io.prestosql.server.security.CertificateConfig
 
getUserMappingPattern() - Method in class io.prestosql.server.security.InsecureAuthenticatorConfig
 
getUserMappingPattern() - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
getUserMappingPattern() - Method in class io.prestosql.server.security.KerberosConfig
 
getUserMappingPattern() - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
getUserMappingPattern() - Method in class io.prestosql.server.security.PasswordAuthenticatorConfig
 
getUserMemoryReservation() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
getUserMemoryReservation() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
getUserMemoryReservation() - Method in class io.prestosql.execution.BasicStageStats
 
getUserMemoryReservation() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getUserMemoryReservation() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
getUserMemoryReservation() - Method in interface io.prestosql.execution.QueryExecution
 
getUserMemoryReservation() - Method in class io.prestosql.execution.QueryStats
 
getUserMemoryReservation() - Method in class io.prestosql.execution.scheduler.SqlQueryScheduler
 
getUserMemoryReservation() - Method in class io.prestosql.execution.SqlQueryExecution
 
getUserMemoryReservation() - Method in class io.prestosql.execution.SqlStageExecution
 
getUserMemoryReservation() - Method in class io.prestosql.execution.StageStateMachine
 
getUserMemoryReservation() - Method in class io.prestosql.execution.StageStats
 
getUserMemoryReservation() - Method in class io.prestosql.operator.DriverStats
 
getUserMemoryReservation() - Method in class io.prestosql.operator.OperatorStats
 
getUserMemoryReservation() - Method in class io.prestosql.operator.PipelineStats
 
getUserMemoryReservation() - Method in class io.prestosql.operator.TaskStats
 
getUserMemoryReservation() - Method in class io.prestosql.server.BasicQueryStats
 
getUsername() - Method in class io.prestosql.server.ui.FixedUserWebUiConfig
 
getUtilization() - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
getUtilization() - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
getUtilization() - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
getUtilization() - Method in interface io.prestosql.execution.buffer.OutputBuffer
Get the memory utilization percentage.
getUtilization() - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
getUuid() - Method in class io.prestosql.testing.TestingTransactionHandle
 
getValidationCpuTime() - Method in class io.prestosql.operator.TableWriterOperator.TableWriterInfo
 
getValidUntil() - Method in class io.prestosql.server.security.oauth2.OAuth2Client.AccessToken
 
getValue() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
getValue() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedMarker
 
getValue() - Method in class io.prestosql.sql.relational.ConstantExpression
 
getValue(BytecodeExpression, BytecodeExpression) - Method in class io.prestosql.sql.gen.SqlTypeBytecodeExpression
 
getValue(Symbol) - Method in class io.prestosql.sql.planner.LookupSymbolResolver
 
getValue(Symbol) - Method in class io.prestosql.sql.planner.NoOpSymbolResolver
 
getValue(Symbol) - Method in interface io.prestosql.sql.planner.SymbolResolver
 
getValueAddresses() - Method in class io.prestosql.operator.PagesIndex
 
getValueInputMetadata() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getValues() - Method in class io.prestosql.operator.aggregation.KeyValuePairs
 
getValues(Type, Block) - Static method in class io.prestosql.operator.scalar.MapValues
 
getValuesFraction() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
getValueType() - Method in interface io.prestosql.operator.aggregation.state.KeyValuePairsState
 
getValueType() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.GroupedState
 
getValueType() - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.SingleState
 
getVariadicBound() - Method in class io.prestosql.metadata.TypeVariableConstraint
 
getVendorFile(String, ServletContext) - Method in class io.prestosql.server.ui.WebUiStaticResource
 
getVersion() - Method in class io.prestosql.execution.buffer.OutputBuffers
 
getVersion() - Method in class io.prestosql.execution.DynamicFiltersCollector.VersionedDynamicFilterDomains
 
getVersion() - Method in class io.prestosql.execution.TaskStatus
 
getVersion() - Method in class io.prestosql.memory.MemoryPoolAssignmentsRequest
 
getVersion() - Method in class io.prestosql.memory.VersionedMemoryPoolId
 
getVersion() - Method in class io.prestosql.metadata.InternalNode
 
getVersionEmbedder() - Method in class io.prestosql.connector.ConnectorContextInstance
 
getVersionEmbedder() - Method in class io.prestosql.testing.TestingConnectorContext
 
getView(Session, QualifiedObjectName) - Method in interface io.prestosql.metadata.Metadata
Returns the view definition for the specified view name.
getView(Session, QualifiedObjectName) - Method in class io.prestosql.metadata.MetadataManager
 
getView(ConnectorSession, SchemaTableName) - Method in class io.prestosql.testing.TestingMetadata
 
getViews(Session, Metadata, AccessControl, QualifiedTablePrefix) - Static method in class io.prestosql.metadata.MetadataListing
 
getViews(Session, QualifiedTablePrefix) - Method in interface io.prestosql.metadata.Metadata
Get the view definitions that match the specified table prefix (never null).
getViews(Session, QualifiedTablePrefix) - Method in class io.prestosql.metadata.MetadataManager
 
getViews(ConnectorSession, Optional<String>) - Method in class io.prestosql.testing.TestingMetadata
 
getVisibleFieldCount() - Method in class io.prestosql.sql.analyzer.RelationType
 
getVisibleFields() - Method in class io.prestosql.sql.analyzer.RelationType
Gets only the visible fields.
getW() - Method in class io.prestosql.server.security.jwt.JwkDecoder.JwkEcPublicKey
 
getWaitingForSource() - Method in class io.prestosql.execution.scheduler.SplitSchedulerStats
 
getWaitingQueuedQueries() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
getWaitingSplits() - Method in class io.prestosql.execution.executor.TaskExecutor
 
getWaitNanos() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
getWallInputBytesRate() - Method in class io.prestosql.execution.QueryManagerStats
 
getWarmupInterval() - Method in class io.prestosql.failuredetector.FailureDetectorConfig
 
getWarningCollector() - Method in class io.prestosql.execution.QueryStateMachine
 
getWarningCollector() - Method in interface io.prestosql.sql.planner.iterative.Rule.Context
 
getWarnings() - Method in class io.prestosql.execution.QueryInfo
 
getWarnings() - Method in class io.prestosql.execution.warnings.DefaultWarningCollector
 
getWarnings() - Method in interface io.prestosql.execution.warnings.WarningCollector
 
getWarnings() - Method in class io.prestosql.testing.MaterializedResult
 
getWarnings() - Method in class io.prestosql.testing.TestingWarningCollector
 
getWeightedExpectedHashCollisions() - Method in class io.prestosql.operator.HashCollisionsInfo
 
getWeightedHashCollisions() - Method in class io.prestosql.operator.HashCollisionsInfo
 
getWeightedSumSquaredHashCollisions() - Method in class io.prestosql.operator.HashCollisionsInfo
 
getWhere(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
getWindowFunctionImplementation(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.metadata.FunctionRegistry
 
getWindowFunctionImplementation(ResolvedFunction) - Method in interface io.prestosql.metadata.Metadata
 
getWindowFunctionImplementation(ResolvedFunction) - Method in class io.prestosql.metadata.MetadataManager
 
getWindowFunctions() - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getWindowFunctions() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
getWindowFunctions() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getWindowFunctions(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
getWindowInfos() - Method in class io.prestosql.operator.WindowInfo
 
getWindowOperatorStats() - Method in class io.prestosql.sql.planner.planprinter.WindowPlanNodeStats
 
getWorkerMemoryInfo() - Method in class io.prestosql.memory.ClusterMemoryManager
 
getWorkerNodes() - Method in class io.prestosql.connector.ConnectorAwareNodeManager
 
getWorkerNodes() - Method in class io.prestosql.testing.TestingNodeManager
 
getWorkersByNetworkPath() - Method in class io.prestosql.execution.scheduler.NodeMap
 
getWriterCount() - Method in class io.prestosql.execution.TaskManagerConfig
 
getWriterMinSize() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getWriterMinSize(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getWrittenConnectorId() - Method in class io.prestosql.transaction.TransactionInfo
 
getWrittenPositions() - Method in class io.prestosql.execution.QueryStats
 
getXxHash64Operator(Type) - Method in class io.prestosql.type.BlockTypeOperators
 
getYieldExecutor() - Method in class io.prestosql.operator.DriverContext
 
getYieldSignal() - Method in class io.prestosql.operator.DriverContext
 
global(ActualProperties) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
global(ActualProperties.Global) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
globalAggregation() - Static method in class io.prestosql.sql.planner.plan.AggregationNode
 
GlobalSystemConnector - Class in io.prestosql.connector.system
 
GlobalSystemConnector(Set<SystemTable>, Set<Procedure>) - Constructor for class io.prestosql.connector.system.GlobalSystemConnector
 
GlobalSystemConnectorFactory - Class in io.prestosql.connector.system
 
GlobalSystemConnectorFactory(Set<SystemTable>, Set<Procedure>) - Constructor for class io.prestosql.connector.system.GlobalSystemConnectorFactory
 
GlobalSystemHandleResolver - Class in io.prestosql.connector.system
 
GlobalSystemHandleResolver() - Constructor for class io.prestosql.connector.system.GlobalSystemHandleResolver
 
GlobalSystemTransactionHandle - Class in io.prestosql.connector.system
 
GlobalSystemTransactionHandle(TransactionId) - Constructor for class io.prestosql.connector.system.GlobalSystemTransactionHandle
 
GONE - io.prestosql.failuredetector.FailureDetector.State
 
GracefulShutdownHandler - Class in io.prestosql.server
 
GracefulShutdownHandler(TaskManager, ServerConfig, ShutdownAction, LifeCycleManager) - Constructor for class io.prestosql.server.GracefulShutdownHandler
 
GracefulShutdownModule - Class in io.prestosql.server
 
GracefulShutdownModule() - Constructor for class io.prestosql.server.GracefulShutdownModule
 
GRANT_EXECUTE_FUNCTION - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
grantRoles(Session, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in interface io.prestosql.metadata.Metadata
Grants the specified roles to the specified grantees in the specified catalog
grantRoles(Session, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.metadata.MetadataManager
 
GrantRolesTask - Class in io.prestosql.execution
 
GrantRolesTask() - Constructor for class io.prestosql.execution.GrantRolesTask
 
grantSchemaPrivileges(Session, CatalogSchemaName, Set<Privilege>, PrestoPrincipal, boolean) - Method in interface io.prestosql.metadata.Metadata
Grants the specified privilege to the specified user on the specified schema.
grantSchemaPrivileges(Session, CatalogSchemaName, Set<Privilege>, PrestoPrincipal, boolean) - Method in class io.prestosql.metadata.MetadataManager
 
grantTablePrivileges(Session, QualifiedObjectName, Set<Privilege>, PrestoPrincipal, boolean) - Method in interface io.prestosql.metadata.Metadata
Grants the specified privilege to the specified user on the specified table
grantTablePrivileges(Session, QualifiedObjectName, Set<Privilege>, PrestoPrincipal, boolean) - Method in class io.prestosql.metadata.MetadataManager
 
grantTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, PrestoPrincipal, boolean) - Method in class io.prestosql.testing.TestingMetadata
 
GrantTask - Class in io.prestosql.execution
 
GrantTask() - Constructor for class io.prestosql.execution.GrantTask
 
graphvizDistributedPlan(SubPlan) - Static method in class io.prestosql.sql.planner.planprinter.PlanPrinter
 
graphvizLogicalPlan(PlanNode, TypeProvider) - Static method in class io.prestosql.sql.planner.planprinter.PlanPrinter
 
GraphvizPrinter - Class in io.prestosql.util
 
greaterThan(int, int) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
Greatest - Class in io.prestosql.operator.scalar
 
Greatest() - Constructor for class io.prestosql.operator.scalar.Greatest
 
GREATEST - Static variable in class io.prestosql.operator.scalar.Greatest
 
GREEN - io.prestosql.operator.scalar.ColorFunctions.SystemColor
 
GroupArrayAggregationState - Class in io.prestosql.operator.aggregation.arrayagg
 
groupBy(PlanNodeStatsEstimate, Collection<Symbol>, Map<Symbol, AggregationNode.Aggregation>) - Static method in class io.prestosql.cost.AggregationStatsRule
 
GroupByHash - Interface in io.prestosql.operator
 
GroupByHashPageIndexer - Class in io.prestosql
 
GroupByHashPageIndexer(GroupByHash) - Constructor for class io.prestosql.GroupByHashPageIndexer
 
GroupByHashPageIndexer(List<? extends Type>, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.GroupByHashPageIndexer
 
GroupByHashPageIndexerFactory - Class in io.prestosql
 
GroupByHashPageIndexerFactory(JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.GroupByHashPageIndexerFactory
 
GroupByIdBlock - Class in io.prestosql.operator
 
GroupByIdBlock(long, Block) - Constructor for class io.prestosql.operator.GroupByIdBlock
 
grouped(Collection<T>) - Static method in class io.prestosql.sql.planner.optimizations.LocalProperties
 
GROUPED_EXECUTION - io.prestosql.operator.PipelineExecutionStrategy
 
GROUPED_EXECUTION - Static variable in class io.prestosql.SystemSessionProperties
 
GroupedAccumulator - Interface in io.prestosql.operator.aggregation
 
GroupedHistogramState - Class in io.prestosql.operator.aggregation.histogram
state object that uses a single histogram for all groups.
GroupedHistogramState(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, int) - Constructor for class io.prestosql.operator.aggregation.histogram.GroupedHistogramState
 
GroupedHyperLogLogState() - Constructor for class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.GroupedHyperLogLogState
 
GroupedLongApproximateMostFrequentState() - Constructor for class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState
 
GroupedLongApproximateMostFrequentState() - Constructor for class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState
 
GroupedLongDecimalWithOverflowAndLongState() - Constructor for class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.GroupedLongDecimalWithOverflowAndLongState
 
GroupedLongDecimalWithOverflowState() - Constructor for class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
GroupedMinMaxByNState() - Constructor for class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.GroupedMinMaxByNState
 
GroupedMinMaxNState() - Constructor for class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.GroupedMinMaxNState
 
GroupedMultimapAggregationState - Class in io.prestosql.operator.aggregation.multimapagg
 
GroupedMultimapAggregationState(Type, Type) - Constructor for class io.prestosql.operator.aggregation.multimapagg.GroupedMultimapAggregationState
 
GroupedQuantileDigestAndPercentileState() - Constructor for class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.GroupedQuantileDigestAndPercentileState
 
GroupedQuantileDigestState() - Constructor for class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.GroupedQuantileDigestState
 
GroupedSetDigestState() - Constructor for class io.prestosql.type.setdigest.SetDigestStateFactory.GroupedSetDigestState
 
GroupedState() - Constructor for class io.prestosql.operator.aggregation.NumericHistogramStateFactory.GroupedState
 
GroupedState(Type, Type) - Constructor for class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.GroupedState
 
GroupedTDigestAndPercentileArrayState() - Constructor for class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.GroupedTDigestAndPercentileArrayState
 
GroupedTDigestAndPercentileState() - Constructor for class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.GroupedTDigestAndPercentileState
 
GroupedTDigestState() - Constructor for class io.prestosql.operator.aggregation.state.TDigestStateFactory.GroupedTDigestState
 
GroupedTopNBuilder - Class in io.prestosql.operator
This class finds the top N rows defined by {@param comparator} for each group specified by {@param groupByHash}.
GroupedTopNBuilder(List<Type>, PageWithPositionComparator, int, boolean, GroupByHash) - Constructor for class io.prestosql.operator.GroupedTopNBuilder
 
GroupedTopNRowNumberAccumulator - Class in io.prestosql.operator
Memory Layout:
GroupedTopNRowNumberAccumulator(LongComparator, int, LongConsumer) - Constructor for class io.prestosql.operator.GroupedTopNRowNumberAccumulator
 
GroupedTopNRowNumberAccumulator.RowReference - Interface in io.prestosql.operator
Reference to an input row.
GroupedTypedHistogram - Class in io.prestosql.operator.aggregation.histogram
implementation that uses groupId in the hash key, so that we may store all groupId x value -> count in one giant map.
GroupedTypedHistogram(long, Block, Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, int) - Constructor for class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
TODO: use RowBlock in the future
GroupedTypedHistogram(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, int) - Constructor for class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
groupId() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
GroupIdNode - Class in io.prestosql.sql.planner.plan
 
GroupIdNode(PlanNodeId, PlanNode, List<List<Symbol>>, Map<Symbol, Symbol>, List<Symbol>, Symbol) - Constructor for class io.prestosql.sql.planner.plan.GroupIdNode
 
GroupIdOperator - Class in io.prestosql.operator
 
GroupIdOperator(OperatorContext, List<Type>, int[][], Block[], Block[]) - Constructor for class io.prestosql.operator.GroupIdOperator
 
GroupIdOperator.GroupIdOperatorFactory - Class in io.prestosql.operator
 
GroupIdOperatorFactory(int, PlanNodeId, List<? extends Type>, List<Map<Integer, Integer>>) - Constructor for class io.prestosql.operator.GroupIdOperator.GroupIdOperatorFactory
 
groupingColumns() - Static method in class io.prestosql.sql.planner.plan.Patterns.Aggregation
 
GroupingOperationRewriter - Class in io.prestosql.sql.planner
 
GroupingSetAnalysis(List<Expression>, List<Set<FieldId>>, List<List<FieldId>>, List<List<Set<FieldId>>>, List<Expression>) - Constructor for class io.prestosql.sql.analyzer.Analysis.GroupingSetAnalysis
 
GroupingSetDescriptor(List<Symbol>, int, Set<Integer>) - Constructor for class io.prestosql.sql.planner.plan.AggregationNode.GroupingSetDescriptor
 
groupingSets(List<Symbol>, int, Set<Integer>) - Static method in class io.prestosql.sql.planner.plan.AggregationNode
 
GroupProviderManager - Class in io.prestosql.security
 
GroupProviderManager() - Constructor for class io.prestosql.security.GroupProviderManager
 
GroupReference - Class in io.prestosql.sql.planner.iterative
 
GroupReference(PlanNodeId, int, List<Symbol>) - Constructor for class io.prestosql.sql.planner.iterative.GroupReference
 
groups() - Method in annotation type io.prestosql.util.PowerOfTwo
 

H

hammingDistance(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
handle(Request, Response) - Method in class io.prestosql.operator.HttpPageBufferClient.PageResponseHandler
 
handleException(Request, Exception) - Method in class io.prestosql.operator.HttpPageBufferClient.PageResponseHandler
 
handleInternalRequest(ContainerRequestContext) - Method in class io.prestosql.server.InternalAuthenticationManager
 
HandleJsonModule - Class in io.prestosql.metadata
 
HandleJsonModule() - Constructor for class io.prestosql.metadata.HandleJsonModule
 
handleNonNull(boolean) - Static method in class io.prestosql.operator.scalar.CastFromUnknownOperator
 
handleNullValue(Scope, LabelNode, Class<?>, List<Class<?>>, boolean) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
HandleResolver - Class in io.prestosql.metadata
 
HandleResolver() - Constructor for class io.prestosql.metadata.HandleResolver
 
hasColumnMask(QualifiedObjectName, String, String) - Method in class io.prestosql.sql.analyzer.Analysis
 
hasConnectorSession() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
hasDefaultOutput() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
hasDependency() - Method in class io.prestosql.sql.analyzer.TypeSignatureProvider
 
hasDistinct() - Method in interface io.prestosql.operator.aggregation.AccumulatorFactory
 
hasDistinct() - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
hasEmptyGroupingSet() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
hasErrorCode(ErrorCodeSupplier) - Method in class io.prestosql.testing.assertions.PrestoExceptionAssert
 
hasFreeReferencesToLambdaArgument(Node, Analysis) - Static method in class io.prestosql.sql.analyzer.FreeLambdaReferenceExtractor
 
hash(int, int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
HASH - io.prestosql.sql.planner.SystemPartitioningHandle.SystemPartitionFunction
 
HASH_PARTITION_COUNT - Static variable in class io.prestosql.SystemSessionProperties
 
HashAggregationBuilder - Interface in io.prestosql.operator.aggregation.builder
 
HashAggregationOperator - Class in io.prestosql.operator
 
HashAggregationOperator(OperatorContext, List<Type>, List<Integer>, List<Integer>, AggregationNode.Step, boolean, List<AccumulatorFactory>, Optional<Integer>, Optional<Integer>, int, Optional<DataSize>, boolean, DataSize, DataSize, SpillerFactory, JoinCompiler, BlockTypeOperators, boolean) - Constructor for class io.prestosql.operator.HashAggregationOperator
 
HashAggregationOperator.HashAggregationOperatorFactory - Class in io.prestosql.operator
 
HashAggregationOperatorFactory(int, PlanNodeId, List<? extends Type>, List<Integer>, List<Integer>, AggregationNode.Step, boolean, List<AccumulatorFactory>, Optional<Integer>, Optional<Integer>, int, Optional<DataSize>, boolean, DataSize, SpillerFactory, JoinCompiler, BlockTypeOperators, boolean) - Constructor for class io.prestosql.operator.HashAggregationOperator.HashAggregationOperatorFactory
 
HashAggregationOperatorFactory(int, PlanNodeId, List<? extends Type>, List<Integer>, List<Integer>, AggregationNode.Step, List<AccumulatorFactory>, Optional<Integer>, Optional<Integer>, int, Optional<DataSize>, JoinCompiler, BlockTypeOperators, boolean) - Constructor for class io.prestosql.operator.HashAggregationOperator.HashAggregationOperatorFactory
 
HashBuilderOperator - Class in io.prestosql.operator
 
HashBuilderOperator(OperatorContext, PartitionedLookupSourceFactory, int, List<Integer>, List<Integer>, OptionalInt, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, Optional<Integer>, List<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, int, PagesIndex.Factory, boolean, SingleStreamSpillerFactory) - Constructor for class io.prestosql.operator.HashBuilderOperator
 
HashBuilderOperator.HashBuilderOperatorFactory - Class in io.prestosql.operator
 
HashBuilderOperator.State - Enum in io.prestosql.operator
 
HashBuilderOperatorFactory(int, PlanNodeId, JoinBridgeManager<PartitionedLookupSourceFactory>, List<Integer>, List<Integer>, OptionalInt, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, Optional<Integer>, List<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, int, PagesIndex.Factory, boolean, SingleStreamSpillerFactory) - Constructor for class io.prestosql.operator.HashBuilderOperator.HashBuilderOperatorFactory
 
hashCode() - Method in class io.prestosql.connector.CatalogName
 
hashCode() - Method in class io.prestosql.connector.informationschema.InformationSchemaColumnHandle
 
hashCode() - Method in class io.prestosql.connector.informationschema.InformationSchemaTableHandle
 
hashCode() - Method in class io.prestosql.connector.informationschema.InformationSchemaTransactionHandle
 
hashCode() - Method in class io.prestosql.connector.system.GlobalSystemTransactionHandle
 
hashCode() - Method in class io.prestosql.connector.system.SystemColumnHandle
 
hashCode() - Method in class io.prestosql.connector.system.SystemTableHandle
 
hashCode() - Method in class io.prestosql.connector.system.SystemTransactionHandle
 
hashCode() - Method in class io.prestosql.cost.LocalCostEstimate
 
hashCode() - Method in class io.prestosql.cost.PlanCostEstimate
 
hashCode() - Method in class io.prestosql.cost.PlanNodeStatsEstimate
 
hashCode() - Method in class io.prestosql.cost.StatisticRange
 
hashCode() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
hashCode() - Method in class io.prestosql.execution.buffer.BufferInfo
 
hashCode() - Method in class io.prestosql.execution.buffer.BufferResult
 
hashCode() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
hashCode() - Method in class io.prestosql.execution.buffer.OutputBuffers
 
hashCode() - Method in class io.prestosql.execution.buffer.OutputBuffers.OutputBufferId
 
hashCode() - Method in class io.prestosql.execution.buffer.PageBufferInfo
 
hashCode() - Method in class io.prestosql.execution.buffer.PageCodecMarker.MarkerSet
 
hashCode() - Method in class io.prestosql.execution.Column
 
hashCode() - Method in class io.prestosql.execution.Input
 
hashCode() - Method in class io.prestosql.execution.Lifespan
 
hashCode() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
hashCode() - Method in class io.prestosql.execution.ScheduledSplit
 
hashCode() - Method in class io.prestosql.execution.scheduler.NetworkLocation
 
hashCode() - Method in class io.prestosql.execution.StageId
 
hashCode() - Method in class io.prestosql.execution.TaskId
 
hashCode() - Method in class io.prestosql.memory.ClusterMemoryPool
 
hashCode() - Method in class io.prestosql.metadata.AllNodes
 
hashCode() - Method in class io.prestosql.metadata.AnalyzeTableHandle
 
hashCode() - Method in class io.prestosql.metadata.BoundSignature
 
hashCode() - Method in class io.prestosql.metadata.FunctionArgumentDefinition
 
hashCode() - Method in class io.prestosql.metadata.FunctionBinding
 
hashCode() - Method in class io.prestosql.metadata.FunctionDependencies.FunctionKey
 
hashCode() - Method in class io.prestosql.metadata.FunctionDependencies.OperatorKey
 
hashCode() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.CastDependency
 
hashCode() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependency
 
hashCode() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.OperatorDependency
 
hashCode() - Method in class io.prestosql.metadata.FunctionId
 
hashCode() - Method in class io.prestosql.metadata.IndexHandle
 
hashCode() - Method in class io.prestosql.metadata.InsertTableHandle
 
hashCode() - Method in class io.prestosql.metadata.InternalNode
 
hashCode() - Method in class io.prestosql.metadata.LongVariableConstraint
 
hashCode() - Method in class io.prestosql.metadata.NewTableLayout
 
hashCode() - Method in class io.prestosql.metadata.OutputTableHandle
 
hashCode() - Method in class io.prestosql.metadata.QualifiedObjectName
 
hashCode() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
hashCode() - Method in class io.prestosql.metadata.ResolvedFunction
 
hashCode() - Method in class io.prestosql.metadata.Signature
 
hashCode() - Method in class io.prestosql.metadata.TableHandle
 
hashCode() - Method in class io.prestosql.metadata.TableProperties.TablePartitioning
 
hashCode() - Method in class io.prestosql.metadata.TypeVariableConstraint
 
hashCode() - Method in class io.prestosql.operator.annotations.CastImplementationDependency
 
hashCode() - Method in class io.prestosql.operator.annotations.FunctionImplementationDependency
 
hashCode() - Method in class io.prestosql.operator.annotations.OperatorImplementationDependency
 
hashCode() - Method in class io.prestosql.operator.annotations.ScalarImplementationDependency
 
hashCode() - Method in class io.prestosql.operator.annotations.TypeImplementationDependency
 
hashCode() - Method in class io.prestosql.operator.HttpPageBufferClient
 
hashCode() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.SpecializedSignature
 
hashCode() - Method in class io.prestosql.operator.window.FrameInfo
 
hashCode() - Method in class io.prestosql.operator.WindowOperator.FrameBoundKey
 
hashCode() - Method in class io.prestosql.security.SecurityContext
 
hashCode() - Method in class io.prestosql.server.DynamicFilterService.DynamicFilterDomainStats
 
hashCode() - Method in class io.prestosql.server.DynamicFilterService.DynamicFiltersStats
 
hashCode() - Method in class io.prestosql.server.security.InternalPrincipal
 
hashCode() - Method in class io.prestosql.server.security.oauth2.OAuth2ServiceModule
 
hashCode() - Method in class io.prestosql.sql.analyzer.Analysis.AccessControlInfo
 
hashCode() - Method in class io.prestosql.sql.analyzer.CanonicalizationAware
 
hashCode() - Method in class io.prestosql.sql.analyzer.FieldId
 
hashCode() - Method in class io.prestosql.sql.analyzer.Output
 
hashCode() - Method in class io.prestosql.sql.analyzer.RelationId
 
hashCode() - Method in class io.prestosql.sql.DynamicFilters.Descriptor
 
hashCode() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
hashCode() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
hashCode() - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
hashCode() - Method in class io.prestosql.sql.planner.OrderingScheme
 
hashCode() - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
hashCode() - Method in class io.prestosql.sql.planner.Partitioning
 
hashCode() - Method in class io.prestosql.sql.planner.PartitioningHandle
 
hashCode() - Method in class io.prestosql.sql.planner.PartitioningScheme
 
hashCode() - Method in class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
hashCode() - Method in class io.prestosql.sql.planner.plan.Assignments
 
hashCode() - Method in class io.prestosql.sql.planner.plan.DynamicFilterId
 
hashCode() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode.EquiJoinClause
 
hashCode() - Method in class io.prestosql.sql.planner.plan.JoinNode.EquiJoinClause
 
hashCode() - Method in class io.prestosql.sql.planner.plan.PlanFragmentId
 
hashCode() - Method in class io.prestosql.sql.planner.plan.PlanNodeId
 
hashCode() - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
hashCode() - Method in class io.prestosql.sql.planner.plan.WindowNode.Frame
 
hashCode() - Method in class io.prestosql.sql.planner.plan.WindowNode.Function
 
hashCode() - Method in class io.prestosql.sql.planner.plan.WindowNode.Specification
 
hashCode() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint
 
hashCode() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.EstimatedStatsAndCost
 
hashCode() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedDomain
 
hashCode() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedMarker
 
hashCode() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedRange
 
hashCode() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan
 
hashCode() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan.TableColumnInfo
 
hashCode() - Method in class io.prestosql.sql.planner.ScopeAware
 
hashCode() - Method in class io.prestosql.sql.planner.SortExpressionContext
 
hashCode() - Method in class io.prestosql.sql.planner.Symbol
 
hashCode() - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
hashCode() - Method in class io.prestosql.sql.relational.CallExpression
 
hashCode() - Method in class io.prestosql.sql.relational.ConstantExpression
 
hashCode() - Method in class io.prestosql.sql.relational.InputReferenceExpression
 
hashCode() - Method in class io.prestosql.sql.relational.LambdaDefinitionExpression
 
hashCode() - Method in class io.prestosql.sql.relational.RowExpression
 
hashCode() - Method in class io.prestosql.sql.relational.SpecialForm
 
hashCode() - Method in class io.prestosql.sql.relational.VariableReferenceExpression
 
hashCode() - Method in class io.prestosql.sql.SqlPath
 
hashCode() - Method in class io.prestosql.sql.SqlPathElement
 
hashCode() - Method in class io.prestosql.testing.MaterializedResult
 
hashCode() - Method in class io.prestosql.testing.MaterializedRow
 
hashCode() - Method in class io.prestosql.testing.TestingAccessControlManager.TestingPrivilege
 
hashCode() - Method in class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
hashCode() - Method in class io.prestosql.testing.TestingTransactionHandle
 
hashCode() - Method in class io.prestosql.transaction.TransactionId
 
hashCode() - Method in class io.prestosql.type.ColorType
 
hashCode() - Method in class io.prestosql.type.IntervalDayTimeType
 
hashCode() - Method in class io.prestosql.type.IntervalYearMonthType
 
hashCode() - Method in class io.prestosql.type.SqlIntervalDayTime
 
hashCode() - Method in class io.prestosql.type.SqlIntervalYearMonth
 
hashCode(long, long) - Method in interface io.prestosql.util.LongLong2LongOpenCustomBigHashMap.HashStrategy
Returns the hash code of the specified element with respect to this hash strategy.
hashCode(Block, int) - Method in interface io.prestosql.type.BlockTypeOperators.BlockPositionHashCode
 
hashCodeNullSafe(Block, int) - Method in interface io.prestosql.type.BlockTypeOperators.BlockPositionHashCode
 
HashCollisionPlanNodeStats - Class in io.prestosql.sql.planner.planprinter
 
HashCollisionPlanNodeStats(PlanNodeId, Duration, Duration, long, DataSize, long, DataSize, Map<String, OperatorInputStats>, Map<String, OperatorHashCollisionsStats>) - Constructor for class io.prestosql.sql.planner.planprinter.HashCollisionPlanNodeStats
 
HashCollisionsCounter - Class in io.prestosql.operator
 
HashCollisionsCounter(OperatorContext) - Constructor for class io.prestosql.operator.HashCollisionsCounter
 
HashCollisionsEstimator - Class in io.prestosql.util
Estimates number of collisions when inserting values into hash table.
HashCollisionsInfo - Class in io.prestosql.operator
 
HashCollisionsInfo(double, double, double) - Constructor for class io.prestosql.operator.HashCollisionsInfo
 
hashCounts(Slice) - Static method in class io.prestosql.type.setdigest.SetDigestFunctions
 
hashCounts(Type, Slice) - Static method in class io.prestosql.type.setdigest.SetDigestFunctions
 
HashGenerationOptimizer - Class in io.prestosql.sql.planner.optimizations
 
HashGenerationOptimizer(Metadata) - Constructor for class io.prestosql.sql.planner.optimizations.HashGenerationOptimizer
 
HashGenerator - Interface in io.prestosql.operator
 
hashPosition(int, int) - Method in interface io.prestosql.operator.PagesHashStrategy
Calculates the hash code the hashed columns in this PagesHashStrategy at the specified position.
hashPosition(int, int) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
hashPosition(int, Page) - Method in interface io.prestosql.operator.HashGenerator
 
hashPosition(int, Page) - Method in class io.prestosql.operator.InterpretedHashGenerator
 
hashPosition(int, Page) - Method in class io.prestosql.operator.PrecomputedHashGenerator
 
hashPosition(int, IntFunction<Block>) - Method in class io.prestosql.operator.InterpretedHashGenerator
 
hashRow(int, Page) - Method in interface io.prestosql.operator.PagesHashStrategy
Calculates the hash code at position in page.
hashRow(int, Page) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
HashSemiJoinOperator - Class in io.prestosql.operator
 
HashUtil - Class in io.prestosql.operator.aggregation.histogram
 
hasLocation(int, int) - Method in class io.prestosql.testing.assertions.PrestoExceptionAssert
 
hasMultipleSources(PlanNode...) - Static method in class io.prestosql.sql.planner.FragmentTableScanCounter
 
hasNext() - Method in class io.prestosql.execution.scheduler.ResettableRandomizedIterator
 
hasNext() - Method in class io.prestosql.operator.window.WindowPartition
 
hasNonEmptyGroupingSet() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
hasOrderBy() - Method in interface io.prestosql.operator.aggregation.AccumulatorFactory
 
hasOrderBy() - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
hasOrderings() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
hasOuterParent(Scope) - Method in class io.prestosql.sql.analyzer.Scope
 
hasRemoveInput() - Method in interface io.prestosql.operator.aggregation.AccumulatorFactory
 
hasRemoveInput() - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
hasRowFilter(QualifiedObjectName, String) - Method in class io.prestosql.sql.analyzer.Analysis
 
hasSchemaName() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
hasSingleNodeExecutionPreference(Metadata) - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
hasSpecializedTypeParameters() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
hasSpecializedTypeParameters() - Method in interface io.prestosql.operator.ParametricImplementation
 
hasSpecializedTypeParameters() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation
 
hasSpilled() - Method in interface io.prestosql.operator.LookupSourceProvider.LookupSourceLease
 
hasTableInView(Table) - Method in class io.prestosql.sql.analyzer.Analysis
 
hasTableName() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
hasTasks() - Method in class io.prestosql.execution.SqlStageExecution
 
hasUnknownComponents() - Method in class io.prestosql.cost.PlanCostEstimate
Returns true if this cost has unknown components.
HeapTraversal - Class in io.prestosql.util
If heap nodes are numbered top down, and left to right as follows:
HeapTraversal() - Constructor for class io.prestosql.util.HeapTraversal
 
HeapTraversal.Child - Enum in io.prestosql.util
 
HeartbeatFailureDetector - Class in io.prestosql.failuredetector
 
HeartbeatFailureDetector(ServiceSelector, HttpClient, FailureDetectorConfig, NodeInfo, InternalCommunicationConfig) - Constructor for class io.prestosql.failuredetector.HeartbeatFailureDetector
 
HeartbeatFailureDetector.Stats - Class in io.prestosql.failuredetector
 
hidden(boolean) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
hiddenColumn(String, Type) - Method in class io.prestosql.metadata.MetadataUtil.TableMetadataBuilder
 
Histogram - Class in io.prestosql.operator.aggregation.histogram
 
Histogram(BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.histogram.Histogram
 
HISTOGRAM_BUCKETS - Static variable in class io.prestosql.operator.JoinStatisticsCounter
 
HistogramState - Interface in io.prestosql.operator.aggregation.histogram
 
HistogramStateFactory - Class in io.prestosql.operator.aggregation.histogram
 
HistogramStateFactory(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, int) - Constructor for class io.prestosql.operator.aggregation.histogram.HistogramStateFactory
 
HistogramStateSerializer - Class in io.prestosql.operator.aggregation.histogram
 
HistogramStateSerializer(Type) - Constructor for class io.prestosql.operator.aggregation.histogram.HistogramStateSerializer
 
HistogramValueReader - Interface in io.prestosql.operator.aggregation.histogram
 
HmacFunctions - Class in io.prestosql.operator.scalar
 
hmacMd5(Slice, Slice) - Static method in class io.prestosql.operator.scalar.HmacFunctions
 
hmacSha1(Slice, Slice) - Static method in class io.prestosql.operator.scalar.HmacFunctions
 
hmacSha256(Slice, Slice) - Static method in class io.prestosql.operator.scalar.HmacFunctions
 
hmacSha512(Slice, Slice) - Static method in class io.prestosql.operator.scalar.HmacFunctions
 
HOSTBASED_SERVICE - io.prestosql.server.security.KerberosNameType
 
hour(long) - Static method in class io.prestosql.operator.scalar.time.TimeFunctions
 
hourFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
HOURS_PER_DAY - Static variable in class io.prestosql.type.DateTimes
 
HTTP_SERVER_AUTHENTICATION_KRB5_KEYTAB - Static variable in class io.prestosql.server.security.KerberosConfig
 
HttpLocationFactory - Class in io.prestosql.server.remotetask
 
HttpLocationFactory(InternalNodeManager, HttpServerInfo, InternalCommunicationConfig) - Constructor for class io.prestosql.server.remotetask.HttpLocationFactory
 
HttpLocationFactory(InternalNodeManager, URI) - Constructor for class io.prestosql.server.remotetask.HttpLocationFactory
 
HttpPageBufferClient - Class in io.prestosql.operator
 
HttpPageBufferClient(String, HttpClient, FeaturesConfig.DataIntegrityVerification, DataSize, Duration, boolean, URI, HttpPageBufferClient.ClientCallback, ScheduledExecutorService, Ticker, Executor) - Constructor for class io.prestosql.operator.HttpPageBufferClient
 
HttpPageBufferClient(String, HttpClient, FeaturesConfig.DataIntegrityVerification, DataSize, Duration, boolean, URI, HttpPageBufferClient.ClientCallback, ScheduledExecutorService, Executor) - Constructor for class io.prestosql.operator.HttpPageBufferClient
 
HttpPageBufferClient.ClientCallback - Interface in io.prestosql.operator
For each request, the addPage method will be called zero or more times, followed by either requestComplete or clientFinished (if buffer complete).
HttpPageBufferClient.PageResponseHandler - Class in io.prestosql.operator
 
HttpPageBufferClient.PagesResponse - Class in io.prestosql.operator
 
HttpRemoteTask - Class in io.prestosql.server.remotetask
 
HttpRemoteTask(Session, TaskId, String, URI, PlanFragment, Multimap<PlanNodeId, Split>, OptionalInt, OutputBuffers, HttpClient, Executor, ScheduledExecutorService, ScheduledExecutorService, Duration, Duration, Duration, boolean, JsonCodec<TaskStatus>, JsonCodec<DynamicFiltersCollector.VersionedDynamicFilterDomains>, JsonCodec<TaskInfo>, JsonCodec<TaskUpdateRequest>, NodeTaskMap.PartitionedSplitCountTracker, RemoteTaskStats, DynamicFilterService) - Constructor for class io.prestosql.server.remotetask.HttpRemoteTask
 
HttpRemoteTaskFactory - Class in io.prestosql.server
 
HttpRemoteTaskFactory(QueryManagerConfig, TaskManagerConfig, HttpClient, LocationFactory, JsonCodec<TaskStatus>, JsonCodec<DynamicFiltersCollector.VersionedDynamicFilterDomains>, JsonCodec<TaskInfo>, JsonCodec<TaskUpdateRequest>, RemoteTaskStats, DynamicFilterService) - Constructor for class io.prestosql.server.HttpRemoteTaskFactory
 
HttpRequestSessionContext - Class in io.prestosql.server
 
HttpRequestSessionContext(MultivaluedMap<String, String>, String, Optional<Identity>, GroupProvider) - Constructor for class io.prestosql.server.HttpRequestSessionContext
 
humanReadableSeconds(double) - Static method in class io.prestosql.operator.scalar.timestamp.HumanReadableSeconds
 
HumanReadableSeconds - Class in io.prestosql.operator.scalar.timestamp
 
HyperLogLogFunctions - Class in io.prestosql.operator.scalar
 
HyperLogLogOperators - Class in io.prestosql.type
 
HyperLogLogState - Interface in io.prestosql.operator.aggregation.state
 
HyperLogLogStateFactory - Class in io.prestosql.operator.aggregation.state
 
HyperLogLogStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory
 
HyperLogLogStateFactory.GroupedHyperLogLogState - Class in io.prestosql.operator.aggregation.state
 
HyperLogLogStateFactory.SingleHyperLogLogState - Class in io.prestosql.operator.aggregation.state
 
HyperLogLogStateSerializer - Class in io.prestosql.operator.aggregation.state
 
HyperLogLogStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.HyperLogLogStateSerializer
 

I

identity(Symbol...) - Static method in class io.prestosql.sql.planner.plan.Assignments
 
identity(Iterable<Symbol>) - Static method in class io.prestosql.sql.planner.plan.Assignments
 
IDENTITY_CAST - Static variable in class io.prestosql.operator.scalar.IdentityCast
 
IdentityCast - Class in io.prestosql.operator.scalar
 
IdentityCast() - Constructor for class io.prestosql.operator.scalar.IdentityCast
 
IdRegistry<T> - Class in io.prestosql.operator
Object registration system that allows looking up objects via stable IDs.
IdRegistry() - Constructor for class io.prestosql.operator.IdRegistry
 
IF - io.prestosql.sql.relational.SpecialForm.Form
 
IfCodeGenerator - Class in io.prestosql.sql.gen
 
IfCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.IfCodeGenerator
 
ifWasNullClearPopAndGoto(Scope, LabelNode, Class<?>, Class<?>...) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
ifWasNullPopAndGoto(Scope, LabelNode, Class<?>, Class<?>...) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
ifWasNullPopAndGoto(Scope, LabelNode, Class<?>, Iterable<? extends Class<?>>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
IGNORE_DOWNSTREAM_PREFERENCES - Static variable in class io.prestosql.SystemSessionProperties
 
IGNORE_STATS_CALCULATOR_FAILURES - Static variable in class io.prestosql.SystemSessionProperties
 
ignoreDownStreamPreferences(Session) - Static method in class io.prestosql.SystemSessionProperties
 
ignoredZone() - Static method in class io.prestosql.util.GenerateTimeZoneIndex
 
immediateFailureQueryStats() - Static method in class io.prestosql.server.BasicQueryStats
 
IMPERSONATE_USER - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
implementation(Function<PolymorphicScalarFunctionBuilder.MethodsGroupBuilder, PolymorphicScalarFunctionBuilder.MethodsGroupBuilder>) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.ChoiceBuilder
 
ImplementationDependency - Interface in io.prestosql.operator.annotations
 
ImplementationDependency.Factory - Class in io.prestosql.operator.annotations
 
ImplementBernoulliSampleAsFilter - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
ImplementBernoulliSampleAsFilter(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.ImplementBernoulliSampleAsFilter
 
ImplementExceptAll - Class in io.prestosql.sql.planner.iterative.rule
Implement EXCEPT ALL using union, window and filter.
ImplementExceptAll(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.ImplementExceptAll
 
ImplementExceptDistinctAsUnion - Class in io.prestosql.sql.planner.iterative.rule
Converts EXCEPT DISTINCT queries into UNION ALL..GROUP BY...WHERE E.g.:
ImplementExceptDistinctAsUnion(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.ImplementExceptDistinctAsUnion
 
ImplementFilteredAggregations - Class in io.prestosql.sql.planner.iterative.rule
Implements filtered aggregations by transforming plans of the following shape:
ImplementFilteredAggregations(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.ImplementFilteredAggregations
 
ImplementIntersectAll - Class in io.prestosql.sql.planner.iterative.rule
Implement INTERSECT ALL using union, window and filter.
ImplementIntersectAll(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.ImplementIntersectAll
 
ImplementIntersectDistinctAsUnion - Class in io.prestosql.sql.planner.iterative.rule
Converts INTERSECT DISTINCT queries into UNION ALL..GROUP BY...WHERE E.g.:
ImplementIntersectDistinctAsUnion(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.ImplementIntersectDistinctAsUnion
 
ImplementLimitWithTies - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
ImplementLimitWithTies(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.ImplementLimitWithTies
 
ImplementOffset - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
ImplementOffset() - Constructor for class io.prestosql.sql.planner.iterative.rule.ImplementOffset
 
IMPLICIT_COERCION - io.prestosql.metadata.SignatureBinder.RelationshipType
 
in(boolean, BooleanOpenHashSet) - Static method in class io.prestosql.util.FastutilSetHelper
 
in(double, DoubleOpenCustomHashSet) - Static method in class io.prestosql.util.FastutilSetHelper
 
in(long, LongOpenCustomHashSet) - Static method in class io.prestosql.util.FastutilSetHelper
 
in(Object, ObjectOpenCustomHashSet<?>) - Static method in class io.prestosql.util.FastutilSetHelper
 
in(Object, Set<?>) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
IN - io.prestosql.sql.relational.SpecialForm.Form
 
INACTIVE - io.prestosql.metadata.NodeState
 
InCodeGenerator - Class in io.prestosql.sql.gen
 
InCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.InCodeGenerator
 
incrementProbeFactoryCount() - Method in class io.prestosql.operator.JoinBridgeManager
 
IndexBuildDriverFactoryProvider - Class in io.prestosql.operator.index
 
IndexBuildDriverFactoryProvider(int, int, PlanNodeId, boolean, List<Type>, List<OperatorFactory>, Optional<DynamicTupleFilterFactory>) - Constructor for class io.prestosql.operator.index.IndexBuildDriverFactoryProvider
 
IndexedData - Interface in io.prestosql.operator.index
 
IndexedPriorityQueue<E> - Class in io.prestosql.execution.resourcegroups
A priority queue with constant time contains(E) and log time remove(E) Ties are broken by insertion order
IndexedPriorityQueue() - Constructor for class io.prestosql.execution.resourcegroups.IndexedPriorityQueue
 
IndexHandle - Class in io.prestosql.metadata
 
IndexHandle(CatalogName, ConnectorTransactionHandle, ConnectorIndexHandle) - Constructor for class io.prestosql.metadata.IndexHandle
 
indexHandleModule(HandleResolver) - Static method in class io.prestosql.metadata.HandleJsonModule
 
IndexInfo(long, long, double, long) - Constructor for class io.prestosql.operator.WindowInfo.IndexInfo
 
indexJoin() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
IndexJoinLookupStats - Class in io.prestosql.operator.index
 
IndexJoinLookupStats() - Constructor for class io.prestosql.operator.index.IndexJoinLookupStats
 
IndexJoinNode - Class in io.prestosql.sql.planner.plan
 
IndexJoinNode(PlanNodeId, IndexJoinNode.Type, PlanNode, PlanNode, List<IndexJoinNode.EquiJoinClause>, Optional<Symbol>, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.IndexJoinNode
 
IndexJoinNode.EquiJoinClause - Class in io.prestosql.sql.planner.plan
 
IndexJoinNode.Type - Enum in io.prestosql.sql.planner.plan
 
IndexJoinOptimizer - Class in io.prestosql.sql.planner.optimizations
 
IndexJoinOptimizer(Metadata, TypeOperators) - Constructor for class io.prestosql.sql.planner.optimizations.IndexJoinOptimizer
 
IndexJoinOptimizer.IndexKeyTracer - Class in io.prestosql.sql.planner.optimizations
Identify the mapping from the lookup symbols used at the top of the index plan to the actual symbols produced by the IndexSource.
IndexKeyTracer() - Constructor for class io.prestosql.sql.planner.optimizations.IndexJoinOptimizer.IndexKeyTracer
 
IndexLoader - Class in io.prestosql.operator.index
 
IndexLoader(Set<Integer>, List<Integer>, OptionalInt, List<Type>, IndexBuildDriverFactoryProvider, int, DataSize, IndexJoinLookupStats, PagesIndex.Factory, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.index.IndexLoader
 
IndexLookupSource - Class in io.prestosql.operator.index
 
IndexLookupSource(IndexLoader) - Constructor for class io.prestosql.operator.index.IndexLookupSource
 
IndexLookupSourceFactory - Class in io.prestosql.operator.index
 
IndexLookupSourceFactory(Set<Integer>, List<Integer>, OptionalInt, List<Type>, IndexBuildDriverFactoryProvider, DataSize, IndexJoinLookupStats, boolean, PagesIndex.Factory, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.index.IndexLookupSourceFactory
 
IndexManager - Class in io.prestosql.index
 
IndexManager() - Constructor for class io.prestosql.index.IndexManager
 
indexOf(Field) - Method in class io.prestosql.sql.analyzer.RelationType
Gets the index of the specified field.
indexPage(Page) - Method in class io.prestosql.GroupByHashPageIndexer
 
IndexSnapshot - Class in io.prestosql.operator.index
 
IndexSnapshot(LookupSource, LookupSource) - Constructor for class io.prestosql.operator.index.IndexSnapshot
 
IndexSnapshotBuilder - Class in io.prestosql.operator.index
 
IndexSnapshotBuilder(List<Type>, List<Integer>, OptionalInt, DriverContext, DataSize, int, PagesIndex.Factory) - Constructor for class io.prestosql.operator.index.IndexSnapshotBuilder
 
indexSource() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
IndexSourceNode - Class in io.prestosql.sql.planner.plan
 
IndexSourceNode(PlanNodeId, IndexHandle, TableHandle, Set<Symbol>, List<Symbol>, Map<Symbol, ColumnHandle>) - Constructor for class io.prestosql.sql.planner.plan.IndexSourceNode
 
IndexSourceOperator - Class in io.prestosql.operator.index
 
IndexSourceOperator(OperatorContext, PlanNodeId, ConnectorIndex, Function<RecordSet, RecordSet>) - Constructor for class io.prestosql.operator.index.IndexSourceOperator
 
IndexSourceOperator.IndexSourceOperatorFactory - Class in io.prestosql.operator.index
 
IndexSourceOperatorFactory(int, PlanNodeId, ConnectorIndex, Function<RecordSet, RecordSet>) - Constructor for class io.prestosql.operator.index.IndexSourceOperator.IndexSourceOperatorFactory
 
IndexSplit - Class in io.prestosql.operator.index
 
IndexSplit(RecordSet) - Constructor for class io.prestosql.operator.index.IndexSplit
 
infinite() - Static method in class io.prestosql.cost.PlanCostEstimate
 
infinity() - Static method in class io.prestosql.operator.scalar.MathFunctions
 
Info(long, String, String, Long, List<ThreadResource.StackLine>) - Constructor for class io.prestosql.server.ThreadResource.Info
 
INFORMATION_SCHEMA - Static variable in enum io.prestosql.connector.informationschema.InformationSchemaTable
 
InformationSchemaColumnHandle - Class in io.prestosql.connector.informationschema
 
InformationSchemaColumnHandle(String) - Constructor for class io.prestosql.connector.informationschema.InformationSchemaColumnHandle
 
InformationSchemaConnector - Class in io.prestosql.connector.informationschema
 
InformationSchemaConnector(String, InternalNodeManager, Metadata, AccessControl) - Constructor for class io.prestosql.connector.informationschema.InformationSchemaConnector
 
InformationSchemaHandleResolver - Class in io.prestosql.connector.informationschema
 
InformationSchemaHandleResolver() - Constructor for class io.prestosql.connector.informationschema.InformationSchemaHandleResolver
 
InformationSchemaMetadata - Class in io.prestosql.connector.informationschema
 
InformationSchemaMetadata(String, Metadata) - Constructor for class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
InformationSchemaPageSource - Class in io.prestosql.connector.informationschema
 
InformationSchemaPageSource(Session, Metadata, AccessControl, InformationSchemaTableHandle, List<ColumnHandle>) - Constructor for class io.prestosql.connector.informationschema.InformationSchemaPageSource
 
InformationSchemaPageSourceProvider - Class in io.prestosql.connector.informationschema
 
InformationSchemaPageSourceProvider(Metadata, AccessControl) - Constructor for class io.prestosql.connector.informationschema.InformationSchemaPageSourceProvider
 
InformationSchemaSplit - Class in io.prestosql.connector.informationschema
 
InformationSchemaSplit(List<HostAddress>) - Constructor for class io.prestosql.connector.informationschema.InformationSchemaSplit
 
InformationSchemaSplitManager - Class in io.prestosql.connector.informationschema
 
InformationSchemaSplitManager(InternalNodeManager) - Constructor for class io.prestosql.connector.informationschema.InformationSchemaSplitManager
 
InformationSchemaTable - Enum in io.prestosql.connector.informationschema
 
InformationSchemaTableHandle - Class in io.prestosql.connector.informationschema
 
InformationSchemaTableHandle(String, InformationSchemaTable, Set<QualifiedTablePrefix>, Optional<Set<String>>, Optional<Set<String>>, OptionalLong) - Constructor for class io.prestosql.connector.informationschema.InformationSchemaTableHandle
 
InformationSchemaTransactionHandle - Class in io.prestosql.connector.informationschema
 
InformationSchemaTransactionHandle(TransactionId) - Constructor for class io.prestosql.connector.informationschema.InformationSchemaTransactionHandle
 
infoRoundTripMillis(long) - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
INITIAL_CAPACITY - Static variable in class io.prestosql.util.LongBigArrayFIFOQueue
The standard initial capacity of a queue.
INITIAL_DYNAMIC_FILTER_DOMAINS - Static variable in class io.prestosql.execution.DynamicFiltersCollector
 
INITIAL_DYNAMIC_FILTERS_VERSION - Static variable in class io.prestosql.execution.DynamicFiltersCollector
 
INITIAL_HASH_VALUE - Static variable in class io.prestosql.sql.planner.optimizations.HashGenerationOptimizer
 
INITIAL_SPLITS_PER_NODE - Static variable in class io.prestosql.SystemSessionProperties
 
InitialBooleanValue - Annotation Type in io.prestosql.operator.aggregation.state
 
InitialDoubleValue - Annotation Type in io.prestosql.operator.aggregation.state
 
initialize() - Method in class io.prestosql.sql.planner.PlanOptimizers
 
initialize(PowerOfTwo) - Method in class io.prestosql.util.PowerOfTwoValidator
 
InitialLongValue - Annotation Type in io.prestosql.operator.aggregation.state
 
initialTaskStatus(TaskId, URI, String) - Static method in class io.prestosql.execution.TaskStatus
 
InjectedConnectorAccessControl - Class in io.prestosql.security
 
InjectedConnectorAccessControl(AccessControl, SecurityContext, String) - Constructor for class io.prestosql.security.InjectedConnectorAccessControl
 
InlineProjections - Class in io.prestosql.sql.planner.iterative.rule
Inlines expressions from a child project node into a parent project node as long as they are simple constants, or they are referenced only once (to avoid introducing duplicate computation) and the references don't appear within a TRY block (to avoid changing semantics).
InlineProjections() - Constructor for class io.prestosql.sql.planner.iterative.rule.InlineProjections
 
inlineSymbols(Function<Symbol, Expression>, Expression) - Static method in class io.prestosql.sql.planner.ExpressionSymbolInliner
 
inlineSymbols(Map<Symbol, ? extends Expression>, Expression) - Static method in class io.prestosql.sql.planner.ExpressionSymbolInliner
 
InMemoryHashAggregationBuilder - Class in io.prestosql.operator.aggregation.builder
 
InMemoryHashAggregationBuilder(List<AccumulatorFactory>, AggregationNode.Step, int, List<Type>, List<Integer>, Optional<Integer>, OperatorContext, Optional<DataSize>, JoinCompiler, BlockTypeOperators, UpdateMemory) - Constructor for class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
InMemoryHashAggregationBuilder(List<AccumulatorFactory>, AggregationNode.Step, int, List<Type>, List<Integer>, Optional<Integer>, OperatorContext, Optional<DataSize>, Optional<Integer>, JoinCompiler, BlockTypeOperators, UpdateMemory) - Constructor for class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
InMemoryNodeManager - Class in io.prestosql.metadata
 
InMemoryNodeManager() - Constructor for class io.prestosql.metadata.InMemoryNodeManager
 
InMemoryNodeManager(URI) - Constructor for class io.prestosql.metadata.InMemoryNodeManager
 
InMemoryTransactionManager - Class in io.prestosql.transaction
 
INNER - io.prestosql.operator.LookupJoinOperators.JoinType
 
INNER - io.prestosql.sql.planner.plan.CorrelatedJoinNode.Type
 
INNER - io.prestosql.sql.planner.plan.IndexJoinNode.Type
 
INNER - io.prestosql.sql.planner.plan.JoinNode.Type
 
INNER - io.prestosql.sql.planner.plan.SpatialJoinNode.Type
 
innerJoin(int, PlanNodeId, JoinBridgeManager<? extends LookupSourceFactory>, List<Type>, List<Integer>, OptionalInt, Optional<List<Integer>>, OptionalInt, PartitioningSpillerFactory, BlockTypeOperators) - Method in class io.prestosql.operator.LookupJoinOperators
 
input(BigintApproximateMostFrequent.State, long, long, long) - Static method in class io.prestosql.operator.aggregation.BigintApproximateMostFrequent
 
input(MultimapAggregationState, Block, Block, int) - Static method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
input(BooleanDistinctState, boolean) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
input(BooleanDistinctState, boolean, double) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
input(CorrelationState, double, double) - Static method in class io.prestosql.operator.aggregation.DoubleCorrelationAggregation
 
input(CorrelationState, long, long) - Static method in class io.prestosql.operator.aggregation.RealCorrelationAggregation
 
input(CovarianceState, double, double) - Static method in class io.prestosql.operator.aggregation.DoubleCovarianceAggregation
 
input(CovarianceState, long, long) - Static method in class io.prestosql.operator.aggregation.RealCovarianceAggregation
 
input(HyperLogLogState, double) - Static method in class io.prestosql.operator.aggregation.ApproximateSetAggregation
 
input(HyperLogLogState, long) - Static method in class io.prestosql.operator.aggregation.ApproximateSetAggregation
 
input(HyperLogLogState, Slice) - Static method in class io.prestosql.operator.aggregation.ApproximateSetAggregation
 
input(HyperLogLogState, Slice) - Static method in class io.prestosql.operator.aggregation.MergeHyperLogLogAggregation
 
input(HyperLogLogState, Block, int) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
input(HyperLogLogState, Block, int, double) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
input(LongAndDoubleState, double) - Static method in class io.prestosql.operator.aggregation.AverageAggregations
 
input(LongAndDoubleState, double) - Static method in class io.prestosql.operator.aggregation.GeometricMeanAggregations
 
input(LongAndDoubleState, long) - Static method in class io.prestosql.operator.aggregation.AverageAggregations
 
input(LongAndDoubleState, long) - Static method in class io.prestosql.operator.aggregation.GeometricMeanAggregations
 
input(LongAndDoubleState, long) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondAverageAggregation
 
input(LongAndDoubleState, long) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthAverageAggregation
 
input(LongAndDoubleState, long) - Static method in class io.prestosql.operator.aggregation.RealGeometricMeanAggregations
 
input(LongState) - Static method in class io.prestosql.operator.aggregation.CountAggregation
 
input(LongState, boolean) - Static method in class io.prestosql.operator.aggregation.CountIfAggregation
 
input(LongState, DoubleState, long) - Static method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
input(LongState, Block, int) - Static method in class io.prestosql.operator.aggregation.CountColumn
 
input(NullableBooleanState, Object, boolean, BinaryFunctionInterface, BinaryFunctionInterface) - Static method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
input(NullableDoubleState, Object, double, BinaryFunctionInterface, BinaryFunctionInterface) - Static method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
input(NullableLongState, Block, int) - Static method in class io.prestosql.operator.aggregation.MaxDataSizeForStats
 
input(NullableLongState, Block, int) - Static method in class io.prestosql.operator.aggregation.SumDataSizeForStats
 
input(NullableLongState, Object, long, BinaryFunctionInterface, BinaryFunctionInterface) - Static method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
input(RegressionState, double, double) - Static method in class io.prestosql.operator.aggregation.DoubleRegressionAggregation
 
input(RegressionState, long, long) - Static method in class io.prestosql.operator.aggregation.RealRegressionAggregation
 
input(TDigestAndPercentileArrayState, double, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileArrayAggregations
 
input(TDigestAndPercentileArrayState, long, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileArrayAggregations
 
input(TDigestAndPercentileArrayState, long, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileArrayAggregations
 
input(TDigestAndPercentileState, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
input(TDigestAndPercentileState, long, double) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
input(TDigestAndPercentileState, long, double) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
input(TDigestState, double) - Static method in class io.prestosql.operator.aggregation.TDigestAggregationFunction
 
input(TDigestState, Object) - Static method in class io.prestosql.operator.aggregation.MergeTDigestAggregation
 
input(VarcharApproximateMostFrequent.State, long, Slice, long) - Static method in class io.prestosql.operator.aggregation.VarcharApproximateMostFrequent
 
input(Type, ArrayAggregationState, Block, int) - Static method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
input(Type, HistogramState, Block, int) - Static method in class io.prestosql.operator.aggregation.histogram.Histogram
 
input(Type, BlockPositionState, Block, int) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
input(Type, NullableBooleanState, Block, int) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
input(Type, NullableDoubleState, Block, int) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
input(Type, NullableLongState, Block, int) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
input(Type, QuantileDigestState, Block, int) - Static method in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
input(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, Type, KeyValuePairsState, Block) - Static method in class io.prestosql.operator.aggregation.MapUnionAggregation
 
input(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, Type, KeyValuePairsState, Block, Block, int) - Static method in class io.prestosql.operator.aggregation.MapAggregationFunction
 
input(BlockTypeOperators.BlockPositionComparison, Type, MinMaxNState, Block, long, int) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
input(BlockTypeOperators.BlockPositionComparison, Type, Type, MinMaxByNState, Block, Block, int, long) - Static method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
input(BlockTypeOperators.BlockPositionXxHash64, NullableLongState, Block, int) - Static method in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
input(SetDigestState, long) - Static method in class io.prestosql.type.setdigest.BuildSetDigestAggregation
 
input(SetDigestState, Slice) - Static method in class io.prestosql.type.setdigest.MergeSetDigestAggregation
 
input(MethodHandle, BlockPositionState, Block, int) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
input(MethodHandle, HyperLogLogState, double) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, long) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, long, double) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, Object) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, Object, double) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
input(MethodHandle, NullableBooleanState, boolean) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
input(MethodHandle, NullableDoubleState, double) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
input(MethodHandle, NullableLongState, long) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
Input - Class in io.prestosql.execution
 
Input(String, String, String, Optional<Object>, List<Column>, PlanFragmentId, PlanNodeId) - Constructor for class io.prestosql.execution.Input
 
INPUT_CHANNEL - io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata.ParameterType
 
INPUT_SPILLED - io.prestosql.operator.HashBuilderOperator.State
Input has been finished and spilled
INPUT_UNSPILLED_AND_BUILT - io.prestosql.operator.HashBuilderOperator.State
Spilled input has been unspilled, LookupSource built from it
INPUT_UNSPILLING - io.prestosql.operator.HashBuilderOperator.State
Spilled input is being unspilled
inputBigint(QuantileDigestState, long, long, double) - Static method in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
InputChannels - Class in io.prestosql.operator.project
 
InputChannels(int...) - Constructor for class io.prestosql.operator.project.InputChannels
 
InputChannels(List<Integer>) - Constructor for class io.prestosql.operator.project.InputChannels
 
inputDouble(QuantileDigestState, double, long, double) - Static method in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
InputExtractor - Class in io.prestosql.sql.planner
 
InputExtractor(Metadata, Session) - Constructor for class io.prestosql.sql.planner.InputExtractor
 
inputLongDecimal(Type, LongDecimalWithOverflowAndLongState, Block, int) - Static method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
inputLongDecimal(Type, LongDecimalWithOverflowState, Block, int) - Static method in class io.prestosql.operator.aggregation.DecimalSumAggregation
 
InputPageProjection - Class in io.prestosql.operator.project
 
InputPageProjection(int, Type) - Constructor for class io.prestosql.operator.project.InputPageProjection
 
inputReal(QuantileDigestState, long, long, double) - Static method in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
InputReferenceExpression - Class in io.prestosql.sql.relational
 
InputReferenceExpression(int, Type) - Constructor for class io.prestosql.sql.relational.InputReferenceExpression
 
inputShortDecimal(Type, LongDecimalWithOverflowAndLongState, Block, int) - Static method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
inputShortDecimal(Type, LongDecimalWithOverflowState, Block, int) - Static method in class io.prestosql.operator.aggregation.DecimalSumAggregation
 
InsecureAuthenticator - Class in io.prestosql.server.security
 
InsecureAuthenticator(InsecureAuthenticatorConfig) - Constructor for class io.prestosql.server.security.InsecureAuthenticator
 
InsecureAuthenticatorConfig - Class in io.prestosql.server.security
 
InsecureAuthenticatorConfig() - Constructor for class io.prestosql.server.security.InsecureAuthenticatorConfig
 
InsecureFormAuthenticator - Class in io.prestosql.server.ui
 
InsecureFormAuthenticator(SecurityConfig) - Constructor for class io.prestosql.server.ui.InsecureFormAuthenticator
 
Insert(TableHandle, List<ColumnHandle>, Optional<NewTableLayout>) - Constructor for class io.prestosql.sql.analyzer.Analysis.Insert
 
INSERT_TABLE - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
InsertReference(TableHandle, List<ColumnHandle>) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.InsertReference
 
InsertTableHandle - Class in io.prestosql.metadata
 
InsertTableHandle(CatalogName, ConnectorTransactionHandle, ConnectorInsertTableHandle) - Constructor for class io.prestosql.metadata.InsertTableHandle
 
insertTableHandleModule(HandleResolver) - Static method in class io.prestosql.metadata.HandleJsonModule
 
InsertTarget(InsertTableHandle, SchemaTableName) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.InsertTarget
 
installPlugin(Plugin) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
installPlugin(Plugin) - Method in class io.prestosql.testing.LocalQueryRunner
 
installPlugin(Plugin) - Method in interface io.prestosql.testing.QueryRunner
 
installPlugin(Plugin, Supplier<ClassLoader>) - Method in class io.prestosql.server.PluginManager
 
INSTANCE - io.prestosql.metadata.RemoteTransactionHandle
 
INSTANCE - io.prestosql.testing.TestingHandle
 
INSTANCE - Static variable in class io.prestosql.sql.planner.NoOpSymbolResolver
 
INSTANCE_SIZE - Static variable in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.SingleQuantileDigestAndPercentileState
 
INSTANCE_SIZE - Static variable in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.SingleTDigestAndPercentileArrayState
 
INSTANCE_SIZE - Static variable in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.SingleTDigestAndPercentileState
 
INTEGER_TO_DECIMAL_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
INTEGER_TO_DECIMAL_SATURATED_FLOOR_CAST - Static variable in class io.prestosql.type.DecimalSaturatedFloorCasts
 
IntegerOperators - Class in io.prestosql.type
 
integerToLongDecimal(long, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
integerToShortDecimal(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
INTERMEDIATE - io.prestosql.sql.planner.plan.AggregationNode.Step
 
INTERNAL_ONLY - io.prestosql.server.security.ResourceSecurity.AccessType
 
InternalAggregationFunction - Class in io.prestosql.operator.aggregation
 
InternalAggregationFunction(String, List<Type>, List<Type>, Type, AccumulatorFactoryBinder) - Constructor for class io.prestosql.operator.aggregation.InternalAggregationFunction
 
InternalAggregationFunction(String, List<Type>, List<Type>, Type, AccumulatorFactoryBinder, List<Class<?>>) - Constructor for class io.prestosql.operator.aggregation.InternalAggregationFunction
 
InternalAuthenticationManager - Class in io.prestosql.server
 
InternalAuthenticationManager(InternalCommunicationConfig, NodeInfo) - Constructor for class io.prestosql.server.InternalAuthenticationManager
 
InternalAuthenticationManager(String, String) - Constructor for class io.prestosql.server.InternalAuthenticationManager
 
InternalCommunicationConfig - Class in io.prestosql.server
 
InternalCommunicationConfig() - Constructor for class io.prestosql.server.InternalCommunicationConfig
 
InternalCommunicationModule - Class in io.prestosql.server
 
InternalCommunicationModule() - Constructor for class io.prestosql.server.InternalCommunicationModule
 
internalCompilePagesIndexOrdering(List<Type>, List<Integer>, List<SortOrder>) - Method in class io.prestosql.sql.gen.OrderingCompiler
 
InternalConnector - Interface in io.prestosql.transaction
 
internalError(Throwable) - Static method in class io.prestosql.util.Failures
 
internalGenerateCpuQuota(long) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
InternalJoinFilterFunction - Interface in io.prestosql.operator
 
InternalNode - Class in io.prestosql.metadata
A node is a server in a cluster than can process queries.
InternalNode(String, URI, NodeVersion, boolean) - Constructor for class io.prestosql.metadata.InternalNode
 
InternalNodeManager - Interface in io.prestosql.metadata
 
internalOnlyResource(AnnotatedElement) - Method in class io.prestosql.server.security.ResourceSecurityBinder
 
InternalPrincipal - Class in io.prestosql.server.security
 
InternalPrincipal(String) - Constructor for class io.prestosql.server.security.InternalPrincipal
 
InternalResourceGroup - Class in io.prestosql.execution.resourcegroups
Resource groups form a tree, and all access to a group is guarded by the root of the tree.
InternalResourceGroup(String, BiConsumer<InternalResourceGroup, Boolean>, Executor) - Constructor for class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
InternalResourceGroup(Optional<InternalResourceGroup>, String, BiConsumer<InternalResourceGroup, Boolean>, Executor) - Constructor for class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
InternalResourceGroupManager<C> - Class in io.prestosql.execution.resourcegroups
 
InternalResourceGroupManager(LegacyResourceGroupConfigurationManager, ClusterMemoryPoolManager, NodeInfo, MBeanExporter) - Constructor for class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
internalStartNext() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
InternalTable - Class in io.prestosql.metadata
 
InternalTable(Map<String, Integer>, Iterable<Page>) - Constructor for class io.prestosql.metadata.InternalTable
 
InternalTable.Builder - Class in io.prestosql.metadata
 
InternalTypeManager - Class in io.prestosql.type
 
InternalTypeManager(Metadata, TypeOperators) - Constructor for class io.prestosql.type.InternalTypeManager
 
InterpretedFunctionInvoker - Class in io.prestosql.sql
 
InterpretedFunctionInvoker(Metadata) - Constructor for class io.prestosql.sql.InterpretedFunctionInvoker
 
InterpretedHashGenerator - Class in io.prestosql.operator
 
InterpretedHashGenerator(List<Type>, int[], BlockTypeOperators) - Constructor for class io.prestosql.operator.InterpretedHashGenerator
 
InterpretedHashGenerator(List<Type>, List<Integer>, BlockTypeOperators) - Constructor for class io.prestosql.operator.InterpretedHashGenerator
 
intersect() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
intersect(StatisticRange) - Method in class io.prestosql.cost.StatisticRange
 
intersect(Type, BlockTypeOperators.BlockPositionIsDistinctFrom, BlockTypeOperators.BlockPositionHashCode, Block, Block) - Method in class io.prestosql.operator.scalar.ArrayIntersectFunction
 
Intersect() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Intersect
 
intersectionCardinality(Slice, Slice) - Static method in class io.prestosql.type.setdigest.SetDigestFunctions
 
IntersectNode - Class in io.prestosql.sql.planner.plan
 
IntersectNode(PlanNodeId, List<PlanNode>, ListMultimap<Symbol, Symbol>, List<Symbol>, boolean) - Constructor for class io.prestosql.sql.planner.plan.IntersectNode
 
INTERVAL_DAY_TIME - Static variable in class io.prestosql.type.IntervalDayTimeType
 
INTERVAL_YEAR_MONTH - Static variable in class io.prestosql.type.IntervalYearMonthType
 
IntervalDayTimeOperators - Class in io.prestosql.type
 
IntervalDayTimeType - Class in io.prestosql.type
 
IntervalDayToSecondAverageAggregation - Class in io.prestosql.operator.aggregation
 
intervalDayToSecondPlusDate(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
intervalDayToSecondPlusTime(long, long) - Static method in class io.prestosql.operator.scalar.time.TimeOperators
 
IntervalDayToSecondPlusTime() - Constructor for class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.IntervalDayToSecondPlusTime
 
IntervalDayToSecondPlusTimestamp() - Constructor for class io.prestosql.operator.scalar.timestamp.TimestampOperators.IntervalDayToSecondPlusTimestamp
 
IntervalDayToSecondPlusTimestamp() - Constructor for class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.IntervalDayToSecondPlusTimestamp
 
IntervalDayToSecondSumAggregation - Class in io.prestosql.operator.aggregation
 
IntervalYearMonthOperators - Class in io.prestosql.type
 
IntervalYearMonthType - Class in io.prestosql.type
 
IntervalYearToMonthAverageAggregation - Class in io.prestosql.operator.aggregation
 
intervalYearToMonthPlusDate(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
IntervalYearToMonthPlusTimestamp() - Constructor for class io.prestosql.operator.scalar.timestamp.TimestampOperators.IntervalYearToMonthPlusTimestamp
 
IntervalYearToMonthPlusTimestamp() - Constructor for class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.IntervalYearToMonthPlusTimestamp
 
IntervalYearToMonthSumAggregation - Class in io.prestosql.operator.aggregation
 
inTransaction(Session, Function<Session, T>) - Method in class io.prestosql.testing.LocalQueryRunner
 
inTransaction(Function<Session, T>) - Method in class io.prestosql.testing.LocalQueryRunner
 
inverseBetaCdf(double, double, double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
inverseNormalCdf(double, double, double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
invoke(FunctionMetadata, FunctionInvoker, ConnectorSession, List<Object>) - Static method in class io.prestosql.sql.InterpretedFunctionInvoker
 
invoke(ResolvedFunction, ConnectorSession, Object...) - Method in class io.prestosql.sql.InterpretedFunctionInvoker
 
invoke(ResolvedFunction, ConnectorSession, List<Object>) - Method in class io.prestosql.sql.InterpretedFunctionInvoker
Arguments must be the native container type for the corresponding SQL types.
invoke(InvokeFunction.InvokeLambda) - Static method in class io.prestosql.operator.scalar.InvokeFunction
 
invoke(Binding, BoundSignature) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
invoke(Binding, String) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
INVOKE_FUNCTION - Static variable in class io.prestosql.operator.scalar.InvokeFunction
 
invokeAll(Collection<? extends Callable<T>>) - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
invokeFunction(Scope, CachedInstanceBinder, Type, FunctionMetadata, Function<InvocationConvention, FunctionInvoker>, BytecodeExpression...) - Static method in class io.prestosql.sql.gen.InvokeFunctionBytecodeExpression
 
InvokeFunction - Class in io.prestosql.operator.scalar
This scalar function exists primarily to test lambda expression support.
InvokeFunction.InvokeLambda - Interface in io.prestosql.operator.scalar
 
InvokeFunctionBytecodeExpression - Class in io.prestosql.sql.gen
 
io.prestosql - package io.prestosql
 
io.prestosql.annotation - package io.prestosql.annotation
 
io.prestosql.block - package io.prestosql.block
 
io.prestosql.connector - package io.prestosql.connector
 
io.prestosql.connector.informationschema - package io.prestosql.connector.informationschema
 
io.prestosql.connector.system - package io.prestosql.connector.system
 
io.prestosql.connector.system.jdbc - package io.prestosql.connector.system.jdbc
 
io.prestosql.cost - package io.prestosql.cost
 
io.prestosql.dispatcher - package io.prestosql.dispatcher
 
io.prestosql.event - package io.prestosql.event
 
io.prestosql.eventlistener - package io.prestosql.eventlistener
 
io.prestosql.execution - package io.prestosql.execution
 
io.prestosql.execution.buffer - package io.prestosql.execution.buffer
 
io.prestosql.execution.executor - package io.prestosql.execution.executor
 
io.prestosql.execution.resourcegroups - package io.prestosql.execution.resourcegroups
 
io.prestosql.execution.scheduler - package io.prestosql.execution.scheduler
 
io.prestosql.execution.scheduler.group - package io.prestosql.execution.scheduler.group
 
io.prestosql.execution.warnings - package io.prestosql.execution.warnings
 
io.prestosql.failuredetector - package io.prestosql.failuredetector
 
io.prestosql.index - package io.prestosql.index
 
io.prestosql.memory - package io.prestosql.memory
 
io.prestosql.metadata - package io.prestosql.metadata
 
io.prestosql.operator - package io.prestosql.operator
 
io.prestosql.operator.aggregation - package io.prestosql.operator.aggregation
 
io.prestosql.operator.aggregation.arrayagg - package io.prestosql.operator.aggregation.arrayagg
 
io.prestosql.operator.aggregation.builder - package io.prestosql.operator.aggregation.builder
 
io.prestosql.operator.aggregation.histogram - package io.prestosql.operator.aggregation.histogram
 
io.prestosql.operator.aggregation.minmaxby - package io.prestosql.operator.aggregation.minmaxby
 
io.prestosql.operator.aggregation.multimapagg - package io.prestosql.operator.aggregation.multimapagg
 
io.prestosql.operator.aggregation.state - package io.prestosql.operator.aggregation.state
 
io.prestosql.operator.annotations - package io.prestosql.operator.annotations
 
io.prestosql.operator.exchange - package io.prestosql.operator.exchange
 
io.prestosql.operator.index - package io.prestosql.operator.index
 
io.prestosql.operator.project - package io.prestosql.operator.project
 
io.prestosql.operator.scalar - package io.prestosql.operator.scalar
 
io.prestosql.operator.scalar.annotations - package io.prestosql.operator.scalar.annotations
 
io.prestosql.operator.scalar.time - package io.prestosql.operator.scalar.time
 
io.prestosql.operator.scalar.timestamp - package io.prestosql.operator.scalar.timestamp
 
io.prestosql.operator.scalar.timestamptz - package io.prestosql.operator.scalar.timestamptz
 
io.prestosql.operator.scalar.timetz - package io.prestosql.operator.scalar.timetz
 
io.prestosql.operator.unnest - package io.prestosql.operator.unnest
 
io.prestosql.operator.window - package io.prestosql.operator.window
 
io.prestosql.security - package io.prestosql.security
 
io.prestosql.server - package io.prestosql.server
 
io.prestosql.server.protocol - package io.prestosql.server.protocol
 
io.prestosql.server.remotetask - package io.prestosql.server.remotetask
 
io.prestosql.server.security - package io.prestosql.server.security
 
io.prestosql.server.security.jwt - package io.prestosql.server.security.jwt
 
io.prestosql.server.security.oauth2 - package io.prestosql.server.security.oauth2
 
io.prestosql.server.testing - package io.prestosql.server.testing
 
io.prestosql.server.ui - package io.prestosql.server.ui
 
io.prestosql.spiller - package io.prestosql.spiller
 
io.prestosql.split - package io.prestosql.split
 
io.prestosql.sql - package io.prestosql.sql
 
io.prestosql.sql.analyzer - package io.prestosql.sql.analyzer
 
io.prestosql.sql.gen - package io.prestosql.sql.gen
 
io.prestosql.sql.gen.lambda - package io.prestosql.sql.gen.lambda
 
io.prestosql.sql.planner - package io.prestosql.sql.planner
 
io.prestosql.sql.planner.iterative - package io.prestosql.sql.planner.iterative
 
io.prestosql.sql.planner.iterative.rule - package io.prestosql.sql.planner.iterative.rule
 
io.prestosql.sql.planner.optimizations - package io.prestosql.sql.planner.optimizations
 
io.prestosql.sql.planner.optimizations.joins - package io.prestosql.sql.planner.optimizations.joins
 
io.prestosql.sql.planner.plan - package io.prestosql.sql.planner.plan
 
io.prestosql.sql.planner.planprinter - package io.prestosql.sql.planner.planprinter
 
io.prestosql.sql.planner.sanity - package io.prestosql.sql.planner.sanity
 
io.prestosql.sql.relational - package io.prestosql.sql.relational
 
io.prestosql.sql.relational.optimizer - package io.prestosql.sql.relational.optimizer
 
io.prestosql.sql.rewrite - package io.prestosql.sql.rewrite
 
io.prestosql.testing - package io.prestosql.testing
 
io.prestosql.testing.assertions - package io.prestosql.testing.assertions
 
io.prestosql.transaction - package io.prestosql.transaction
 
io.prestosql.type - package io.prestosql.type
 
io.prestosql.type.setdigest - package io.prestosql.type.setdigest
 
io.prestosql.util - package io.prestosql.util
 
io.prestosql.version - package io.prestosql.version
 
IoPlan(Set<IoPlanPrinter.IoPlan.TableColumnInfo>, Optional<CatalogSchemaTableName>, IoPlanPrinter.EstimatedStatsAndCost) - Constructor for class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan
 
IoPlanPrinter - Class in io.prestosql.sql.planner.planprinter
 
IoPlanPrinter.ColumnConstraint - Class in io.prestosql.sql.planner.planprinter
 
IoPlanPrinter.EstimatedStatsAndCost - Class in io.prestosql.sql.planner.planprinter
 
IoPlanPrinter.FormattedDomain - Class in io.prestosql.sql.planner.planprinter
 
IoPlanPrinter.FormattedMarker - Class in io.prestosql.sql.planner.planprinter
 
IoPlanPrinter.FormattedRange - Class in io.prestosql.sql.planner.planprinter
 
IoPlanPrinter.IoPlan - Class in io.prestosql.sql.planner.planprinter
 
IoPlanPrinter.IoPlan.IoPlanBuilder - Class in io.prestosql.sql.planner.planprinter
 
IoPlanPrinter.IoPlan.TableColumnInfo - Class in io.prestosql.sql.planner.planprinter
 
IPADDRESS - Static variable in class io.prestosql.type.IpAddressType
 
IpAddressOperators - Class in io.prestosql.type
 
IpAddressType - Class in io.prestosql.type
 
IPv4 - io.prestosql.execution.scheduler.SubnetBasedTopology.AddressProtocol
 
IPv6 - io.prestosql.execution.scheduler.SubnetBasedTopology.AddressProtocol
 
IS_NULL - io.prestosql.sql.relational.SpecialForm.Form
 
isAcknowledgePages() - Method in class io.prestosql.operator.ExchangeClientConfig
 
isAggregation(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
isAggregationFunction(QualifiedName) - Method in interface io.prestosql.metadata.Metadata
Is the named function an aggregation function? This does not need type parameters because overloads between aggregation and other function types are not allowed.
isAggregationFunction(QualifiedName) - Method in class io.prestosql.metadata.MetadataManager
 
isAliased() - Method in class io.prestosql.sql.analyzer.Field
 
isAllowPushdownIntoConnectors(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isAnonymous() - Method in class io.prestosql.sql.analyzer.RelationId
 
isAnyTaskBlocked() - Method in class io.prestosql.execution.SqlStageExecution
 
isAtLeast(PlanNode, Lookup, long) - Static method in class io.prestosql.sql.planner.optimizations.QueryCardinalityUtil
 
isAtLeastScalar(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.optimizations.QueryCardinalityUtil
 
isAtMost(PlanNode, Lookup, long) - Static method in class io.prestosql.sql.planner.optimizations.QueryCardinalityUtil
 
isAtMostScalar(PlanNode) - Static method in class io.prestosql.sql.planner.optimizations.QueryCardinalityUtil
 
isAtMostScalar(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.optimizations.QueryCardinalityUtil
 
isAutoCommit(TransactionId) - Method in interface io.prestosql.transaction.TransactionManager
 
isAutoCommitContext() - Method in class io.prestosql.transaction.TransactionInfo
 
isBlocked() - Method in class io.prestosql.operator.DeleteOperator
 
isBlocked() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator
 
isBlocked() - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator
 
isBlocked() - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator
 
isBlocked() - Method in class io.prestosql.operator.ExchangeClient
 
isBlocked() - Method in class io.prestosql.operator.ExchangeOperator
 
isBlocked() - Method in class io.prestosql.operator.HashBuilderOperator
 
isBlocked() - Method in class io.prestosql.operator.index.PageBufferOperator
 
isBlocked() - Method in class io.prestosql.operator.LookupOuterOperator
 
isBlocked() - Method in class io.prestosql.operator.MergeOperator
 
isBlocked() - Method in class io.prestosql.operator.NestedLoopBuildOperator
 
isBlocked() - Method in class io.prestosql.operator.NestedLoopJoinOperator
 
isBlocked() - Method in interface io.prestosql.operator.Operator
Returns a future that will be completed when the operator becomes unblocked.
isBlocked() - Method in class io.prestosql.operator.PageSourceOperator
 
isBlocked() - Method in class io.prestosql.operator.PartitionedOutputOperator
 
isBlocked() - Method in class io.prestosql.operator.SpatialIndexBuilderOperator
 
isBlocked() - Method in class io.prestosql.operator.TableFinishOperator
 
isBlocked() - Method in class io.prestosql.operator.TableScanOperator
 
isBlocked() - Method in class io.prestosql.operator.TableWriterOperator
 
isBlocked() - Method in class io.prestosql.operator.TaskOutputOperator
 
isBlocked() - Method in class io.prestosql.operator.WindowOperator
 
isBlocked() - Method in interface io.prestosql.operator.WorkProcessor
 
isBlocked() - Method in class io.prestosql.operator.WorkProcessorOperatorAdapter
 
isBlocked() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
isBlocked() - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
isBlocked() - Method in class io.prestosql.server.QueryProgressStats
 
isBlockPosition() - Method in class io.prestosql.operator.aggregation.AggregationImplementation.AggregateNativeContainerType
 
isBufferComplete() - Method in class io.prestosql.execution.buffer.BufferResult
 
isBuildSideReplicated(PlanNode) - Static method in class io.prestosql.operator.JoinUtils
 
isCanAddBuffers() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
isCanAddPages() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
isClearTransactionId() - Method in class io.prestosql.execution.QueryInfo
 
isClientComplete() - Method in class io.prestosql.operator.HttpPageBufferClient.PagesResponse
 
isClientTransactionSupport() - Method in class io.prestosql.Session
 
isClientTransactionSupport() - Method in class io.prestosql.SessionRepresentation
 
isClosed() - Method in class io.prestosql.operator.ExchangeClient
 
isClosed() - Method in class io.prestosql.testing.PageConsumerOperator
 
isCoercible() - Method in class io.prestosql.type.TypeCoercion.TypeCompatibility
 
isCollectingTaskNeeded(QueryId, PlanFragment) - Method in class io.prestosql.server.DynamicFilterService
Dynamic filters are collected in same stage as the join operator.
isCollectPlanStatisticsForAllQueries() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isCollectPlanStatisticsForAllQueries(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isColocatedJoinEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isColocatedJoinsEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isColumnReference(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
isColumnReference(Expression) - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
isColumnReference(QualifiedName) - Method in class io.prestosql.sql.analyzer.Scope
 
isComparable() - Method in class io.prestosql.type.FunctionType
 
isComparable() - Method in class io.prestosql.type.IpAddressType
 
isComparable() - Method in class io.prestosql.type.JsonType
 
isComparable() - Method in class io.prestosql.type.UnknownType
 
isComparable() - Method in class io.prestosql.type.UuidType
 
isComparableRequired() - Method in class io.prestosql.metadata.TypeVariableConstraint
 
isCompatible() - Method in class io.prestosql.type.TypeCoercion.TypeCompatibility
 
isCompatible(Type, Type) - Method in class io.prestosql.type.TypeCoercion
 
isCompatibleTablePartitioningWith(ActualProperties, Function<Symbol, Set<Symbol>>, Metadata, Session) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isCompatibleTablePartitioningWith(Partitioning, boolean, Metadata, Session) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isCompatibleWith(Partitioning, Metadata, Session) - Method in class io.prestosql.sql.planner.Partitioning
 
isCompatibleWith(Partitioning, Function<Symbol, Set<Symbol>>, Function<Symbol, Optional<NullableValue>>, Function<Symbol, Optional<NullableValue>>, Metadata, Session) - Method in class io.prestosql.sql.planner.Partitioning
 
isCompleteInfo() - Method in class io.prestosql.execution.QueryInfo
 
isCompleteInfo() - Method in class io.prestosql.execution.StageInfo
 
isCompressed() - Method in class io.prestosql.execution.buffer.SerializedPage
 
isConstant() - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
isContainsCrossJoin() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
isCoordinator() - Method in class io.prestosql.metadata.InternalNode
 
isCoordinator() - Method in class io.prestosql.server.NodeStatus
 
isCoordinator() - Method in class io.prestosql.server.ServerConfig
 
isCoordinator() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
isCoordinatorOnly() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isCoordinatorOnly() - Method in class io.prestosql.sql.planner.PartitioningHandle
 
isCoordinatorOnly() - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
isCovariantTypeBase(String) - Static method in class io.prestosql.type.TypeCoercion
 
isCpuTimerEnabled() - Method in class io.prestosql.operator.DriverContext
 
isCpuTimerEnabled() - Method in class io.prestosql.operator.PipelineContext
 
isCpuTimerEnabled() - Method in class io.prestosql.operator.TaskContext
 
isCreateTableAsSelectNoOp() - Method in class io.prestosql.sql.analyzer.Analysis.Create
 
isCreateTableAsSelectWithData() - Method in class io.prestosql.sql.analyzer.Analysis.Create
 
isCrossJoin() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
isDecomposable() - Method in class io.prestosql.operator.aggregation.AggregationHeader
 
isDecomposable(Metadata) - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
isDefaultFilterFactorEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isDefaultFilterFactorEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isDeleteTarget(Table) - Method in class io.prestosql.sql.analyzer.Analysis
 
isDeprecated() - Method in class io.prestosql.metadata.FunctionMetadata
 
isDescribe() - Method in class io.prestosql.sql.analyzer.Analysis
 
isDestroyed() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
isDestroyed() - Method in class io.prestosql.execution.executor.TaskHandle
 
isDestroyed() - Method in interface io.prestosql.operator.LookupSourceFactory
 
isDestroyed() - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
isDeterministic() - Method in class io.prestosql.metadata.FunctionMetadata
 
isDeterministic() - Method in class io.prestosql.operator.index.TuplePageFilter
 
isDeterministic() - Method in class io.prestosql.operator.project.ConstantPageProjection
 
isDeterministic() - Method in class io.prestosql.operator.project.DictionaryAwarePageFilter
 
isDeterministic() - Method in class io.prestosql.operator.project.DictionaryAwarePageProjection
 
isDeterministic() - Method in class io.prestosql.operator.project.GeneratedPageProjection
 
isDeterministic() - Method in class io.prestosql.operator.project.InputPageProjection
 
isDeterministic() - Method in interface io.prestosql.operator.project.PageFilter
 
isDeterministic() - Method in interface io.prestosql.operator.project.PageProjection
 
isDeterministic() - Method in class io.prestosql.operator.scalar.annotations.ScalarImplementationHeader
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ScalarHeader
 
isDeterministic(RowExpression) - Method in class io.prestosql.sql.relational.DeterminismEvaluator
 
isDeterministic(Expression, Metadata) - Static method in class io.prestosql.sql.planner.DeterminismEvaluator
 
isDeterministic(Expression, Function<FunctionCall, FunctionMetadata>) - Static method in class io.prestosql.sql.planner.DeterminismEvaluator
 
isDictionaryAggregation() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isDictionaryAggregationEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isDistinct() - Method in class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
isDistinct() - Method in class io.prestosql.sql.planner.plan.ExceptNode
 
isDistinct() - Method in class io.prestosql.sql.planner.plan.IntersectNode
 
isDistinct(PlanNode) - Static method in class io.prestosql.sql.planner.optimizations.DistinctOutputQueryUtil
 
isDistinct(PlanNode, Function<PlanNode, PlanNode>) - Static method in class io.prestosql.sql.planner.optimizations.DistinctOutputQueryUtil
 
isDistinctFrom(Block, int, Block, int) - Method in interface io.prestosql.type.BlockTypeOperators.BlockPositionIsDistinctFrom
 
isDistributedIndexJoinEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isDistributedIndexJoinsEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isDistributedSortEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isDistributedSortEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isDone() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
isDone() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
isDone() - Method in class io.prestosql.execution.DataDefinitionExecution
 
isDone() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
isDone() - Method in enum io.prestosql.execution.QueryState
Is this a terminal state.
isDone() - Method in class io.prestosql.execution.QueryStateMachine
 
isDone() - Method in interface io.prestosql.execution.QueryTracker.TrackedQuery
 
isDone() - Method in class io.prestosql.execution.SqlQueryExecution
 
isDone() - Method in enum io.prestosql.execution.StageState
Is this a terminal state.
isDone() - Method in enum io.prestosql.execution.TaskState
Is this a terminal state.
isDone() - Method in class io.prestosql.operator.DriverContext
 
isDone() - Method in class io.prestosql.operator.OperatorContext
 
isDone() - Method in class io.prestosql.operator.PipelineContext
 
isDone() - Method in class io.prestosql.operator.TaskContext
 
isDynamic() - Method in class io.prestosql.execution.scheduler.BucketNodeMap
 
isDynamic() - Method in class io.prestosql.execution.scheduler.FixedBucketNodeMap
 
isDynamic() - Method in class io.prestosql.execution.scheduler.group.DynamicBucketNodeMap
 
isDynamicFilter(Expression) - Static method in class io.prestosql.sql.DynamicFilters
 
isDynamicLifespanSchedule() - Method in class io.prestosql.operator.StageExecutionDescriptor
 
isDynamicScheduleForGroupedExecution(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isDynamicScheduleForGroupedExecutionEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isEffectivelySinglePartition(Set<Symbol>) - Method in class io.prestosql.sql.planner.Partitioning
 
isEffectivelySingleStream() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isEmpty() - Method in class io.prestosql.cost.StatisticRange
 
isEmpty() - Method in class io.prestosql.execution.buffer.BufferResult
 
isEmpty() - Method in class io.prestosql.execution.resourcegroups.IndexedPriorityQueue
 
isEmpty() - Method in class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
 
isEmpty() - Method in interface io.prestosql.operator.aggregation.arrayagg.ArrayAggregationState
 
isEmpty() - Method in class io.prestosql.operator.aggregation.arrayagg.SingleArrayAggregationState
 
isEmpty() - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
isEmpty() - Method in class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
isEmpty() - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
isEmpty() - Method in interface io.prestosql.operator.aggregation.multimapagg.MultimapAggregationState
 
isEmpty() - Method in class io.prestosql.operator.aggregation.multimapagg.SingleMultimapAggregationState
 
isEmpty() - Method in class io.prestosql.operator.aggregation.TypedHeap
 
isEmpty() - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
isEmpty() - Method in class io.prestosql.operator.ChannelSet
 
isEmpty() - Method in class io.prestosql.operator.index.IndexLookupSource
 
isEmpty() - Method in class io.prestosql.operator.JoinHash
 
isEmpty() - Method in class io.prestosql.operator.LookupJoinPageBuilder
 
isEmpty() - Method in interface io.prestosql.operator.LookupSource
 
isEmpty() - Method in class io.prestosql.operator.OuterLookupSource
 
isEmpty() - Method in class io.prestosql.operator.PageBuffer
 
isEmpty() - Method in class io.prestosql.operator.PartitionedLookupSource
 
isEmpty() - Method in interface io.prestosql.operator.PositionLinks.FactoryBuilder
 
isEmpty() - Method in class io.prestosql.operator.project.SelectedPositions
 
isEmpty() - Method in class io.prestosql.server.protocol.QueryResultRows
 
isEmpty() - Method in class io.prestosql.sql.planner.iterative.Rule.Result
 
isEmpty() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
isEmpty() - Method in class io.prestosql.sql.planner.plan.Assignments
 
isEmpty() - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
isEmpty() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
 
isEmpty() - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
isEmpty(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.optimizations.QueryCardinalityUtil
 
isEnabled() - Method in class io.prestosql.failuredetector.FailureDetectorConfig
 
isEnabled() - Method in class io.prestosql.server.EmbeddedDiscoveryConfig
 
isEnabled() - Method in class io.prestosql.server.ui.WebUiConfig
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.AddIntermediateAggregations
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.EliminateCrossJoins
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins.ExtractSpatialInnerJoin
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins.ExtractSpatialLeftJoin
 
isEnabled(Session) - Method in interface io.prestosql.sql.planner.iterative.Rule
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.PushAggregationIntoTableScan
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.PushAggregationThroughOuterJoin
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.PushDistinctLimitIntoTableScan
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.PushLimitIntoTableScan
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.PushPartialAggregationThroughJoin
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.PushPredicateIntoTableScan
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.PushPredicateThroughProjectIntoWindow
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.PushProjectionIntoTableScan
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.PushSampleIntoTableScan
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.PushTableWriteThroughUnion
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.ReorderJoins
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.TransformFilteringSemiJoinToInnerJoin
 
isEnableDynamicFiltering() - Method in class io.prestosql.execution.DynamicFilterConfig
 
isEnableDynamicFiltering(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isEnableForcedExchangeBelowGroupId() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isEnableForcedExchangeBelowGroupId(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isEnableIntermediateAggregations() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isEnableIntermediateAggregations(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isEnableLargeDynamicFilters() - Method in class io.prestosql.execution.DynamicFilterConfig
 
isEnableLargeDynamicFilters(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isEnableStatsCalculator() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isEnableStatsCalculator(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isEncrypted() - Method in class io.prestosql.execution.buffer.SerializedPage
 
isExact() - Method in class io.prestosql.type.setdigest.SetDigest
 
isExactlyPartitionedOn(Iterable<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
isExchangeCompressionEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isExchangeCompressionEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isExecutionStarted() - Method in class io.prestosql.operator.DriverContext
 
isExpandableQuery(Query) - Method in class io.prestosql.sql.analyzer.Analysis
 
isExpressionExpensive() - Method in class io.prestosql.sql.gen.ExpressionProfiler
 
isFailure() - Method in enum io.prestosql.execution.StageState
Is this a non-success terminal state.
isFinal() - Method in class io.prestosql.operator.ExchangeClientStatus
 
isFinal() - Method in class io.prestosql.operator.JoinOperatorInfo
 
isFinal() - Method in interface io.prestosql.operator.OperatorInfo
 
isFinal() - Method in class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputInfo
 
isFinal() - Method in class io.prestosql.operator.SplitOperatorInfo
 
isFinal() - Method in class io.prestosql.operator.TableFinishInfo
 
isFinal() - Method in class io.prestosql.operator.TableWriterOperator.TableWriterInfo
 
isFinalQueryInfo() - Method in class io.prestosql.execution.QueryInfo
 
isFinalStageInfo() - Method in class io.prestosql.execution.StageInfo
 
isFinished() - Method in class io.prestosql.connector.informationschema.InformationSchemaPageSource
 
isFinished() - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
isFinished() - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
isFinished() - Method in class io.prestosql.execution.buffer.BufferInfo
 
isFinished() - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
isFinished() - Method in interface io.prestosql.execution.buffer.OutputBuffer
A buffer is finished once no-more-pages has been set and all buffers have been closed with an abort call.
isFinished() - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
isFinished() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
isFinished() - Method in class io.prestosql.execution.scheduler.AllAtOnceExecutionSchedule
 
isFinished() - Method in interface io.prestosql.execution.scheduler.ExecutionSchedule
 
isFinished() - Method in class io.prestosql.execution.scheduler.PhasedExecutionSchedule
 
isFinished() - Method in class io.prestosql.execution.scheduler.ScheduleResult
 
isFinished() - Method in interface io.prestosql.execution.SplitRunner
 
isFinished() - Method in class io.prestosql.operator.AggregationOperator
 
isFinished() - Method in class io.prestosql.operator.DeleteOperator
 
isFinished() - Method in class io.prestosql.operator.DevNullOperator
 
isFinished() - Method in class io.prestosql.operator.DistinctLimitOperator
 
isFinished() - Method in class io.prestosql.operator.Driver
 
isFinished() - Method in class io.prestosql.operator.DynamicFilterSourceOperator
 
isFinished() - Method in class io.prestosql.operator.EnforceSingleRowOperator
 
isFinished() - Method in class io.prestosql.operator.exchange.LocalExchangeSink
 
isFinished() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator
 
isFinished() - Method in class io.prestosql.operator.exchange.LocalExchangeSource
 
isFinished() - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator
 
isFinished() - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator
 
isFinished() - Method in class io.prestosql.operator.ExchangeClient
 
isFinished() - Method in class io.prestosql.operator.ExchangeOperator
 
isFinished() - Method in class io.prestosql.operator.ExplainAnalyzeOperator
 
isFinished() - Method in class io.prestosql.operator.FinishedOperator
 
isFinished() - Method in class io.prestosql.operator.GroupIdOperator
 
isFinished() - Method in class io.prestosql.operator.HashAggregationOperator
 
isFinished() - Method in class io.prestosql.operator.HashBuilderOperator
 
isFinished() - Method in class io.prestosql.operator.index.IndexSourceOperator
 
isFinished() - Method in class io.prestosql.operator.index.PageBufferOperator
 
isFinished() - Method in class io.prestosql.operator.index.PagesIndexBuilderOperator
 
isFinished() - Method in class io.prestosql.operator.JoinProbe
 
isFinished() - Method in class io.prestosql.operator.LimitOperator
 
isFinished() - Method in class io.prestosql.operator.LookupOuterOperator
 
isFinished() - Method in class io.prestosql.operator.MarkDistinctOperator
 
isFinished() - Method in class io.prestosql.operator.MergeOperator
 
isFinished() - Method in class io.prestosql.operator.NestedLoopBuildOperator
 
isFinished() - Method in class io.prestosql.operator.NestedLoopJoinOperator
 
isFinished() - Method in interface io.prestosql.operator.Operator
Is this operator completely finished processing and no more output pages will be produced.
isFinished() - Method in class io.prestosql.operator.OrderByOperator
 
isFinished() - Method in class io.prestosql.operator.PageBuffer
 
isFinished() - Method in class io.prestosql.operator.PageSourceOperator
 
isFinished() - Method in class io.prestosql.operator.PartitionedOutputOperator
 
isFinished() - Method in class io.prestosql.operator.RowNumberOperator
 
isFinished() - Method in class io.prestosql.operator.SetBuilderOperator
 
isFinished() - Method in class io.prestosql.operator.SpatialIndexBuilderOperator
 
isFinished() - Method in class io.prestosql.operator.SpatialJoinOperator
 
isFinished() - Method in class io.prestosql.operator.StatisticsWriterOperator
 
isFinished() - Method in class io.prestosql.operator.TableDeleteOperator
 
isFinished() - Method in class io.prestosql.operator.TableFinishOperator
 
isFinished() - Method in class io.prestosql.operator.TableScanOperator
 
isFinished() - Method in class io.prestosql.operator.TableWriterOperator
 
isFinished() - Method in class io.prestosql.operator.TaskOutputOperator
 
isFinished() - Method in class io.prestosql.operator.TopNRowNumberOperator
 
isFinished() - Method in class io.prestosql.operator.unnest.UnnestOperator
 
isFinished() - Method in class io.prestosql.operator.ValuesOperator
 
isFinished() - Method in class io.prestosql.operator.WindowOperator
 
isFinished() - Method in interface io.prestosql.operator.WorkProcessor
 
isFinished() - Method in class io.prestosql.operator.WorkProcessorOperatorAdapter
 
isFinished() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
isFinished() - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
isFinished() - Method in class io.prestosql.split.BufferingSplitSource
 
isFinished() - Method in class io.prestosql.split.ConnectorAwareSplitSource
 
isFinished() - Method in class io.prestosql.split.MappedPageSource
 
isFinished() - Method in class io.prestosql.split.SampledSplitSource
 
isFinished() - Method in interface io.prestosql.split.SplitSource
 
isFinished() - Method in class io.prestosql.testing.NullOutputOperator
 
isFinished() - Method in class io.prestosql.testing.PageConsumerOperator
 
isFinite(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
isFirstNull() - Method in interface io.prestosql.operator.aggregation.minmaxby.TwoNullableValueState
 
isFixedManagementUserForHttps() - Method in class io.prestosql.server.security.SecurityConfig
 
isForceSingleNodeOutput() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isForceSingleNodeOutput(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isForDelete() - Method in class io.prestosql.sql.planner.plan.TableScanNode
 
isFull() - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
isFull() - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
isFull() - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
isFull() - Method in interface io.prestosql.execution.buffer.OutputBuffer
Get a future that will be completed when the buffer is not full.
isFull() - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
isFull() - Method in interface io.prestosql.operator.aggregation.builder.HashAggregationBuilder
 
isFull() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
isFull() - Method in class io.prestosql.operator.aggregation.builder.SpillableHashAggregationBuilder
 
isFull() - Method in class io.prestosql.operator.index.PageBuffer
 
isFull() - Method in class io.prestosql.operator.LookupJoinPageBuilder
 
isFullyBlocked() - Method in class io.prestosql.execution.BasicStageStats
 
isFullyBlocked() - Method in class io.prestosql.execution.QueryStats
 
isFullyBlocked() - Method in class io.prestosql.execution.StageStats
 
isFullyBlocked() - Method in class io.prestosql.operator.DriverContext
 
isFullyBlocked() - Method in class io.prestosql.operator.DriverStats
 
isFullyBlocked() - Method in class io.prestosql.operator.PipelineStats
 
isFullyBlocked() - Method in class io.prestosql.operator.TaskStats
 
isFullyBlocked() - Method in class io.prestosql.server.BasicQueryStats
 
isGroupedExecutionEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isGroupedExecutionEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isHidden() - Method in class io.prestosql.metadata.FunctionMetadata
 
isHidden() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
isHidden() - Method in class io.prestosql.operator.aggregation.AggregationHeader
 
isHidden() - Method in class io.prestosql.operator.scalar.annotations.ScalarImplementationHeader
 
isHidden() - Method in class io.prestosql.operator.scalar.ScalarHeader
 
isHidden() - Method in class io.prestosql.sql.analyzer.Field
 
isHttp2Enabled() - Method in class io.prestosql.server.InternalCommunicationConfig
 
isHttpsRequired() - Method in class io.prestosql.server.InternalCommunicationConfig
 
isIdentity() - Method in class io.prestosql.sql.planner.plan.Assignments
 
isIdentity() - Method in class io.prestosql.sql.planner.plan.ProjectNode
 
isIdentity(Symbol) - Method in class io.prestosql.sql.planner.plan.Assignments
 
isIgnoreDownstreamPreferences() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isIgnoreNulls() - Method in class io.prestosql.sql.planner.plan.WindowNode.Function
 
isIgnoreStatsCalculatorFailures() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isIgnoreStatsCalculatorFailures(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isImplementationDependencyAnnotation(Annotation) - Static method in interface io.prestosql.operator.annotations.ImplementationDependency
 
isIncludeCoordinator() - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
isIncludeExceptionInResponse() - Method in class io.prestosql.server.ServerConfig
 
isInferenceCandidate(Metadata, Expression) - Static method in class io.prestosql.sql.planner.EqualityInference
Determines whether an Expression may be successfully applied to the equality inference
isInfinite(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
isInputDriver() - Method in class io.prestosql.operator.DriverFactory
 
isInputPipeline() - Method in class io.prestosql.operator.PipelineContext
 
isInputPipeline() - Method in class io.prestosql.operator.PipelineStats
 
isInputRaw() - Method in enum io.prestosql.sql.planner.plan.AggregationNode.Step
 
isInsecureAuthenticationOverHttpAllowed() - Method in class io.prestosql.server.security.SecurityConfig
 
isInstanceOfAny(Class<?>...) - Static method in class io.prestosql.util.MorePredicates
 
isInteger(long) - Static method in class io.prestosql.sql.gen.InCodeGenerator
 
isInternalRequest(ContainerRequestContext) - Static method in class io.prestosql.server.InternalAuthenticationManager
 
isInternalSystemConnector(CatalogName) - Static method in class io.prestosql.connector.CatalogName
 
isIterativeRuleBasedColumnPruning() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isIterativeRuleBasedColumnPruning(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isJoinPositionEligible(int, int, Page) - Method in class io.prestosql.operator.PagesRTreeIndex
 
isJoinPositionEligible(int, int, Page) - Method in interface io.prestosql.operator.PagesSpatialIndex
 
isJoinPositionEligible(long, int, Page) - Method in class io.prestosql.operator.index.IndexLookupSource
 
isJoinPositionEligible(long, int, Page) - Method in class io.prestosql.operator.JoinHash
 
isJoinPositionEligible(long, int, Page) - Method in interface io.prestosql.operator.LookupSource
 
isJoinPositionEligible(long, int, Page) - Method in class io.prestosql.operator.OuterLookupSource
 
isJoinPositionEligible(long, int, Page) - Method in class io.prestosql.operator.PartitionedLookupSource
 
isJsonLengthLimitExceeded() - Method in class io.prestosql.operator.TableFinishInfo
 
isJsonScalar(Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
isLastBatch() - Method in class io.prestosql.split.SplitSource.SplitBatch
Returns true if all splits for the requested driver group have been returned.
isLateMaterializationEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isLateMaterializationEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isLeaf() - Method in class io.prestosql.sql.planner.PlanFragment
 
isLikePattern(Slice, Optional<Slice>) - Static method in class io.prestosql.type.LikeFunctions
 
isList() - Method in class io.prestosql.operator.project.SelectedPositions
 
isLoaded() - Method in class io.prestosql.operator.GroupByIdBlock
 
isLoaded() - Method in class io.prestosql.server.security.PasswordAuthenticatorManager
 
isLocal() - Method in class io.prestosql.sql.analyzer.ResolvedField
 
isLocalScope(Scope) - Method in class io.prestosql.sql.analyzer.Scope
 
isLoginEnabled(boolean) - Method in interface io.prestosql.server.ui.FormAuthenticator
 
isLoginEnabled(boolean) - Method in class io.prestosql.server.ui.InsecureFormAuthenticator
 
isLoginEnabled(boolean) - Method in class io.prestosql.server.ui.PasswordManagerFormAuthenticator
 
isMemoryExceeded() - Method in class io.prestosql.operator.index.IndexSnapshotBuilder
 
isMemoryRevokingRequested() - Method in class io.prestosql.operator.OperatorContext
 
isNaN(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
isNeedsPlan() - Method in class io.prestosql.execution.TaskInfo
 
isNodePartitionedOn(Collection<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isNodePartitionedOn(Collection<Symbol>, boolean) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isNoMoreBufferIds() - Method in class io.prestosql.execution.buffer.OutputBuffers
 
isNoMoreBufferLocations() - Method in class io.prestosql.execution.QueryExecution.QueryOutputInfo
 
isNoMoreLocations() - Method in class io.prestosql.operator.ExchangeClientStatus
 
isNoMoreRows() - Method in class io.prestosql.operator.project.CursorProcessorOutput
 
isNoMoreSplits() - Method in class io.prestosql.execution.TaskSource
 
isNull() - Method in interface io.prestosql.operator.aggregation.state.NullableBooleanState
 
isNull() - Method in interface io.prestosql.operator.aggregation.state.NullableDoubleState
 
isNull() - Method in interface io.prestosql.operator.aggregation.state.NullableLongState
 
isNull(int) - Method in class io.prestosql.operator.GroupByIdBlock
 
isNull(int) - Method in class io.prestosql.operator.index.PageRecordSet.PageRecordCursor
 
isNull(int) - Method in class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
isNull(int, int) - Method in class io.prestosql.operator.PagesIndex
 
isNull(int, int) - Method in class io.prestosql.operator.window.PagesWindowIndex
 
isNullable() - Method in class io.prestosql.metadata.FunctionArgumentDefinition
 
isNullable() - Method in class io.prestosql.metadata.FunctionMetadata
 
isNullable() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
isNullable() - Method in interface io.prestosql.operator.ParametricImplementation
 
isNullable() - Method in class io.prestosql.operator.ParametricImplementationsGroup
 
isNullable() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation
 
IsNullCodeGenerator - Class in io.prestosql.sql.gen
 
IsNullCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.IsNullCodeGenerator
 
isNullsAllowed() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedDomain
 
isNullsAndAnyReplicated() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isNumericType(Type) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
isolateClass(DynamicClassLoader, Class<T>, Class<? extends T>, Class<?>...) - Static method in class io.prestosql.sql.gen.IsolatedClass
 
IsolatedClass - Class in io.prestosql.sql.gen
 
isOmitDateTimeTypePrecision() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isOmitDateTimeTypePrecision(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isOperatorName(String) - Static method in class io.prestosql.metadata.Signature
 
isOptimizeDistinctAggregationEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isOptimizeHashGeneration() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isOptimizeHashGenerationEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isOptimizeMetadataQueries() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isOptimizeMetadataQueries(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isOptimizeMixedDistinctAggregations() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isOptimizeTopNRowNumber() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isOptimizeTopNRowNumber(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isOptional() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.CastDependency
 
isOptional() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependency
 
isOptional() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.OperatorDependency
 
isOrderable() - Method in class io.prestosql.type.ColorType
 
isOrderable() - Method in class io.prestosql.type.FunctionType
 
isOrderable() - Method in class io.prestosql.type.IpAddressType
 
isOrderable() - Method in class io.prestosql.type.UnknownType
 
isOrderable() - Method in class io.prestosql.type.UuidType
 
isOrderableRequired() - Method in class io.prestosql.metadata.TypeVariableConstraint
 
isOrderByRedundant(OrderBy) - Method in class io.prestosql.sql.analyzer.Analysis
 
isOrdered() - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
isOrderSensitive() - Method in class io.prestosql.metadata.AggregationFunctionMetadata
 
isOrderSensitive() - Method in class io.prestosql.operator.aggregation.AggregationHeader
 
isOrderSensitive() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
isOrderSensitive() - Method in class io.prestosql.sql.planner.plan.RowNumberNode
 
isOriginalOrder(List<Integer>) - Static method in class io.prestosql.sql.planner.iterative.rule.EliminateCrossJoins
 
isOutputBufferOverutilized() - Method in class io.prestosql.execution.SqlTask
 
isOutputBufferOverutilized() - Method in class io.prestosql.execution.TaskStatus
 
isOutputDriver() - Method in class io.prestosql.operator.DriverFactory
 
isOutputPartial() - Method in enum io.prestosql.sql.planner.plan.AggregationNode.Step
 
isOutputPipeline() - Method in class io.prestosql.operator.PipelineContext
 
isOutputPipeline() - Method in class io.prestosql.operator.PipelineStats
 
isOutputRowCountUnknown() - Method in class io.prestosql.cost.PlanNodeStatsEstimate
 
isOverutilized() - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
isOverutilized() - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
isOverutilized() - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
isOverutilized() - Method in interface io.prestosql.execution.buffer.OutputBuffer
Check if the buffer is blocking producers.
isOverutilized() - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
isPagesIndexEagerCompactionEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isParallelPreferred() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
isParameterBlock(Annotation[]) - Static method in class io.prestosql.operator.aggregation.AggregationImplementation.Parser
 
isParameterNullable(Annotation[]) - Static method in class io.prestosql.operator.aggregation.AggregationImplementation.Parser
 
isParseDecimalLiteralsAsDouble() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isParseDecimalLiteralsAsDouble(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isPartial() - Method in class io.prestosql.sql.planner.plan.DistinctLimitNode
 
isPartial() - Method in class io.prestosql.sql.planner.plan.LimitNode
 
isPartial() - Static method in class io.prestosql.sql.planner.plan.Patterns.DistinctLimit
 
isPartial() - Method in class io.prestosql.sql.planner.plan.SortNode
 
isPartial() - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
isPartitionedOn(Iterable<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
isPartitionedOn(Collection<Symbol>, Set<Symbol>) - Method in class io.prestosql.sql.planner.Partitioning
 
isPartitionedSources(PlanNodeId) - Method in class io.prestosql.sql.planner.PlanFragment
 
isPasswordAllowed(boolean) - Method in interface io.prestosql.server.ui.FormAuthenticator
 
isPasswordAllowed(boolean) - Method in class io.prestosql.server.ui.FormWebUiAuthenticationFilter
 
isPasswordAllowed(boolean) - Method in class io.prestosql.server.ui.InsecureFormAuthenticator
 
isPasswordAllowed(boolean) - Method in class io.prestosql.server.ui.PasswordManagerFormAuthenticator
 
isPerOperatorCpuTimerEnabled() - Method in class io.prestosql.execution.TaskManagerConfig
 
isPerOperatorCpuTimerEnabled() - Method in class io.prestosql.operator.DriverContext
 
isPerOperatorCpuTimerEnabled() - Method in class io.prestosql.operator.PipelineContext
 
isPerOperatorCpuTimerEnabled() - Method in class io.prestosql.operator.TaskContext
 
isPositionNull(int, int) - Method in interface io.prestosql.operator.PagesHashStrategy
Checks if any of the hashed columns is null
isPositionNull(int, int) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
isPredicatePushdownUseTableProperties() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isPredicatePushdownUseTableProperties(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isPreferPartialAggregation() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isPrestoAnnotation(Annotation) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
isPushAggregationThroughOuterJoin() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isPushAggregationThroughOuterJoin(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isPushPartialAggregationThoughJoin() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isPushPartialAggregationThroughJoin(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isPushTableWriteThroughUnion() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isPushTableWriteThroughUnion(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isQueryRegistered(QueryId) - Method in class io.prestosql.dispatcher.DispatchManager
 
isQueryResultsCompressionEnabled() - Method in class io.prestosql.server.ServerConfig
 
isReadOnly() - Method in class io.prestosql.transaction.TransactionInfo
 
isRedistributeWrites() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isRedistributeWrites(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isRemotelyAccessible() - Method in class io.prestosql.connector.informationschema.InformationSchemaSplit
 
isRemotelyAccessible() - Method in class io.prestosql.connector.system.SystemSplit
 
isRemotelyAccessible() - Method in class io.prestosql.metadata.Split
 
isRemotelyAccessible() - Method in class io.prestosql.operator.index.IndexSplit
 
isRemotelyAccessible() - Method in class io.prestosql.split.EmptySplit
 
isRemotelyAccessible() - Method in class io.prestosql.split.RemoteSplit
 
isRemotelyAccessible() - Method in class io.prestosql.testing.TestingSplit
 
isRepartitionEffective(Collection<Symbol>, Set<Symbol>) - Method in class io.prestosql.sql.planner.Partitioning
 
isReplicateNullsAndAny() - Method in class io.prestosql.sql.planner.PartitioningScheme
 
isRequiredSharedSecretSet() - Method in class io.prestosql.server.InternalCommunicationConfig
 
isReservedPoolDisabled() - Method in class io.prestosql.memory.NodeMemoryConfig
Deprecated.
isResolved(QualifiedName) - Static method in class io.prestosql.metadata.ResolvedFunction
 
isRewriteFilteringSemiJoinToInnerJoin() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isRewriteFilteringSemiJoinToInnerJoin(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isRowCountEnabled() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
isRunning() - Method in class io.prestosql.operator.HttpPageBufferClient
 
isSatisfiedBy(StreamPropertyDerivations.StreamProperties) - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
isScalar(PlanNode) - Static method in class io.prestosql.sql.planner.optimizations.QueryCardinalityUtil
 
isScalar(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.optimizations.QueryCardinalityUtil
 
isScaleWriters() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isScaleWriters(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isScanGroupedExecution(PlanNodeId) - Method in class io.prestosql.operator.StageExecutionDescriptor
 
isScheduled() - Method in class io.prestosql.execution.BasicStageStats
 
isScheduled() - Method in class io.prestosql.execution.QueryInfo
 
isScheduled() - Method in class io.prestosql.execution.QueryStats
 
isScheduled() - Method in class io.prestosql.server.BasicQueryInfo
 
isSecondNull() - Method in interface io.prestosql.operator.aggregation.minmaxby.TwoNullableValueState
 
isSet() - Method in class io.prestosql.operator.DriverYieldSignal
 
isSet(byte) - Method in enum io.prestosql.execution.buffer.PageCodecMarker
 
isShareIndexLoading() - Method in class io.prestosql.execution.TaskManagerConfig
 
isShareIndexLoading(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isShutdown() - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
isShutdownRequested() - Method in class io.prestosql.server.GracefulShutdownHandler
 
isSingleNode() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isSingleNode() - Method in class io.prestosql.sql.planner.PartitioningHandle
 
isSingleNode() - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
isSingleStream() - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
isSingleStreamPreferred() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
isSingleValue() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
isSkipMaterializedViewRefresh() - Method in class io.prestosql.sql.analyzer.Analysis
 
isSkipRedundantSort() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isSkipRedundantSort(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isSortChannelPositionNull(int, int) - Method in interface io.prestosql.operator.PagesHashStrategy
Checks if sort channel is null at the specified position
isSortChannelPositionNull(int, int) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
isSpatialJoinEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isSpatialJoinFilter(PlanNode, PlanNode, Expression) - Static method in class io.prestosql.util.SpatialJoinUtils
 
isSpatialJoinsEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isSpillable() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
isSpillCompressionEnabled() - Method in class io.prestosql.spiller.NodeSpillConfig
 
isSpillEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isSpillEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isSpillEncryptionEnabled() - Method in class io.prestosql.spiller.NodeSpillConfig
 
isSpillOrderBy() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isSpillOrderBy(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isSpillWindowOperator() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isSpillWindowOperator(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isStageGroupedExecution() - Method in class io.prestosql.operator.StageExecutionDescriptor
 
isStatisticsCpuTimerEnabled() - Method in class io.prestosql.execution.TaskManagerConfig
 
isStatisticsCpuTimerEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isStreamable() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
isStreamPartitionedOn(Collection<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isStreamPartitionedOn(Collection<Symbol>, boolean) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isStreamRepartitionEffective(Collection<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isTablesEnumeratingTable(InformationSchemaTable) - Static method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
isTarget() - Method in class io.prestosql.util.HeapTraversal
 
isTaskCpuTimerEnabled() - Method in class io.prestosql.execution.TaskManagerConfig
 
isTaskWide() - Method in class io.prestosql.execution.Lifespan
 
isTerminal() - Method in enum io.prestosql.execution.buffer.BufferState
 
isTerminated() - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
isTransactionControlStatement(Statement) - Static method in class io.prestosql.util.StatementUtils
 
isTypeOnlyCoercion(Type, Type) - Method in class io.prestosql.type.TypeCoercion
 
isTypeOnlyCoercion(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
isTypeOnlyCoercion(Expression) - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
isUnknown() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
isUnwrapCasts() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isUnwrapCasts(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isUseMarkDistinct() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isUsePreferredWritePartitioning() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isUsePreferredWritePartitioning(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isValid(Slug.Context, String, long) - Method in class io.prestosql.server.protocol.Slug
 
isValid(Integer, ConstraintValidatorContext) - Method in class io.prestosql.util.PowerOfTwoValidator
 
isValidCredential(String, String, boolean) - Method in interface io.prestosql.server.ui.FormAuthenticator
 
isValidCredential(String, String, boolean) - Method in class io.prestosql.server.ui.InsecureFormAuthenticator
 
isValidCredential(String, String, boolean) - Method in class io.prestosql.server.ui.PasswordManagerFormAuthenticator
 
isValidOffset(int, int) - Static method in class io.prestosql.type.DateTimes
 
isVariable() - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
isVariableArity() - Method in class io.prestosql.metadata.Signature
 
isVerbose() - Method in class io.prestosql.sql.planner.plan.ExplainAnalyzeNode
 
isWaitingForMemory() - Method in class io.prestosql.operator.OperatorContext
 
isWaitingForRevocableMemory() - Method in class io.prestosql.operator.OperatorContext
 
isWithTies() - Method in class io.prestosql.sql.planner.plan.LimitNode
 
isWorkerShutdown() - Method in class io.prestosql.server.testing.TestingPrestoServer.TestShutdownAction
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class io.prestosql.server.PagesResponseWriter
 
ITERATIVE_COLUMN_PRUNING - Static variable in class io.prestosql.SystemSessionProperties
 
ITERATIVE_OPTIMIZER_TIMEOUT - Static variable in class io.prestosql.SystemSessionProperties
 
IterativeOptimizer - Class in io.prestosql.sql.planner.iterative
 
IterativeOptimizer(RuleStatsRecorder, StatsCalculator, CostCalculator, Predicate<Session>, List<PlanOptimizer>, Set<Rule<?>>) - Constructor for class io.prestosql.sql.planner.iterative.IterativeOptimizer
 
IterativeOptimizer(RuleStatsRecorder, StatsCalculator, CostCalculator, Set<Rule<?>>) - Constructor for class io.prestosql.sql.planner.iterative.IterativeOptimizer
 
iterator() - Method in class io.prestosql.execution.resourcegroups.IndexedPriorityQueue
 
iterator() - Method in interface io.prestosql.operator.WorkProcessor
Converts WorkProcessor into an Iterator.
iterator() - Method in class io.prestosql.server.protocol.QueryResultRows
 
iterator() - Method in class io.prestosql.testing.MaterializedResult
 

J

jaccardIndex(Slice, Slice) - Static method in class io.prestosql.type.setdigest.SetDigestFunctions
 
jaccardIndex(SetDigest, SetDigest) - Static method in class io.prestosql.type.setdigest.SetDigest
 
JdbcTable - Class in io.prestosql.connector.system.jdbc
 
JdbcTable() - Constructor for class io.prestosql.connector.system.jdbc.JdbcTable
 
JmxNamingConfig - Class in io.prestosql.server
 
JmxNamingConfig() - Constructor for class io.prestosql.server.JmxNamingConfig
 
join() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
Join() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Join
 
JOIN_DISTRIBUTION_TYPE - Static variable in class io.prestosql.SystemSessionProperties
 
JOIN_MAX_BROADCAST_TABLE_SIZE - Static variable in class io.prestosql.SystemSessionProperties
 
JOIN_REORDERING_STRATEGY - Static variable in class io.prestosql.SystemSessionProperties
 
JoinBridge - Interface in io.prestosql.operator
A bridge that connects build, probe, and outer operators of a join.
JoinBridgeManager<T extends JoinBridge> - Class in io.prestosql.operator
 
JoinBridgeManager(boolean, PipelineExecutionStrategy, PipelineExecutionStrategy, Function<Lifespan, T>, List<Type>) - Constructor for class io.prestosql.operator.JoinBridgeManager
 
JoinCompiler - Class in io.prestosql.sql.gen
 
JoinCompiler(TypeOperators) - Constructor for class io.prestosql.sql.gen.JoinCompiler
 
JoinCompiler.LookupSourceSupplierFactory - Class in io.prestosql.sql.gen
 
JoinCompiler.PagesHashStrategyFactory - Class in io.prestosql.sql.gen
 
joinExpressionRewrite() - Method in class io.prestosql.sql.planner.iterative.rule.ExpressionRewriteRuleSet
 
JoinFilterFunction - Interface in io.prestosql.operator
 
JoinFilterFunctionCompiler - Class in io.prestosql.sql.gen
 
JoinFilterFunctionCompiler(Metadata) - Constructor for class io.prestosql.sql.gen.JoinFilterFunctionCompiler
 
JoinFilterFunctionCompiler.JoinFilterFunctionFactory - Interface in io.prestosql.sql.gen
 
JoinGraph - Class in io.prestosql.sql.planner.optimizations.joins
JoinGraph represents sequence of Joins, where nodes in the graph are PlanNodes that are being joined and edges are all equality join conditions between pair of nodes.
JoinGraph(PlanNode) - Constructor for class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
JoinGraph(List<PlanNode>, Multimap<PlanNodeId, JoinGraph.Edge>, PlanNodeId, List<Expression>, boolean) - Constructor for class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
JoinGraph.Edge - Class in io.prestosql.sql.planner.optimizations.joins
 
JoinHash - Class in io.prestosql.operator
 
JoinHash(PagesHash, Optional<JoinFilterFunction>, Optional<PositionLinks>) - Constructor for class io.prestosql.operator.JoinHash
 
JoinHashSupplier - Class in io.prestosql.operator
 
JoinHashSupplier(Session, PagesHashStrategy, LongArrayList, List<List<Block>>, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, Optional<Integer>, List<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>) - Constructor for class io.prestosql.operator.JoinHashSupplier
 
JoinNode - Class in io.prestosql.sql.planner.plan
 
JoinNode(PlanNodeId, JoinNode.Type, PlanNode, PlanNode, List<JoinNode.EquiJoinClause>, List<Symbol>, List<Symbol>, Optional<Expression>, Optional<Symbol>, Optional<Symbol>, Optional<JoinNode.DistributionType>, Optional<Boolean>, Map<DynamicFilterId, Symbol>, Optional<PlanNodeStatsAndCostSummary>) - Constructor for class io.prestosql.sql.planner.plan.JoinNode
 
JoinNode.DistributionType - Enum in io.prestosql.sql.planner.plan
 
JoinNode.EquiJoinClause - Class in io.prestosql.sql.planner.plan
 
JoinNode.Type - Enum in io.prestosql.sql.planner.plan
 
JoinOperatorFactory - Interface in io.prestosql.operator
 
JoinOperatorFactory.OuterOperatorFactoryResult - Class in io.prestosql.operator
 
JoinOperatorInfo - Class in io.prestosql.operator
 
JoinOperatorInfo(LookupJoinOperators.JoinType, long[], long[], Optional<Long>) - Constructor for class io.prestosql.operator.JoinOperatorInfo
 
joinPositionWithinPartition - Variable in class io.prestosql.operator.LookupJoinOperator.SavedRow
A snapshot of LookupJoinOperator.PageJoiner.joinPosition "de-partitioned", i.e.
joinPositionWithinPartition(long) - Method in class io.prestosql.operator.index.IndexLookupSource
 
joinPositionWithinPartition(long) - Method in class io.prestosql.operator.JoinHash
 
joinPositionWithinPartition(long) - Method in interface io.prestosql.operator.LookupSource
 
joinPositionWithinPartition(long) - Method in class io.prestosql.operator.OuterLookupSource
 
joinPositionWithinPartition(long) - Method in class io.prestosql.operator.PartitionedLookupSource
 
JoinProbe - Class in io.prestosql.operator
 
JoinProbe.JoinProbeFactory - Class in io.prestosql.operator
 
JoinProbeFactory(int[], List<Integer>, OptionalInt) - Constructor for class io.prestosql.operator.JoinProbe.JoinProbeFactory
 
joinSourcePositions - Variable in class io.prestosql.operator.LookupJoinOperator.SavedRow
A snapshot of LookupJoinOperator.PageJoiner.joinSourcePositions
JoinStatisticsCounter - Class in io.prestosql.operator
 
JoinStatisticsCounter(LookupJoinOperators.JoinType) - Constructor for class io.prestosql.operator.JoinStatisticsCounter
 
JoinStatsRule - Class in io.prestosql.cost
 
JoinStatsRule(FilterStatsCalculator, StatsNormalizer) - Constructor for class io.prestosql.cost.JoinStatsRule
 
JoinUtils - Class in io.prestosql.operator
This class must be public as it is accessed via join compiler reflection.
joinWith(RelationType) - Method in class io.prestosql.sql.analyzer.RelationType
Creates a new tuple descriptor containing all fields from this tuple descriptor and all fields from the specified tuple descriptor.
JONI - io.prestosql.sql.analyzer.RegexLibrary
 
JONI_REGEXP - Static variable in class io.prestosql.type.JoniRegexpType
 
joniRegexp(Slice) - Static method in class io.prestosql.operator.scalar.JoniRegexpCasts
 
JoniRegexp - Class in io.prestosql.type
 
JoniRegexp(Slice, Regex) - Constructor for class io.prestosql.type.JoniRegexp
 
JoniRegexpCasts - Class in io.prestosql.operator.scalar
 
JoniRegexpFunctions - Class in io.prestosql.operator.scalar
 
JoniRegexpReplaceLambdaFunction - Class in io.prestosql.operator.scalar
 
JoniRegexpReplaceLambdaFunction() - Constructor for class io.prestosql.operator.scalar.JoniRegexpReplaceLambdaFunction
 
JoniRegexpType - Class in io.prestosql.type
 
JoniRegexpType() - Constructor for class io.prestosql.type.JoniRegexpType
 
JSON - Static variable in class io.prestosql.type.JsonType
 
JSON_FACTORY - Static variable in class io.prestosql.operator.scalar.JsonOperators
 
JSON_FACTORY - Static variable in class io.prestosql.util.JsonUtil
 
JSON_PATH - Static variable in class io.prestosql.type.JsonPathType
 
JSON_STRING_TO_ARRAY - Static variable in class io.prestosql.operator.scalar.JsonStringToArrayCast
 
JSON_STRING_TO_ARRAY_NAME - Static variable in class io.prestosql.operator.scalar.JsonStringToArrayCast
 
JSON_STRING_TO_MAP - Static variable in class io.prestosql.operator.scalar.JsonStringToMapCast
 
JSON_STRING_TO_MAP_NAME - Static variable in class io.prestosql.operator.scalar.JsonStringToMapCast
 
JSON_STRING_TO_ROW - Static variable in class io.prestosql.operator.scalar.JsonStringToRowCast
 
JSON_STRING_TO_ROW_NAME - Static variable in class io.prestosql.operator.scalar.JsonStringToRowCast
 
JSON_TO_ARRAY - Static variable in class io.prestosql.operator.scalar.JsonToArrayCast
 
JSON_TO_DECIMAL_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
JSON_TO_MAP - Static variable in class io.prestosql.operator.scalar.JsonToMapCast
 
JSON_TO_ROW - Static variable in class io.prestosql.operator.scalar.JsonToRowCast
 
jsonArrayContains(Slice, boolean) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
jsonArrayContains(Slice, double) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
jsonArrayContains(Slice, long) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
jsonArrayContains(Slice, Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
jsonArrayGet(Slice, long) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
jsonArrayLength(Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
JsonCastException - Exception in io.prestosql.util
 
JsonCastException(String) - Constructor for exception io.prestosql.util.JsonCastException
 
jsonCreate(PartitioningHandle, List<Partitioning.ArgumentBinding>) - Static method in class io.prestosql.sql.planner.Partitioning
 
jsonCreator(StageExecutionDescriptor.StageExecutionStrategy, Set<PlanNodeId>) - Static method in class io.prestosql.operator.StageExecutionDescriptor
 
jsonCreator(String) - Static method in class io.prestosql.execution.Lifespan
 
jsonExtract(Slice, JsonPath) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
JsonExtract - Class in io.prestosql.operator.scalar
Extracts values from JSON
JsonExtract.JsonExtractor<T> - Interface in io.prestosql.operator.scalar
 
JsonExtract.JsonSizeExtractor - Class in io.prestosql.operator.scalar
 
JsonExtract.JsonValueJsonExtractor - Class in io.prestosql.operator.scalar
 
JsonExtract.ObjectFieldJsonExtractor<T> - Class in io.prestosql.operator.scalar
 
JsonExtract.ScalarValueJsonExtractor - Class in io.prestosql.operator.scalar
 
jsonExtractScalar(Slice, JsonPath) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
jsonFormat(Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
jsonFragmentPlan(PlanNode, Map<Symbol, Type>, Metadata, Session) - Static method in class io.prestosql.sql.planner.planprinter.PlanPrinter
 
JsonFunctions - Class in io.prestosql.operator.scalar
 
JsonOperators - Class in io.prestosql.operator.scalar
 
jsonParse(Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
JsonPath - Class in io.prestosql.operator.scalar
 
JsonPath(String) - Constructor for class io.prestosql.operator.scalar.JsonPath
 
JsonPathTokenizer - Class in io.prestosql.operator.scalar
 
JsonPathTokenizer(String) - Constructor for class io.prestosql.operator.scalar.JsonPathTokenizer
 
JsonPathType - Class in io.prestosql.type
 
JsonRenderedNode(String, String, String, String, List<JsonRenderer.JsonRenderedNode>, List<String>) - Constructor for class io.prestosql.sql.planner.planprinter.JsonRenderer.JsonRenderedNode
 
JsonRenderer - Class in io.prestosql.sql.planner.planprinter
 
JsonRenderer() - Constructor for class io.prestosql.sql.planner.planprinter.JsonRenderer
 
JsonRenderer.JsonRenderedNode - Class in io.prestosql.sql.planner.planprinter
 
jsonSize(Slice, JsonPath) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
JsonSizeExtractor() - Constructor for class io.prestosql.operator.scalar.JsonExtract.JsonSizeExtractor
 
JsonStringToArrayCast - Class in io.prestosql.operator.scalar
 
JsonStringToMapCast - Class in io.prestosql.operator.scalar
 
JsonStringToRowCast - Class in io.prestosql.operator.scalar
 
JsonToArrayCast - Class in io.prestosql.operator.scalar
 
jsonToLongDecimal(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
JsonToMapCast - Class in io.prestosql.operator.scalar
 
JsonToRowCast - Class in io.prestosql.operator.scalar
 
jsonToShortDecimal(Slice, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
JsonType - Class in io.prestosql.type
The stack representation for JSON objects must have the keys in natural sorted order.
JsonType() - Constructor for class io.prestosql.type.JsonType
 
JsonUtil - Class in io.prestosql.util
 
JsonUtil.BlockBuilderAppender - Interface in io.prestosql.util
 
JsonUtil.JsonGeneratorWriter - Interface in io.prestosql.util
 
JsonUtil.ObjectKeyProvider - Interface in io.prestosql.util
 
JsonValueJsonExtractor() - Constructor for class io.prestosql.operator.scalar.JsonExtract.JsonValueJsonExtractor
 
JwkDecoder - Class in io.prestosql.server.security.jwt
 
JwkDecoder.JwkEcPublicKey - Class in io.prestosql.server.security.jwt
 
JwkDecoder.JwkPublicKey - Interface in io.prestosql.server.security.jwt
 
JwkDecoder.JwkRsaPublicKey - Class in io.prestosql.server.security.jwt
 
JwkDecoder.Keys - Class in io.prestosql.server.security.jwt
 
JwkEcPublicKey(String, ECParameterSpec, ECPoint) - Constructor for class io.prestosql.server.security.jwt.JwkDecoder.JwkEcPublicKey
 
JwkRsaPublicKey(String, BigInteger, BigInteger) - Constructor for class io.prestosql.server.security.jwt.JwkDecoder.JwkRsaPublicKey
 
JwkService - Class in io.prestosql.server.security.jwt
 
JwkService(JwtAuthenticatorConfig, HttpClient) - Constructor for class io.prestosql.server.security.jwt.JwkService
 
JwkService(URI, HttpClient, Duration) - Constructor for class io.prestosql.server.security.jwt.JwkService
 
JwkSigningKeyResolver - Class in io.prestosql.server.security.jwt
 
JwkSigningKeyResolver(JwkService) - Constructor for class io.prestosql.server.security.jwt.JwkSigningKeyResolver
 
JwtAuthenticator - Class in io.prestosql.server.security.jwt
 
JwtAuthenticator(JwtAuthenticatorConfig, SigningKeyResolver) - Constructor for class io.prestosql.server.security.jwt.JwtAuthenticator
 
JwtAuthenticatorConfig - Class in io.prestosql.server.security.jwt
 
JwtAuthenticatorConfig() - Constructor for class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
JwtAuthenticatorSupportModule - Class in io.prestosql.server.security.jwt
 
JwtAuthenticatorSupportModule() - Constructor for class io.prestosql.server.security.jwt.JwtAuthenticatorSupportModule
 

K

KerberosAuthenticator - Class in io.prestosql.server.security
 
KerberosAuthenticator(KerberosConfig) - Constructor for class io.prestosql.server.security.KerberosAuthenticator
 
KerberosConfig - Class in io.prestosql.server.security
 
KerberosConfig() - Constructor for class io.prestosql.server.security.KerberosConfig
 
KerberosNameType - Enum in io.prestosql.server.security
 
key - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
The array of keys.
key - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
The array of keys.
KeyAndBlockPositionValueState - Interface in io.prestosql.operator.aggregation.minmaxby
Used for MinMaxBy aggregation states where value's native container type is Block or Slice.
KeyAndBlockPositionValueStateSerializer<T extends KeyAndBlockPositionValueState> - Class in io.prestosql.operator.aggregation.minmaxby
 
keys - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
Cached set of keys.
Keys(List<Map<String, String>>) - Constructor for class io.prestosql.server.security.jwt.JwkDecoder.Keys
 
keySet() - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
KeyValuePairs - Class in io.prestosql.operator.aggregation
 
KeyValuePairs(Block, Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, Type) - Constructor for class io.prestosql.operator.aggregation.KeyValuePairs
 
KeyValuePairs(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, Type) - Constructor for class io.prestosql.operator.aggregation.KeyValuePairs
 
KeyValuePairsState - Interface in io.prestosql.operator.aggregation.state
 
KeyValuePairsStateFactory - Class in io.prestosql.operator.aggregation.state
 
KeyValuePairsStateFactory(Type, Type) - Constructor for class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory
 
KeyValuePairsStateFactory.GroupedState - Class in io.prestosql.operator.aggregation.state
 
KeyValuePairsStateFactory.SingleState - Class in io.prestosql.operator.aggregation.state
 
KeyValuePairStateSerializer - Class in io.prestosql.operator.aggregation.state
 
KeyValuePairStateSerializer(MapType, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode) - Constructor for class io.prestosql.operator.aggregation.state.KeyValuePairStateSerializer
 
KILL_QUERY - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
killQuery(QueryId, String, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.QueryResource
 
killQuery(QueryId, String, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.ui.UiQueryResource
 
killQuery(String, String, ConnectorSession) - Method in class io.prestosql.connector.system.KillQueryProcedure
 
KillQueryProcedure - Class in io.prestosql.connector.system
 
KillQueryProcedure(Optional<DispatchManager>, AccessControl) - Constructor for class io.prestosql.connector.system.KillQueryProcedure
 
kurtosis(CentralMomentsState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.CentralMomentsAggregation
 

L

LagFunction - Class in io.prestosql.operator.window
 
LagFunction(List<Integer>, boolean) - Constructor for class io.prestosql.operator.window.LagFunction
 
LAMBDA_CAPTURE_METHOD - Static variable in class io.prestosql.sql.gen.LambdaCapture
 
LambdaBytecodeGenerator - Class in io.prestosql.sql.gen
 
lambdaCapture(MethodHandles.Lookup, String, MethodType, MethodType, MethodHandle, MethodType) - Static method in class io.prestosql.sql.gen.LambdaCapture
 
LambdaCapture - Class in io.prestosql.sql.gen
 
LambdaCaptureDesugaringRewriter - Class in io.prestosql.sql.planner.iterative.rule
 
LambdaDefinitionExpression - Class in io.prestosql.sql.relational
 
LambdaDefinitionExpression(List<Type>, List<String>, RowExpression) - Constructor for class io.prestosql.sql.relational.LambdaDefinitionExpression
 
LambdaExpressionExtractor - Class in io.prestosql.sql.gen
 
LambdaFunctionInterface - Interface in io.prestosql.sql.gen.lambda
 
LambdaProvider - Interface in io.prestosql.operator.aggregation
 
largePrecision(long, LongTimestamp, Slice) - Static method in class io.prestosql.operator.scalar.timestamp.WithTimeZone
 
lastDayOfMonth(long) - Static method in class io.prestosql.operator.scalar.timestamp.LastDayOfMonth
 
lastDayOfMonth(long) - Static method in class io.prestosql.operator.scalar.timestamptz.LastDayOfMonth
 
lastDayOfMonth(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.LastDayOfMonth
 
lastDayOfMonth(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.LastDayOfMonth
 
LastDayOfMonth - Class in io.prestosql.operator.scalar.timestamp
 
LastDayOfMonth - Class in io.prestosql.operator.scalar.timestamptz
 
lastDayOfMonthFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
lastLong() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
 
lastRun - Variable in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
LastValueFunction - Class in io.prestosql.operator.window
 
LastValueFunction(List<Integer>, boolean) - Constructor for class io.prestosql.operator.window.LastValueFunction
 
LATE_MATERIALIZATION - Static variable in class io.prestosql.SystemSessionProperties
 
LazyAccumulatorFactoryBinder - Class in io.prestosql.operator.aggregation
 
LazyAccumulatorFactoryBinder(AggregationMetadata, DynamicClassLoader) - Constructor for class io.prestosql.operator.aggregation.LazyAccumulatorFactoryBinder
 
LazyOutputBuffer - Class in io.prestosql.execution.buffer
 
LazyOutputBuffer(TaskId, String, Executor, DataSize, DataSize, Supplier<LocalMemoryContext>, Runnable) - Constructor for class io.prestosql.execution.buffer.LazyOutputBuffer
 
LeadFunction - Class in io.prestosql.operator.window
 
LeadFunction(List<Integer>, boolean) - Constructor for class io.prestosql.operator.window.LeadFunction
 
Least - Class in io.prestosql.operator.scalar
 
Least() - Constructor for class io.prestosql.operator.scalar.Least
 
LEAST - Static variable in class io.prestosql.operator.scalar.Least
 
LEFT - io.prestosql.sql.planner.plan.CorrelatedJoinNode.Type
 
LEFT - io.prestosql.sql.planner.plan.JoinNode.Type
 
LEFT - io.prestosql.sql.planner.plan.SpatialJoinNode.Type
 
LEFT - io.prestosql.util.HeapTraversal.Child
 
leftPad(Slice, long, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
leftPad(Slice, long, Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
leftTrim(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
leftTrim(Slice, int[]) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
LegacyResourceGroupConfigurationManager - Class in io.prestosql.execution.resourcegroups
 
LegacyResourceGroupConfigurationManager(QueryManagerConfig) - Constructor for class io.prestosql.execution.resourcegroups.LegacyResourceGroupConfigurationManager
 
lendPagesSpatialIndex(Supplier<PagesSpatialIndex>) - Method in class io.prestosql.operator.PagesSpatialIndexFactory
Called by SpatialIndexBuilderOperator to provide a Supplier of spatial indexes for SpatialJoinOperators to use.
lendPartitionLookupSource(int, Supplier<LookupSource>) - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
length - Variable in class io.prestosql.util.LongBigArrayFIFOQueue
The current (cached) length of LongBigArrayFIFOQueue.array.
length() - Method in class io.prestosql.cost.StatisticRange
 
length(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
length(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
lessThan(int, int) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
lessThan(Block, int, Block, int) - Method in interface io.prestosql.type.BlockTypeOperators.BlockPositionLessThan
 
levenshteinDistance(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
Lifespan - Class in io.prestosql.execution
 
lifespanFinished(Lifespan) - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
lifespanFinished(Lifespan) - Method in interface io.prestosql.operator.WorkProcessorOperatorFactory
 
LifespanScheduler - Interface in io.prestosql.execution.scheduler.group
 
LIKE_PATTERN - Static variable in class io.prestosql.type.LikePatternType
 
LIKE_PATTERN_FUNCTION_NAME - Static variable in class io.prestosql.type.LikeFunctions
 
likeChar(Long, Slice, JoniRegexp) - Static method in class io.prestosql.type.LikeFunctions
 
LikeFunctions - Class in io.prestosql.type
 
likePattern(Slice) - Static method in class io.prestosql.type.LikeFunctions
 
likePattern(Slice, Slice) - Static method in class io.prestosql.type.LikeFunctions
 
likePattern(Long, Slice) - Static method in class io.prestosql.type.LikeFunctions
 
LikePatternType - Class in io.prestosql.type
 
likeVarchar(Slice, JoniRegexp) - Static method in class io.prestosql.type.LikeFunctions
 
limit() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
Limit() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Limit
 
LimitNode - Class in io.prestosql.sql.planner.plan
 
LimitNode(PlanNodeId, PlanNode, long, boolean) - Constructor for class io.prestosql.sql.planner.plan.LimitNode
 
LimitNode(PlanNodeId, PlanNode, long, Optional<OrderingScheme>, boolean) - Constructor for class io.prestosql.sql.planner.plan.LimitNode
 
LimitOperator - Class in io.prestosql.operator
 
LimitOperator(OperatorContext, long) - Constructor for class io.prestosql.operator.LimitOperator
 
LimitOperator.LimitOperatorFactory - Class in io.prestosql.operator
 
LimitOperatorFactory(int, PlanNodeId, long) - Constructor for class io.prestosql.operator.LimitOperator.LimitOperatorFactory
 
LimitPushDown - Class in io.prestosql.sql.planner.optimizations
 
LimitPushDown() - Constructor for class io.prestosql.sql.planner.optimizations.LimitPushDown
 
LimitStatsRule - Class in io.prestosql.cost
 
LimitStatsRule(StatsNormalizer) - Constructor for class io.prestosql.cost.LimitStatsRule
 
link(int, int) - Method in class io.prestosql.operator.ArrayPositionLinks.FactoryBuilder
 
link(int, int) - Method in interface io.prestosql.operator.PositionLinks.FactoryBuilder
 
link(int, int) - Method in class io.prestosql.operator.SortedPositionLinks.FactoryBuilder
 
list() - Method in class io.prestosql.metadata.FunctionRegistry
 
listAllRoleGrants(Session, String, Optional<Set<String>>, Optional<Set<String>>, OptionalLong) - Method in interface io.prestosql.metadata.Metadata
List all role grants in the specified catalog, optionally filtered by passed role, grantee, and limit predicates.
listAllRoleGrants(Session, String, Optional<Set<String>>, Optional<Set<String>>, OptionalLong) - Method in class io.prestosql.metadata.MetadataManager
 
listApplicableRoles(Session, PrestoPrincipal, String) - Method in interface io.prestosql.metadata.Metadata
List applicable roles, including the transitive grants, for the specified principal
listApplicableRoles(Session, PrestoPrincipal, String) - Method in class io.prestosql.metadata.MetadataManager
 
listCatalogs(Session, Metadata, AccessControl) - Static method in class io.prestosql.metadata.MetadataListing
 
listCatalogs(Session, Metadata, AccessControl, Optional<String>) - Static method in class io.prestosql.metadata.MetadataListing
 
listConnectorIds() - Method in class io.prestosql.metadata.CatalogMetadata
 
listEnabledRoles(Session, String) - Method in interface io.prestosql.metadata.Metadata
List applicable roles, including the transitive grants, in given session
listEnabledRoles(Session, String) - Method in class io.prestosql.metadata.MetadataManager
 
listFunctions() - Method in interface io.prestosql.metadata.Metadata
 
listFunctions() - Method in class io.prestosql.metadata.MetadataManager
 
listOfListsCopy(List<List<T>>) - Static method in class io.prestosql.util.MoreLists
 
listPartitionHandles(Session, PartitioningHandle) - Method in class io.prestosql.sql.planner.NodePartitioningManager
 
listRoleGrants(Session, String, PrestoPrincipal) - Method in interface io.prestosql.metadata.Metadata
List roles grants in the specified catalog for a given principal, not recursively.
listRoleGrants(Session, String, PrestoPrincipal) - Method in class io.prestosql.metadata.MetadataManager
 
listRoles(Session, String) - Method in interface io.prestosql.metadata.Metadata
List available roles in specified catalog.
listRoles(Session, String) - Method in class io.prestosql.metadata.MetadataManager
 
listSchemaNames(Session, String) - Method in interface io.prestosql.metadata.Metadata
 
listSchemaNames(Session, String) - Method in class io.prestosql.metadata.MetadataManager
 
listSchemaNames(ConnectorSession) - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
listSchemaNames(ConnectorSession) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
listSchemaNames(ConnectorSession) - Method in class io.prestosql.testing.TestingMetadata
 
listSchemas(Session, Metadata, AccessControl, String) - Static method in class io.prestosql.metadata.MetadataListing
 
listSchemas(Session, Metadata, AccessControl, String, Optional<String>) - Static method in class io.prestosql.metadata.MetadataListing
 
listSystemTables(ConnectorSession) - Method in class io.prestosql.connector.system.CoordinatorSystemTablesProvider
 
listSystemTables(ConnectorSession) - Method in class io.prestosql.connector.system.StaticSystemTablesProvider
 
listSystemTables(ConnectorSession) - Method in interface io.prestosql.connector.system.SystemTablesProvider
 
listTableColumns(Session, Metadata, AccessControl, QualifiedTablePrefix) - Static method in class io.prestosql.metadata.MetadataListing
 
listTableColumns(Session, QualifiedTablePrefix) - Method in interface io.prestosql.metadata.Metadata
Gets the metadata for all columns that match the specified table prefix.
listTableColumns(Session, QualifiedTablePrefix) - Method in class io.prestosql.metadata.MetadataManager
 
listTableColumns(ConnectorSession, SchemaTablePrefix) - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
listTableColumns(ConnectorSession, SchemaTablePrefix) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
listTableColumns(ConnectorSession, SchemaTablePrefix) - Method in class io.prestosql.testing.TestingMetadata
 
listTablePrivileges(Session, Metadata, AccessControl, QualifiedTablePrefix) - Static method in class io.prestosql.metadata.MetadataListing
 
listTablePrivileges(Session, QualifiedTablePrefix) - Method in interface io.prestosql.metadata.Metadata
Gets the privileges for the specified table available to the given grantee considering the selected session role
listTablePrivileges(Session, QualifiedTablePrefix) - Method in class io.prestosql.metadata.MetadataManager
 
listTables(Session, Metadata, AccessControl, QualifiedTablePrefix) - Static method in class io.prestosql.metadata.MetadataListing
 
listTables(Session, QualifiedTablePrefix) - Method in interface io.prestosql.metadata.Metadata
Get the names that match the specified table prefix (never null).
listTables(Session, QualifiedTablePrefix) - Method in class io.prestosql.metadata.MetadataManager
 
listTables(Session, String, String) - Method in class io.prestosql.testing.LocalQueryRunner
 
listTables(Session, String, String) - Method in interface io.prestosql.testing.QueryRunner
 
listTables(ConnectorSession, Optional<String>) - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
listTables(ConnectorSession, Optional<String>) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
listTables(ConnectorSession, Optional<String>) - Method in class io.prestosql.testing.TestingMetadata
 
listViews(Session, Metadata, AccessControl, QualifiedTablePrefix) - Static method in class io.prestosql.metadata.MetadataListing
 
listViews(Session, QualifiedTablePrefix) - Method in interface io.prestosql.metadata.Metadata
Get the names that match the specified table prefix (never null).
listViews(Session, QualifiedTablePrefix) - Method in class io.prestosql.metadata.MetadataManager
 
listViews(ConnectorSession, Optional<String>) - Method in class io.prestosql.testing.TestingMetadata
 
LITERAL_FUNCTION_NAME - Static variable in class io.prestosql.metadata.LiteralFunction
 
LiteralEncoder - Class in io.prestosql.sql.planner
 
LiteralEncoder(Metadata) - Constructor for class io.prestosql.sql.planner.LiteralEncoder
 
LiteralFunction - Class in io.prestosql.metadata
 
LiteralFunction(Supplier<BlockEncodingSerde>) - Constructor for class io.prestosql.metadata.LiteralFunction
 
LiteralImplementationDependency - Class in io.prestosql.operator.annotations
 
LiteralImplementationDependency(String) - Constructor for class io.prestosql.operator.annotations.LiteralImplementationDependency
 
LiteralInterpreter - Class in io.prestosql.sql.planner
 
ln(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
load() - Method in class io.prestosql.operator.PartitionedConsumption.Partition
 
loadCatalogs() - Method in class io.prestosql.metadata.StaticCatalogStore
 
loadCertificateAuthenticator() - Method in class io.prestosql.server.security.CertificateAuthenticatorManager
 
loadConfigurationManager() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
loadConfigurationManager() - Method in class io.prestosql.execution.resourcegroups.NoOpResourceGroupManager
 
loadConfigurationManager() - Method in interface io.prestosql.execution.resourcegroups.ResourceGroupManager
 
loadConfigurationManager() - Method in class io.prestosql.server.SessionPropertyDefaults
 
loadConfiguredGroupProvider() - Method in class io.prestosql.security.GroupProviderManager
 
loadConstant(Binding) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
loadConstant(CallSiteBinder, Object, Class<?>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
loadEventListeners() - Method in class io.prestosql.eventlistener.EventListenerManager
 
loadEventListeners() - Method in class io.prestosql.testing.LocalQueryRunner
 
loadKeyFile(File) - Static method in class io.prestosql.server.security.jwt.FileSigningKeyResolver
 
loadPasswordAuthenticator() - Method in class io.prestosql.server.security.PasswordAuthenticatorManager
 
loadPlugins() - Method in class io.prestosql.server.PluginManager
 
loadSystemAccessControl() - Method in class io.prestosql.security.AccessControlManager
 
loadSystemAccessControl(String, Map<String, String>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
local(List<? extends LocalProperty<Symbol>>) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
LOCAL - io.prestosql.sql.planner.plan.ExchangeNode.Scope
 
LocalCoordinatorLocation - Class in io.prestosql.dispatcher
 
LocalCoordinatorLocation() - Constructor for class io.prestosql.dispatcher.LocalCoordinatorLocation
 
LocalCostEstimate - Class in io.prestosql.cost
Represents inherent cost of some plan node, not including cost of its sources.
LocalCostEstimate(double, double, double) - Constructor for class io.prestosql.cost.LocalCostEstimate
 
LocalDispatchQuery - Class in io.prestosql.dispatcher
 
LocalDispatchQuery(QueryStateMachine, ListenableFuture<QueryExecution>, QueryMonitor, ClusterSizeMonitor, Executor, Consumer<QueryExecution>) - Constructor for class io.prestosql.dispatcher.LocalDispatchQuery
 
LocalDispatchQueryFactory - Class in io.prestosql.dispatcher
 
LocalDispatchQueryFactory(QueryManager, TransactionManager, AccessControl, Metadata, QueryMonitor, LocationFactory, Map<Class<? extends Statement>, QueryExecution.QueryExecutionFactory<?>>, WarningCollectorFactory, ClusterSizeMonitor, DispatchExecutor) - Constructor for class io.prestosql.dispatcher.LocalDispatchQueryFactory
 
LocalDynamicFilterConsumer - Class in io.prestosql.sql.planner
 
LocalDynamicFilterConsumer(Map<DynamicFilterId, Integer>, Map<DynamicFilterId, Type>, int) - Constructor for class io.prestosql.sql.planner.LocalDynamicFilterConsumer
 
LocalExchange - Class in io.prestosql.operator.exchange
 
LocalExchange(int, int, PartitioningHandle, List<? extends Type>, List<Integer>, Optional<Integer>, DataSize, BlockTypeOperators) - Constructor for class io.prestosql.operator.exchange.LocalExchange
 
LocalExchange.LocalExchangeFactory - Class in io.prestosql.operator.exchange
 
LocalExchange.LocalExchangeSinkFactory - Class in io.prestosql.operator.exchange
 
LocalExchange.LocalExchangeSinkFactoryId - Class in io.prestosql.operator.exchange
 
LocalExchangeBufferInfo - Class in io.prestosql.operator.exchange
 
LocalExchangeBufferInfo(long, int) - Constructor for class io.prestosql.operator.exchange.LocalExchangeBufferInfo
 
LocalExchangeFactory(PartitioningHandle, int, List<Type>, List<Integer>, Optional<Integer>, PipelineExecutionStrategy, DataSize, BlockTypeOperators) - Constructor for class io.prestosql.operator.exchange.LocalExchange.LocalExchangeFactory
 
LocalExchangeMemoryManager - Class in io.prestosql.operator.exchange
 
LocalExchangeMemoryManager(long) - Constructor for class io.prestosql.operator.exchange.LocalExchangeMemoryManager
 
LocalExchanger - Interface in io.prestosql.operator.exchange
 
LocalExchangeSink - Class in io.prestosql.operator.exchange
 
LocalExchangeSink(LocalExchanger, Consumer<LocalExchangeSink>) - Constructor for class io.prestosql.operator.exchange.LocalExchangeSink
 
LocalExchangeSinkFactoryId(int) - Constructor for class io.prestosql.operator.exchange.LocalExchange.LocalExchangeSinkFactoryId
 
LocalExchangeSinkOperator - Class in io.prestosql.operator.exchange
 
LocalExchangeSinkOperator.LocalExchangeSinkOperatorFactory - Class in io.prestosql.operator.exchange
 
LocalExchangeSinkOperatorFactory(LocalExchange.LocalExchangeFactory, int, PlanNodeId, LocalExchange.LocalExchangeSinkFactoryId, Function<Page, Page>) - Constructor for class io.prestosql.operator.exchange.LocalExchangeSinkOperator.LocalExchangeSinkOperatorFactory
 
LocalExchangeSource - Class in io.prestosql.operator.exchange
 
LocalExchangeSource(Consumer<LocalExchangeSource>) - Constructor for class io.prestosql.operator.exchange.LocalExchangeSource
 
LocalExchangeSourceOperator - Class in io.prestosql.operator.exchange
 
LocalExchangeSourceOperator(OperatorContext, LocalExchangeSource) - Constructor for class io.prestosql.operator.exchange.LocalExchangeSourceOperator
 
LocalExchangeSourceOperator.LocalExchangeSourceOperatorFactory - Class in io.prestosql.operator.exchange
 
LocalExchangeSourceOperatorFactory(int, PlanNodeId, LocalExchange.LocalExchangeFactory) - Constructor for class io.prestosql.operator.exchange.LocalExchangeSourceOperator.LocalExchangeSourceOperatorFactory
 
LocalExecutionPlan(List<DriverFactory>, List<PlanNodeId>, StageExecutionDescriptor) - Constructor for class io.prestosql.sql.planner.LocalExecutionPlanner.LocalExecutionPlan
 
LocalExecutionPlanner - Class in io.prestosql.sql.planner
 
LocalExecutionPlanner(Metadata, TypeAnalyzer, Optional<ExplainAnalyzeContext>, PageSourceProvider, IndexManager, NodePartitioningManager, PageSinkManager, ExchangeClientSupplier, ExpressionCompiler, PageFunctionCompiler, JoinFilterFunctionCompiler, IndexJoinLookupStats, TaskManagerConfig, SpillerFactory, SingleStreamSpillerFactory, PartitioningSpillerFactory, PagesIndex.Factory, JoinCompiler, LookupJoinOperators, OrderingCompiler, DynamicFilterConfig, TypeOperators, BlockTypeOperators) - Constructor for class io.prestosql.sql.planner.LocalExecutionPlanner
 
LocalExecutionPlanner.LocalExecutionPlan - Class in io.prestosql.sql.planner
 
LocalMemoryManager - Class in io.prestosql.memory
 
LocalMemoryManager(NodeMemoryConfig) - Constructor for class io.prestosql.memory.LocalMemoryManager
 
LocalMemoryManagerExporter - Class in io.prestosql.memory
 
LocalMemoryManagerExporter(LocalMemoryManager, MBeanExporter) - Constructor for class io.prestosql.memory.LocalMemoryManagerExporter
 
LocalMergeSourceOperator - Class in io.prestosql.operator.exchange
 
LocalMergeSourceOperator(OperatorContext, List<LocalExchangeSource>, List<Type>, PageWithPositionComparator) - Constructor for class io.prestosql.operator.exchange.LocalMergeSourceOperator
 
LocalMergeSourceOperator.LocalMergeSourceOperatorFactory - Class in io.prestosql.operator.exchange
 
LocalMergeSourceOperatorFactory(int, PlanNodeId, LocalExchange.LocalExchangeFactory, List<Type>, OrderingCompiler, List<Integer>, List<SortOrder>) - Constructor for class io.prestosql.operator.exchange.LocalMergeSourceOperator.LocalMergeSourceOperatorFactory
 
LocalPartitionGenerator - Class in io.prestosql.operator.exchange
 
LocalPartitionGenerator(HashGenerator, int) - Constructor for class io.prestosql.operator.exchange.LocalPartitionGenerator
 
LocalPlannerAware - Interface in io.prestosql.operator
 
localPlannerComplete() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator.LocalExchangeSinkOperatorFactory
 
localPlannerComplete() - Method in interface io.prestosql.operator.LocalPlannerAware
 
LocalProperties - Class in io.prestosql.sql.planner.optimizations
 
LocalQueryRunner - Class in io.prestosql.testing
 
LocalQueryRunner.Builder - Class in io.prestosql.testing
 
localRevocableMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
LocalSpillContext - Class in io.prestosql.spiller
 
LocalSpillContext(SpillContext) - Constructor for class io.prestosql.spiller.LocalSpillContext
 
LocalSpillManager - Class in io.prestosql.spiller
 
LocalSpillManager(NodeSpillConfig) - Constructor for class io.prestosql.spiller.LocalSpillManager
 
localSystemMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
localSystemMemoryContext() - Method in class io.prestosql.operator.PipelineContext
 
localSystemMemoryContext() - Method in class io.prestosql.operator.TaskContext
 
localTime(long, ConnectorSession, Long) - Static method in class io.prestosql.operator.scalar.time.LocalTimeFunction
 
LocalTimeFunction - Class in io.prestosql.operator.scalar.time
 
localTimestamp(long, ConnectorSession, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.LocalTimestamp
 
localTimestamp(long, ConnectorSession, Long) - Static method in class io.prestosql.operator.scalar.timestamp.LocalTimestamp
 
LocalTimestamp - Class in io.prestosql.operator.scalar.timestamp
 
localUserMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
locate(HostAddress) - Method in class io.prestosql.execution.scheduler.FileBasedNetworkTopology
 
locate(HostAddress) - Method in class io.prestosql.execution.scheduler.FlatNetworkTopology
 
locate(HostAddress) - Method in interface io.prestosql.execution.scheduler.NetworkTopology
 
locate(HostAddress) - Method in class io.prestosql.execution.scheduler.SubnetBasedTopology
 
LocationFactory - Interface in io.prestosql.execution
 
lockDownNodes() - Method in class io.prestosql.execution.scheduler.DynamicSplitPlacementPolicy
 
lockDownNodes() - Method in class io.prestosql.execution.scheduler.FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy
 
lockDownNodes() - Method in interface io.prestosql.execution.scheduler.NodeSelector
 
lockDownNodes() - Method in interface io.prestosql.execution.scheduler.SplitPlacementPolicy
 
lockDownNodes() - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
lockDownNodes() - Method in class io.prestosql.execution.scheduler.UniformNodeSelector
 
log(double, double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
log10(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
log2(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
LogicalPlanner - Class in io.prestosql.sql.planner
 
LogicalPlanner(Session, List<PlanOptimizer>, PlanNodeIdAllocator, Metadata, TypeOperators, TypeAnalyzer, StatsCalculator, CostCalculator, WarningCollector) - Constructor for class io.prestosql.sql.planner.LogicalPlanner
 
LogicalPlanner(Session, List<PlanOptimizer>, PlanSanityChecker, PlanNodeIdAllocator, Metadata, TypeOperators, TypeAnalyzer, StatsCalculator, CostCalculator, WarningCollector) - Constructor for class io.prestosql.sql.planner.LogicalPlanner
 
LogicalPlanner.Stage - Enum in io.prestosql.sql.planner
 
login(String, String, String, SecurityContext) - Method in class io.prestosql.server.ui.LoginResource
 
LoginResource - Class in io.prestosql.server.ui
 
LoginResource(FormWebUiAuthenticationFilter) - Constructor for class io.prestosql.server.ui.LoginResource
 
logout(HttpHeaders, UriInfo, SecurityContext) - Method in class io.prestosql.server.ui.LoginResource
 
logout(HttpHeaders, UriInfo, SecurityContext) - Method in class io.prestosql.server.ui.OAuth2WebUiLogoutResource
 
long2LongEntrySet() - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
Long2LongOpenBigHashMap - Class in io.prestosql.util
 
Long2LongOpenBigHashMap() - Constructor for class io.prestosql.util.Long2LongOpenBigHashMap
Creates a new hash map with initial expected BigArrays.SEGMENT_SIZE entries and Hash.DEFAULT_LOAD_FACTOR as load factor.
Long2LongOpenBigHashMap(long) - Constructor for class io.prestosql.util.Long2LongOpenBigHashMap
Creates a new hash map with Hash.DEFAULT_LOAD_FACTOR as load factor.
Long2LongOpenBigHashMap(long, float) - Constructor for class io.prestosql.util.Long2LongOpenBigHashMap
Creates a new hash map.
Long2LongOpenBigHashMap(Long2LongMap) - Constructor for class io.prestosql.util.Long2LongOpenBigHashMap
Creates a new hash map with Hash.DEFAULT_LOAD_FACTOR as load factor copying a given type-specific one.
Long2LongOpenBigHashMap(Long2LongMap, float) - Constructor for class io.prestosql.util.Long2LongOpenBigHashMap
Creates a new hash map copying a given type-specific one.
Long2LongOpenBigHashMap(Map<? extends Long, ? extends Long>) - Constructor for class io.prestosql.util.Long2LongOpenBigHashMap
Creates a new hash map with Hash.DEFAULT_LOAD_FACTOR as load factor copying a given one.
Long2LongOpenBigHashMap(Map<? extends Long, ? extends Long>, float) - Constructor for class io.prestosql.util.Long2LongOpenBigHashMap
Creates a new hash map copying a given one.
LongAndBlockPositionValueState - Interface in io.prestosql.operator.aggregation.minmaxby
 
LongAndDoubleState - Interface in io.prestosql.operator.aggregation.state
 
LongApproximateMostFrequentStateFactory - Class in io.prestosql.operator.aggregation
 
LongApproximateMostFrequentStateFactory() - Constructor for class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory
 
LongApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState - Class in io.prestosql.operator.aggregation
 
LongApproximateMostFrequentStateFactory.SingleLongApproximateMostFrequentState - Class in io.prestosql.operator.aggregation
 
LongApproximateMostFrequentStateSerializer - Class in io.prestosql.operator.aggregation
 
LongApproximateMostFrequentStateSerializer() - Constructor for class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateSerializer
 
longArrayMax(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMaxFunction
 
longArrayMin(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMinFunction
 
LongBigArrayFIFOQueue - Class in io.prestosql.util
A type-specific array-based FIFO queue, supporting also deque operations.
LongBigArrayFIFOQueue() - Constructor for class io.prestosql.util.LongBigArrayFIFOQueue
Creates a new empty queue with standard initial capacity.
LongBigArrayFIFOQueue(long) - Constructor for class io.prestosql.util.LongBigArrayFIFOQueue
Creates a new empty queue with given capacity.
LongBooleanState - Interface in io.prestosql.operator.aggregation.minmaxby
 
longDecimalToBigint(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
longDecimalToBoolean(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
longDecimalToDouble(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
longDecimalToGenericIntegerType(Slice, int, long, long) - Static method in class io.prestosql.type.DecimalSaturatedFloorCasts
 
longDecimalToInteger(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
longDecimalToJson(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
longDecimalToLongDecimal(Slice, int, int, int, int) - Static method in class io.prestosql.type.DecimalSaturatedFloorCasts
 
longDecimalToReal(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
longDecimalToShortDecimal(Slice, int, int, int, int) - Static method in class io.prestosql.type.DecimalSaturatedFloorCasts
 
longDecimalToSmallint(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
longDecimalToTinyint(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
longDecimalToVarchar(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
LongDecimalWithOverflowAndLongState - Interface in io.prestosql.operator.aggregation.state
 
LongDecimalWithOverflowAndLongStateFactory - Class in io.prestosql.operator.aggregation.state
 
LongDecimalWithOverflowAndLongStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory
 
LongDecimalWithOverflowAndLongStateFactory.GroupedLongDecimalWithOverflowAndLongState - Class in io.prestosql.operator.aggregation.state
 
LongDecimalWithOverflowAndLongStateFactory.SingleLongDecimalWithOverflowAndLongState - Class in io.prestosql.operator.aggregation.state
 
LongDecimalWithOverflowAndLongStateSerializer - Class in io.prestosql.operator.aggregation.state
 
LongDecimalWithOverflowAndLongStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateSerializer
 
LongDecimalWithOverflowState - Interface in io.prestosql.operator.aggregation.state
 
LongDecimalWithOverflowStateFactory - Class in io.prestosql.operator.aggregation.state
 
LongDecimalWithOverflowStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory
 
LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState - Class in io.prestosql.operator.aggregation.state
 
LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState - Class in io.prestosql.operator.aggregation.state
 
LongDecimalWithOverflowStateSerializer - Class in io.prestosql.operator.aggregation.state
 
LongDecimalWithOverflowStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateSerializer
 
LongDoubleState - Interface in io.prestosql.operator.aggregation.minmaxby
 
longElementAt(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayElementAtFunction
 
longGreaterThanZero(long) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
LongLong2LongOpenCustomBigHashMap - Class in io.prestosql.util
 
LongLong2LongOpenCustomBigHashMap(long, float, LongLong2LongOpenCustomBigHashMap.HashStrategy) - Constructor for class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Creates a new hash map.
LongLong2LongOpenCustomBigHashMap(long, LongLong2LongOpenCustomBigHashMap.HashStrategy) - Constructor for class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Creates a new hash map with Hash.DEFAULT_LOAD_FACTOR as load factor.
LongLong2LongOpenCustomBigHashMap(LongLong2LongOpenCustomBigHashMap.HashStrategy) - Constructor for class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Creates a new hash map with initial expected BigArrays.SEGMENT_SIZE entries and Hash.DEFAULT_LOAD_FACTOR as load factor.
LongLong2LongOpenCustomBigHashMap.HashStrategy - Interface in io.prestosql.util
 
LongLongState - Interface in io.prestosql.operator.aggregation.minmaxby
 
longSize() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
 
LongState - Interface in io.prestosql.operator.aggregation.state
 
longSubscript(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
LongSumAggregation - Class in io.prestosql.operator.aggregation
 
longTime(long, ConnectorSession, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.CurrentTime
 
longTimestamp(long, long) - Static method in class io.prestosql.type.DateTimes
 
longTimestamp(long, ConnectorSession, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.CurrentTimestamp
 
longTimestamp(long, Instant) - Static method in class io.prestosql.type.DateTimes
 
longTimestampWithTimeZone(long, long, ZoneId) - Static method in class io.prestosql.type.DateTimes
 
longTimestampWithTimeZone(long, Instant, TimeZoneKey) - Static method in class io.prestosql.type.DateTimes
 
LongToBooleanFunction - Interface in io.prestosql.operator.scalar
 
longToLong(long, long, ConnectorSession, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimestampWithTimeZoneCast
 
longToLong(long, ConnectorSession, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimeWithTimeZoneCast
 
longToLong(long, ConnectorSession, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamp.TimeWithTimeZoneToTimestampCast
 
longToLong(long, ConnectorSession, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToTimestampWithTimeZoneCast
 
longToLong(long, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimestampCast
 
longToLong(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimestampCast
 
longToLong(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimestampWithTimeZoneCast
 
longToLong(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimeWithTimeZoneCast
 
longToLong(long, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToTimeWithTimeZoneCast
 
longToShort(long, ConnectorSession, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimestampWithTimeZoneCast
 
longToShort(long, ConnectorSession, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimeWithTimeZoneCast
 
longToShort(long, ConnectorSession, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamp.TimeWithTimeZoneToTimestampCast
 
longToShort(long, ConnectorSession, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToTimestampWithTimeZoneCast
 
longToShort(long, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimestampCast
 
longToShort(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimestampCast
 
longToShort(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimestampWithTimeZoneCast
 
longToShort(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimeWithTimeZoneCast
 
longToShort(long, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToTimeWithTimeZoneCast
 
longValue - Variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.SingleLongDecimalWithOverflowAndLongState
 
LongVariableConstraint - Class in io.prestosql.metadata
 
LongVariableConstraint(String, String) - Constructor for class io.prestosql.metadata.LongVariableConstraint
 
longVariableConstraints(LongVariableConstraint...) - Method in class io.prestosql.metadata.SignatureBuilder
 
longVariableConstraints(List<LongVariableConstraint>) - Method in class io.prestosql.metadata.SignatureBuilder
 
longVariableExpression(String, String) - Static method in class io.prestosql.metadata.Signature
 
Lookup - Interface in io.prestosql.sql.planner.iterative
 
LOOKUP_OUTER - io.prestosql.operator.LookupJoinOperators.JoinType
 
LOOKUP_SOURCE_BUILT - io.prestosql.operator.HashBuilderOperator.State
LookupSource has been built and passed on without any spill occurring
lookupAllAtOnce(PartitionedLookupSourceFactory) - Static method in class io.prestosql.operator.JoinBridgeManager
 
LookupJoinOperator - Class in io.prestosql.operator
 
LookupJoinOperator.SavedRow - Class in io.prestosql.operator
 
LookupJoinOperator.SpillInfoSnapshot - Class in io.prestosql.operator
 
LookupJoinOperatorFactory - Class in io.prestosql.operator
 
LookupJoinOperatorFactory(int, PlanNodeId, JoinBridgeManager<? extends LookupSourceFactory>, List<Type>, List<Type>, List<Type>, LookupJoinOperators.JoinType, JoinProbe.JoinProbeFactory, BlockTypeOperators, OptionalInt, List<Integer>, OptionalInt, PartitioningSpillerFactory) - Constructor for class io.prestosql.operator.LookupJoinOperatorFactory
 
LookupJoinOperators - Class in io.prestosql.operator
 
LookupJoinOperators() - Constructor for class io.prestosql.operator.LookupJoinOperators
 
LookupJoinOperators.JoinType - Enum in io.prestosql.operator
 
LookupJoinPageBuilder - Class in io.prestosql.operator
This page builder creates pages with dictionary blocks: normal dictionary blocks for the probe side and the original blocks for the build side.
LookupJoinPageBuilder(List<Type>) - Constructor for class io.prestosql.operator.LookupJoinPageBuilder
 
lookupOuterJoin(int, PlanNodeId, JoinBridgeManager<? extends LookupSourceFactory>, List<Type>, List<Integer>, OptionalInt, Optional<List<Integer>>, OptionalInt, PartitioningSpillerFactory, BlockTypeOperators) - Method in class io.prestosql.operator.LookupJoinOperators
 
LookupOuterOperator - Class in io.prestosql.operator
 
LookupOuterOperator(OperatorContext, ListenableFuture<OuterPositionIterator>, List<Type>, List<Type>, Runnable) - Constructor for class io.prestosql.operator.LookupOuterOperator
 
LookupOuterOperator.LookupOuterOperatorFactory - Class in io.prestosql.operator
 
LookupOuterOperatorFactory(int, PlanNodeId, List<Type>, List<Type>, JoinBridgeManager<?>) - Constructor for class io.prestosql.operator.LookupOuterOperator.LookupOuterOperatorFactory
 
LookupSource - Interface in io.prestosql.operator
 
LookupSourceFactory - Interface in io.prestosql.operator
 
LookupSourceProvider - Interface in io.prestosql.operator
 
LookupSourceProvider.LookupSourceLease - Interface in io.prestosql.operator
 
LookupSourceSupplier - Interface in io.prestosql.operator
 
LookupSourceSupplierFactory(Class<? extends LookupSourceSupplier>, JoinCompiler.PagesHashStrategyFactory) - Constructor for class io.prestosql.sql.gen.JoinCompiler.LookupSourceSupplierFactory
 
LookupSymbolResolver - Class in io.prestosql.sql.planner
 
LookupSymbolResolver(Map<Symbol, ColumnHandle>, Map<ColumnHandle, NullableValue>) - Constructor for class io.prestosql.sql.planner.LookupSymbolResolver
 
lower(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
LowMemoryKiller - Interface in io.prestosql.memory
 
LowMemoryKiller.QueryMemoryInfo - Class in io.prestosql.memory
 
LuhnCheck(Slice) - Static method in class io.prestosql.operator.scalar.LuhnCheckFunction
 
LuhnCheckFunction - Class in io.prestosql.operator.scalar
 

M

MAGENTA - io.prestosql.operator.scalar.ColorFunctions.SystemColor
 
main(String[]) - Static method in class io.prestosql.util.GenerateTimeZoneIndex
 
makeClassName(String) - Static method in class io.prestosql.util.CompilerUtils
 
makeClassName(String, Optional<String>) - Static method in class io.prestosql.util.CompilerUtils
 
makeCompatiblePartitioning(Session, TableHandle, PartitioningHandle) - Method in interface io.prestosql.metadata.Metadata
Return a table handle whose partitioning is converted to the provided partitioning handle, but otherwise identical to the provided table handle.
makeCompatiblePartitioning(Session, TableHandle, PartitioningHandle) - Method in class io.prestosql.metadata.MetadataManager
 
makeServicePrincipal(String, String) - Method in enum io.prestosql.server.security.KerberosNameType
 
makeSetContainmentPlanForAll(SetOperationNode) - Method in class io.prestosql.sql.planner.iterative.rule.SetOperationNodeTranslator
 
makeSetContainmentPlanForDistinct(SetOperationNode) - Method in class io.prestosql.sql.planner.iterative.rule.SetOperationNodeTranslator
 
makeSlug(Slug.Context, long) - Method in class io.prestosql.server.protocol.Slug
 
ManagedQueryExecution - Interface in io.prestosql.execution
 
MANAGEMENT_READ - io.prestosql.server.security.ResourceSecurity.AccessType
 
MANAGEMENT_WRITE - io.prestosql.server.security.ResourceSecurity.AccessType
 
managementReadResource(AnnotatedElement) - Method in class io.prestosql.server.security.ResourceSecurityBinder
 
managementWriteResource(AnnotatedElement) - Method in class io.prestosql.server.security.ResourceSecurityBinder
 
mangleOperatorName(OperatorType) - Static method in class io.prestosql.metadata.Signature
 
manipulateAdjacentWindowNodes(WindowNode, WindowNode, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.GatherAndMergeWindows.MergeAdjacentWindowsOverProjects
 
manipulateAdjacentWindowNodes(WindowNode, WindowNode, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.GatherAndMergeWindows.SwapAdjacentWindowsBySpecifications
 
map() - Method in class io.prestosql.operator.scalar.EmptyMapConstructor
 
map(Scope, CachedInstanceBinder, Type, Type, Variable, FunctionMetadata, Function<InvocationConvention, FunctionInvoker>) - Static method in class io.prestosql.sql.gen.ArrayGeneratorUtils
 
map(Scope, CallSiteBinder, BytecodeExpression, Type, Type, Function<BytecodeExpression, BytecodeExpression>) - Static method in class io.prestosql.sql.gen.ArrayGeneratorUtils
 
map(Scope, CallSiteBinder, Type, Type, BytecodeExpression, Function<BytecodeExpression, BytecodeExpression>) - Static method in class io.prestosql.sql.gen.ArrayGeneratorUtils
 
map(OrderingScheme) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(PartitioningScheme, List<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(AggregationNode.Aggregation) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(AggregationNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(AggregationNode, PlanNode, PlanNodeId) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(DistinctLimitNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(GroupIdNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(LimitNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(RowNumberNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(StatisticsWriterNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(TableFinishNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(TableWriterNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(TableWriterNode, PlanNode, PlanNodeId) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(TopNNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(TopNNode, PlanNode, PlanNodeId) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(TopNRowNumberNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(WindowNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(Symbol) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(Expression) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(Function<T, R>) - Method in interface io.prestosql.operator.WorkProcessor
 
map(Function<T, T2>) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
map(List<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
MAP - Static variable in class io.prestosql.type.MapParametricType
 
MAP_CONSTRUCTOR - Static variable in class io.prestosql.operator.scalar.MapConstructor
 
MAP_ELEMENT_AT - Static variable in class io.prestosql.operator.scalar.MapElementAtFunction
 
MAP_FILTER_FUNCTION - Static variable in class io.prestosql.operator.scalar.MapFilterFunction
 
MAP_TO_JSON - Static variable in class io.prestosql.operator.scalar.MapToJsonCast
 
MAP_TRANSFORM_VALUES_FUNCTION - Static variable in class io.prestosql.operator.scalar.MapTransformValuesFunction
 
MAP_ZIP_WITH_FUNCTION - Static variable in class io.prestosql.operator.scalar.MapZipWithFunction
 
MapAggregationFunction - Class in io.prestosql.operator.aggregation
 
MapAggregationFunction(BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.MapAggregationFunction
 
mapAndDistinct(List<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
mapCardinality(Block) - Static method in class io.prestosql.operator.scalar.MapCardinalityFunction
 
MapCardinalityFunction - Class in io.prestosql.operator.scalar
 
mapCast(MethodHandle, MethodHandle, Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, ConnectorSession, Block) - Static method in class io.prestosql.operator.scalar.MapToMapCast
 
mapConcat(MapType, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, Object, Block[]) - Static method in class io.prestosql.operator.scalar.MapConcatFunction
 
MapConcatFunction - Class in io.prestosql.operator.scalar
 
MapConcatFunction(BlockTypeOperators) - Constructor for class io.prestosql.operator.scalar.MapConcatFunction
 
MapConstructor - Class in io.prestosql.operator.scalar
 
MapConstructor() - Constructor for class io.prestosql.operator.scalar.MapConstructor
 
MapConstructor.State - Class in io.prestosql.operator.scalar
 
mapDistinctValuesCount(Function<Double, Double>) - Method in class io.prestosql.cost.SymbolStatsEstimate
 
MapElementAtFunction - Class in io.prestosql.operator.scalar
 
MapElementAtFunction() - Constructor for class io.prestosql.operator.scalar.MapElementAtFunction
 
MapEntriesFunction - Class in io.prestosql.operator.scalar
 
MapEntriesFunction(Type) - Constructor for class io.prestosql.operator.scalar.MapEntriesFunction
 
MapFilterFunction - Class in io.prestosql.operator.scalar
 
mapFromEntries(RowType, Block) - Method in class io.prestosql.operator.scalar.MapEntriesFunction
 
mapFromEntries(BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, MapType, ConnectorSession, Block) - Method in class io.prestosql.operator.scalar.MapFromEntriesFunction
 
MapFromEntriesFunction - Class in io.prestosql.operator.scalar
 
MapFromEntriesFunction(Type) - Constructor for class io.prestosql.operator.scalar.MapFromEntriesFunction
 
mapFromProperties(List<Property>) - Static method in class io.prestosql.sql.NodeUtils
 
MapKeys - Class in io.prestosql.operator.scalar
 
mapNullsFraction(Function<Double, Double>) - Method in class io.prestosql.cost.SymbolStatsEstimate
 
mapOutputRowCount(Function<Double, Double>) - Method in class io.prestosql.cost.PlanNodeStatsEstimate
 
MapParametricType - Class in io.prestosql.type
 
MapParametricType() - Constructor for class io.prestosql.type.MapParametricType
 
mappedCopy(Iterable<T>, Function<T, R>) - Static method in class io.prestosql.util.MoreLists
 
MappedPageSource - Class in io.prestosql.split
 
MappedPageSource(ConnectorPageSource, List<Integer>) - Constructor for class io.prestosql.split.MappedPageSource
 
MappedRecordSet - Class in io.prestosql.split
 
MappedRecordSet(RecordSet, List<Integer>) - Constructor for class io.prestosql.split.MappedRecordSet
 
Mapping(Symbol, List<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.UnnestNode.Mapping
 
MapSubscriptOperator - Class in io.prestosql.operator.scalar
 
MapSubscriptOperator() - Constructor for class io.prestosql.operator.scalar.MapSubscriptOperator
 
mapSymbolColumnStatistics(Symbol, Function<SymbolStatsEstimate, SymbolStatsEstimate>) - Method in class io.prestosql.cost.PlanNodeStatsEstimate
 
MapToJsonCast - Class in io.prestosql.operator.scalar
 
MapToMapCast - Class in io.prestosql.operator.scalar
 
MapToMapCast(BlockTypeOperators) - Constructor for class io.prestosql.operator.scalar.MapToMapCast
 
MapTransformKeysFunction - Class in io.prestosql.operator.scalar
 
MapTransformKeysFunction(BlockTypeOperators) - Constructor for class io.prestosql.operator.scalar.MapTransformKeysFunction
 
MapTransformValuesFunction - Class in io.prestosql.operator.scalar
 
MapUnionAggregation - Class in io.prestosql.operator.aggregation
 
MapUnionAggregation(BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.MapUnionAggregation
 
mapUser(String) - Method in class io.prestosql.server.security.UserMapping
 
mapUser(String) - Method in class io.prestosql.server.security.UserMapping.Rule
 
MapValues - Class in io.prestosql.operator.scalar
 
mapZipWith(Type, Type, Type, MapType, Object, Block, Block, MapZipWithFunction.MapZipWithLambda) - Static method in class io.prestosql.operator.scalar.MapZipWithFunction
 
MapZipWithFunction - Class in io.prestosql.operator.scalar
 
MapZipWithFunction.MapZipWithLambda - Interface in io.prestosql.operator.scalar
 
markDistinct() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
MarkDistinctHash - Class in io.prestosql.operator
 
MarkDistinctHash(Session, List<Type>, int[], Optional<Integer>, int, JoinCompiler, BlockTypeOperators, UpdateMemory) - Constructor for class io.prestosql.operator.MarkDistinctHash
 
MarkDistinctHash(Session, List<Type>, int[], Optional<Integer>, JoinCompiler, BlockTypeOperators, UpdateMemory) - Constructor for class io.prestosql.operator.MarkDistinctHash
 
MarkDistinctNode - Class in io.prestosql.sql.planner.plan
 
MarkDistinctNode(PlanNodeId, PlanNode, Symbol, List<Symbol>, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.MarkDistinctNode
 
MarkDistinctOperator - Class in io.prestosql.operator
 
MarkDistinctOperator(OperatorContext, List<Type>, List<Integer>, Optional<Integer>, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.MarkDistinctOperator
 
MarkDistinctOperator.MarkDistinctOperatorFactory - Class in io.prestosql.operator
 
MarkDistinctOperatorFactory(int, PlanNodeId, List<? extends Type>, Collection<Integer>, Optional<Integer>, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.MarkDistinctOperator.MarkDistinctOperatorFactory
 
markDistinctRows(Page) - Method in class io.prestosql.operator.MarkDistinctHash
 
markRedundantOrderBy(OrderBy) - Method in class io.prestosql.sql.analyzer.Analysis
 
mask - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
The mask for wrapping a position counter.
mask - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
The mask for wrapping a position counter.
match(SelectionCriteria) - Method in class io.prestosql.execution.resourcegroups.LegacyResourceGroupConfigurationManager
 
match(List<LocalProperty<T>>, List<LocalProperty<T>>) - Static method in class io.prestosql.sql.planner.optimizations.LocalProperties
Attempt to match the desired properties to a sequence of known properties.
matcher(byte[]) - Method in class io.prestosql.type.JoniRegexp
 
matcher(Slice) - Method in class io.prestosql.type.Re2JRegexp
 
matches() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
matches(Slice) - Method in class io.prestosql.type.Re2JRegexp
 
matches(QualifiedObjectName) - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
matches(Optional<String>, String, TestingAccessControlManager.TestingPrivilegeType) - Method in class io.prestosql.testing.TestingAccessControlManager.TestingPrivilege
 
matchesPrefix(Optional<QualifiedName>) - Method in class io.prestosql.sql.analyzer.Field
 
MaterializedResult - Class in io.prestosql.testing
 
MaterializedResult(List<MaterializedRow>, List<? extends Type>) - Constructor for class io.prestosql.testing.MaterializedResult
 
MaterializedResult(List<MaterializedRow>, List<? extends Type>, Map<String, String>, Set<String>, Optional<String>, OptionalLong, List<Warning>) - Constructor for class io.prestosql.testing.MaterializedResult
 
MaterializedResult.Builder - Class in io.prestosql.testing
 
MaterializedResultWithPlan(MaterializedResult, Plan) - Constructor for class io.prestosql.testing.QueryRunner.MaterializedResultWithPlan
 
MaterializedRow - Class in io.prestosql.testing
Materialize all values in a row Special handling is added for Double types for approximate comparisons
MaterializedRow(int, Object...) - Constructor for class io.prestosql.testing.MaterializedRow
 
MaterializedRow(int, List<Object>) - Constructor for class io.prestosql.testing.MaterializedRow
 
MaterializedRow(List<Object>) - Constructor for class io.prestosql.testing.MaterializedRow
 
materializeSourceDataStream(Session, ConnectorPageSource, List<Type>) - Static method in class io.prestosql.testing.MaterializedResult
 
materializeSourceDataStream(ConnectorSession, ConnectorPageSource, List<Type>) - Static method in class io.prestosql.testing.MaterializedResult
 
MathFunctions - Class in io.prestosql.operator.scalar
 
MathFunctions.Abs - Class in io.prestosql.operator.scalar
 
MathFunctions.Ceiling - Class in io.prestosql.operator.scalar
 
MathFunctions.Floor - Class in io.prestosql.operator.scalar
 
MathFunctions.Round - Class in io.prestosql.operator.scalar
 
MathFunctions.RoundN - Class in io.prestosql.operator.scalar
 
MathFunctions.Sign - Class in io.prestosql.operator.scalar
 
MathFunctions.Truncate - Class in io.prestosql.operator.scalar
 
MathFunctions.TruncateN - Class in io.prestosql.operator.scalar
 
max(double...) - Static method in class io.prestosql.util.MoreMath
 
max(long) - Static method in class io.prestosql.util.MinMaxCompare
 
MAX_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.MaxAggregationFunction
 
MAX_ARITY - Static variable in class io.prestosql.operator.scalar.ZipFunction
 
MAX_BATCH_SIZE - Static variable in class io.prestosql.operator.project.PageProcessor
 
MAX_BY - Static variable in class io.prestosql.operator.aggregation.minmaxby.MaxByAggregationFunction
 
MAX_DOUBLE_FUNCTION - Static variable in class io.prestosql.util.MinMaxCompare
 
MAX_DRIVERS_PER_TASK - Static variable in class io.prestosql.SystemSessionProperties
 
MAX_FUNCTION_MEMORY - Static variable in class io.prestosql.operator.aggregation.TypedSet
 
MAX_GROUPING_SETS - Static variable in class io.prestosql.SystemSessionProperties
 
MAX_REAL_FUNCTION - Static variable in class io.prestosql.util.MinMaxCompare
 
MAX_RECURSION_DEPTH - Static variable in class io.prestosql.SystemSessionProperties
 
MAX_REORDERED_JOINS - Static variable in class io.prestosql.SystemSessionProperties
 
MaxAggregationFunction - Class in io.prestosql.operator.aggregation
 
MaxAggregationFunction() - Constructor for class io.prestosql.operator.aggregation.MaxAggregationFunction
 
MaxByAggregationFunction - Class in io.prestosql.operator.aggregation.minmaxby
 
MaxByAggregationFunction() - Constructor for class io.prestosql.operator.aggregation.minmaxby.MaxByAggregationFunction
 
MaxByNAggregationFunction - Class in io.prestosql.operator.aggregation.minmaxby
 
MaxByNAggregationFunction(BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.minmaxby.MaxByNAggregationFunction
 
MaxDataSizeForStats - Class in io.prestosql.operator.aggregation
 
maxDouble(double, double) - Static method in class io.prestosql.util.MinMaxCompare
 
maxFill - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
Threshold after which we rehash.
maxFill - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Threshold after which we rehash.
MaxNAggregationFunction - Class in io.prestosql.operator.aggregation
 
MaxNAggregationFunction(BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.MaxNAggregationFunction
 
maxReal(long, long) - Static method in class io.prestosql.util.MinMaxCompare
 
mayReturnNullOnNonNullInput(Expression) - Static method in class io.prestosql.sql.planner.NullabilityAnalyzer
TODO: this currently produces a very conservative estimate.
md5(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
mediumPrecision(long, long, Slice) - Static method in class io.prestosql.operator.scalar.timestamp.WithTimeZone
 
Memo - Class in io.prestosql.sql.planner.iterative
Stores a plan in a form that's efficient to mutate locally (i.e.
Memo(PlanNodeIdAllocator, PlanNode) - Constructor for class io.prestosql.sql.planner.iterative.Memo
 
MemoryInfo - Class in io.prestosql.memory
 
MemoryInfo(int, DataSize, Map<MemoryPoolId, MemoryPoolInfo>) - Constructor for class io.prestosql.memory.MemoryInfo
 
MemoryManagerConfig - Class in io.prestosql.memory
 
MemoryManagerConfig() - Constructor for class io.prestosql.memory.MemoryManagerConfig
 
MemoryManagerConfig.LowMemoryKillerPolicy - Enum in io.prestosql.memory
 
MemoryPool - Class in io.prestosql.memory
 
MemoryPool(MemoryPoolId, DataSize) - Constructor for class io.prestosql.memory.MemoryPool
 
MemoryPoolAssignment - Class in io.prestosql.memory
 
MemoryPoolAssignment(QueryId, MemoryPoolId) - Constructor for class io.prestosql.memory.MemoryPoolAssignment
 
MemoryPoolAssignmentsRequest - Class in io.prestosql.memory
 
MemoryPoolAssignmentsRequest(String, long, List<MemoryPoolAssignment>) - Constructor for class io.prestosql.memory.MemoryPoolAssignmentsRequest
 
memoryPoolExists(MemoryPoolId) - Method in class io.prestosql.memory.ClusterMemoryManager
 
MemoryPoolListener - Interface in io.prestosql.memory
 
MemoryResource - Class in io.prestosql.memory
Manages memory pools on this worker node
MemoryResource(LocalMemoryManager, TaskManager) - Constructor for class io.prestosql.memory.MemoryResource
 
MemoryRevokingScheduler - Class in io.prestosql.execution
 
MemoryRevokingScheduler(LocalMemoryManager, SqlTaskManager, TaskManagementExecutor, FeaturesConfig) - Constructor for class io.prestosql.execution.MemoryRevokingScheduler
 
MemoryTrackingRemoteTaskFactory - Class in io.prestosql.execution
 
MemoryTrackingRemoteTaskFactory(RemoteTaskFactory, QueryStateMachine) - Constructor for class io.prestosql.execution.MemoryTrackingRemoteTaskFactory
 
merge(long, long, long, BiFunction<? super Long, ? super Long, ? extends Long>) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
merge(long, long, BiFunction<? super Long, ? super Long, ? extends Long>) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
merge(SqlTaskIoStats) - Method in class io.prestosql.execution.SqlTaskIoStats
 
merge(ApproximateMostFrequentHistogram<K>) - Method in class io.prestosql.operator.aggregation.ApproximateMostFrequentHistogram
 
merge(ArrayAggregationState) - Method in interface io.prestosql.operator.aggregation.arrayagg.ArrayAggregationState
 
merge(DoubleHistogramAggregation.State, DoubleHistogramAggregation.State) - Static method in class io.prestosql.operator.aggregation.DoubleHistogramAggregation
 
merge(DoubleHistogramAggregation.State, DoubleHistogramAggregation.State) - Static method in class io.prestosql.operator.aggregation.RealHistogramAggregation
 
merge(MultimapAggregationState) - Method in interface io.prestosql.operator.aggregation.multimapagg.MultimapAggregationState
 
merge(List<Type>, List<Type>, List<WorkProcessor<Page>>, DriverYieldSignal) - Method in class io.prestosql.operator.MergeHashSort
Rows with same hash value are guaranteed to be in the same result page.
MERGE - Static variable in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
Mergeable<T> - Interface in io.prestosql.util
 
MergeAdjacentWindowsOverProjects(int) - Constructor for class io.prestosql.sql.planner.iterative.rule.GatherAndMergeWindows.MergeAdjacentWindowsOverProjects
 
mergeCentralMomentsState(CentralMomentsState, CentralMomentsState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
mergeCorrelationState(CorrelationState, CorrelationState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
mergeCovarianceState(CovarianceState, CovarianceState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
MergeExcept - Class in io.prestosql.sql.planner.iterative.rule
 
MergeExcept() - Constructor for class io.prestosql.sql.planner.iterative.rule.MergeExcept
 
MergeFilters - Class in io.prestosql.sql.planner.iterative.rule
 
MergeFilters(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.MergeFilters
 
MergeHashSort - Class in io.prestosql.operator
This class performs merge of previously hash sorted pages streams.
MergeHashSort(AggregatedMemoryContext, BlockTypeOperators) - Constructor for class io.prestosql.operator.MergeHashSort
 
MergeHyperLogLogAggregation - Class in io.prestosql.operator.aggregation
 
MergeIntersect - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
MergeIntersect() - Constructor for class io.prestosql.sql.planner.iterative.rule.MergeIntersect
 
MergeLimitOverProjectWithSort - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
MergeLimitOverProjectWithSort() - Constructor for class io.prestosql.sql.planner.iterative.rule.MergeLimitOverProjectWithSort
 
MergeLimits - Class in io.prestosql.sql.planner.iterative.rule
This rule handles both LimitNode with ties and LimitNode without ties.
MergeLimits() - Constructor for class io.prestosql.sql.planner.iterative.rule.MergeLimits
 
MergeLimitWithDistinct - Class in io.prestosql.sql.planner.iterative.rule
 
MergeLimitWithDistinct() - Constructor for class io.prestosql.sql.planner.iterative.rule.MergeLimitWithDistinct
 
MergeLimitWithSort - Class in io.prestosql.sql.planner.iterative.rule
 
MergeLimitWithSort() - Constructor for class io.prestosql.sql.planner.iterative.rule.MergeLimitWithSort
 
MergeLimitWithTopN - Class in io.prestosql.sql.planner.iterative.rule
This rule handles both LimitNode with ties and LimitNode without ties.
MergeLimitWithTopN() - Constructor for class io.prestosql.sql.planner.iterative.rule.MergeLimitWithTopN
 
mergeMaps(Map<K, V>, Map<K, V>, BinaryOperator<V>) - Static method in class io.prestosql.util.MoreMaps
 
mergeMaps(Stream<Map<K, V>>, BinaryOperator<V>) - Static method in class io.prestosql.util.MoreMaps
 
MergeOperator - Class in io.prestosql.operator
 
MergeOperator(OperatorContext, PlanNodeId, ExchangeClientSupplier, PagesSerde, PageWithPositionComparator, List<Integer>, List<Type>) - Constructor for class io.prestosql.operator.MergeOperator
 
MergeOperator.MergeOperatorFactory - Class in io.prestosql.operator
 
MergeOperatorFactory(int, PlanNodeId, ExchangeClientSupplier, PagesSerdeFactory, OrderingCompiler, List<Type>, List<Integer>, List<Integer>, List<SortOrder>) - Constructor for class io.prestosql.operator.MergeOperator.MergeOperatorFactory
 
mergePages(Iterable<? extends Type>, long, int, int, WorkProcessor<Page>, AggregatedMemoryContext) - Static method in class io.prestosql.operator.project.MergePages
 
mergePages(Iterable<? extends Type>, long, int, WorkProcessor<Page>, AggregatedMemoryContext) - Static method in class io.prestosql.operator.project.MergePages
 
MergePages - Class in io.prestosql.operator.project
This class is intended to be used right after the PageProcessor to ensure that the size of the pages returned by FilterAndProject and ScanFilterAndProject is big enough so it does not introduce considerable synchronization overhead.
MergeQuantileDigestFunction - Class in io.prestosql.operator.aggregation
 
MergeQuantileDigestFunction() - Constructor for class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
mergeRegressionState(RegressionState, RegressionState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
mergeResults(List<Void>) - Method in class io.prestosql.memory.VoidTraversingQueryContextVisitor
 
mergeResults(List<R>) - Method in class io.prestosql.memory.TraversingQueryContextVisitor
 
MergeSetDigestAggregation - Class in io.prestosql.type.setdigest
 
mergeSorted(Iterable<WorkProcessor<T>>, Comparator<T>) - Static method in interface io.prestosql.operator.WorkProcessor
 
mergeSortedPages(List<WorkProcessor<Page>>, PageWithPositionComparator, List<Type>, AggregatedMemoryContext, DriverYieldSignal) - Static method in class io.prestosql.util.MergeSortedPages
 
mergeSortedPages(List<WorkProcessor<Page>>, PageWithPositionComparator, List<Integer>, List<Type>, BiPredicate<PageBuilder, MergeSortedPages.PageWithPosition>, boolean, AggregatedMemoryContext, DriverYieldSignal) - Static method in class io.prestosql.util.MergeSortedPages
 
MergeSortedPages - Class in io.prestosql.util
 
MergeSortedPages.PageWithPosition - Class in io.prestosql.util
 
MergeTDigestAggregation - Class in io.prestosql.operator.aggregation
 
MergeUnion - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
MergeUnion() - Constructor for class io.prestosql.sql.planner.iterative.rule.MergeUnion
 
mergeVarianceState(VarianceState, VarianceState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
mergeWith(NumericHistogram) - Method in class io.prestosql.operator.aggregation.NumericHistogram
 
mergeWith(LocalExchangeBufferInfo) - Method in class io.prestosql.operator.exchange.LocalExchangeBufferInfo
 
mergeWith(ExchangeClientStatus) - Method in class io.prestosql.operator.ExchangeClientStatus
 
mergeWith(HashCollisionsInfo) - Method in class io.prestosql.operator.HashCollisionsInfo
 
mergeWith(JoinOperatorInfo) - Method in class io.prestosql.operator.JoinOperatorInfo
 
mergeWith(PartitionedOutputOperator.PartitionedOutputInfo) - Method in class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputInfo
 
mergeWith(TableWriterOperator.TableWriterInfo) - Method in class io.prestosql.operator.TableWriterOperator.TableWriterInfo
 
mergeWith(WindowInfo) - Method in class io.prestosql.operator.WindowInfo
 
mergeWith(PlanNodeStats) - Method in class io.prestosql.sql.planner.planprinter.HashCollisionPlanNodeStats
 
mergeWith(PlanNodeStats) - Method in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
mergeWith(PlanNodeStats) - Method in class io.prestosql.sql.planner.planprinter.WindowPlanNodeStats
 
mergeWith(SetDigest) - Method in class io.prestosql.type.setdigest.SetDigest
 
mergeWith(T) - Method in interface io.prestosql.util.Mergeable
Merges the current state with the state of the other instance, and returns the merged state.
mergingExchange(PlanNodeId, ExchangeNode.Scope, PlanNode, OrderingScheme) - Static method in class io.prestosql.sql.planner.plan.ExchangeNode
 
MergingHashAggregationBuilder - Class in io.prestosql.operator.aggregation.builder
 
MergingHashAggregationBuilder(List<AccumulatorFactory>, AggregationNode.Step, int, List<Type>, Optional<Integer>, OperatorContext, WorkProcessor<Page>, AggregatedMemoryContext, long, int, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.builder.MergingHashAggregationBuilder
 
message() - Method in annotation type io.prestosql.util.PowerOfTwo
 
Metadata - Interface in io.prestosql.metadata
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.AttributeJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.CatalogJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.ColumnJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.ProcedureColumnJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.ProcedureJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.PseudoColumnJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.SchemaJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.SuperTableJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.SuperTypeJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.TableJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.TableTypeJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.TypesJdbcTable
 
METADATA - Static variable in class io.prestosql.connector.system.jdbc.UdtJdbcTable
 
MetadataListing - Class in io.prestosql.metadata
 
MetadataManager - Class in io.prestosql.metadata
 
MetadataManager(FeaturesConfig, SessionPropertyManager, SchemaPropertyManager, TablePropertyManager, ColumnPropertyManager, AnalyzePropertyManager, TransactionManager, TypeOperators, BlockTypeOperators) - Constructor for class io.prestosql.metadata.MetadataManager
 
MetadataQueryOptimizer - Class in io.prestosql.sql.planner.optimizations
Converts cardinality-insensitive aggregations (max, min, "distinct") over partition keys into simple metadata queries
MetadataQueryOptimizer(Metadata) - Constructor for class io.prestosql.sql.planner.optimizations.MetadataQueryOptimizer
 
MetadataUtil - Class in io.prestosql.metadata
 
MetadataUtil.TableMetadataBuilder - Class in io.prestosql.metadata
 
method(Class<?>, String, Class<?>...) - Static method in class io.prestosql.util.Reflection
 
methodHandle(StandardErrorCode, Method) - Static method in class io.prestosql.util.Reflection
Returns a MethodHandle corresponding to the specified method.
methodHandle(Class<?>, String, Class<?>...) - Static method in class io.prestosql.util.Reflection
Returns a MethodHandle corresponding to the specified method.
methodHandle(Method) - Static method in class io.prestosql.util.Reflection
Returns a MethodHandle corresponding to the specified method.
methods(String...) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.MethodsGroupBuilder
 
methods(List<String>) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.MethodsGroupBuilder
 
methodWithExplicitJavaTypes(String, List<Optional<Class<?>>>) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.MethodsGroupBuilder
 
MICROSECONDS_PER_DAY - Static variable in class io.prestosql.type.DateTimes
 
MICROSECONDS_PER_MILLISECOND - Static variable in class io.prestosql.type.DateTimes
 
MICROSECONDS_PER_SECOND - Static variable in class io.prestosql.type.DateTimes
 
millisecond(long) - Static method in class io.prestosql.operator.scalar.time.TimeFunctions
 
millisecondFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
MILLISECONDS_PER_DAY - Static variable in class io.prestosql.type.DateTimes
 
MILLISECONDS_PER_MINUTE - Static variable in class io.prestosql.type.DateTimes
 
MILLISECONDS_PER_SECOND - Static variable in class io.prestosql.type.DateTimes
 
min(double...) - Static method in class io.prestosql.util.MoreMath
 
min(long) - Static method in class io.prestosql.util.MinMaxCompare
 
MIN_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.MinAggregationFunction
 
MIN_ARITY - Static variable in class io.prestosql.operator.scalar.ZipFunction
 
MIN_BY - Static variable in class io.prestosql.operator.aggregation.minmaxby.MinByAggregationFunction
 
MinAggregationFunction - Class in io.prestosql.operator.aggregation
 
MinAggregationFunction() - Constructor for class io.prestosql.operator.aggregation.MinAggregationFunction
 
MinByAggregationFunction - Class in io.prestosql.operator.aggregation.minmaxby
 
MinByAggregationFunction() - Constructor for class io.prestosql.operator.aggregation.minmaxby.MinByAggregationFunction
 
MinByNAggregationFunction - Class in io.prestosql.operator.aggregation.minmaxby
 
MinByNAggregationFunction(BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.minmaxby.MinByNAggregationFunction
 
MinMaxByNState - Interface in io.prestosql.operator.aggregation.minmaxby
 
MinMaxByNStateFactory - Class in io.prestosql.operator.aggregation.minmaxby
 
MinMaxByNStateFactory() - Constructor for class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory
 
MinMaxByNStateFactory.GroupedMinMaxByNState - Class in io.prestosql.operator.aggregation.minmaxby
 
MinMaxByNStateFactory.SingleMinMaxByNState - Class in io.prestosql.operator.aggregation.minmaxby
 
MinMaxByNStateSerializer - Class in io.prestosql.operator.aggregation.minmaxby
 
MinMaxByNStateSerializer(BlockTypeOperators.BlockPositionComparison, Type, Type) - Constructor for class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateSerializer
 
MinMaxCompare - Class in io.prestosql.util
 
MinMaxNState - Interface in io.prestosql.operator.aggregation.state
 
MinMaxNStateFactory - Class in io.prestosql.operator.aggregation.state
 
MinMaxNStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.MinMaxNStateFactory
 
MinMaxNStateFactory.GroupedMinMaxNState - Class in io.prestosql.operator.aggregation.state
 
MinMaxNStateFactory.SingleMinMaxNState - Class in io.prestosql.operator.aggregation.state
 
MinMaxNStateSerializer - Class in io.prestosql.operator.aggregation.state
 
MinMaxNStateSerializer(BlockTypeOperators.BlockPositionComparison, Type) - Constructor for class io.prestosql.operator.aggregation.state.MinMaxNStateSerializer
 
minN - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
We never resize below this threshold, which is the construction-time {#n}.
minN - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
We never resize below this threshold, which is the construction-time {#n}.
MinNAggregationFunction - Class in io.prestosql.operator.aggregation
 
MinNAggregationFunction(BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.MinNAggregationFunction
 
minute(long) - Static method in class io.prestosql.operator.scalar.time.TimeFunctions
 
minuteFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
MINUTES_PER_HOUR - Static variable in class io.prestosql.type.DateTimes
 
missingAttributeException(Expression, QualifiedName) - Static method in class io.prestosql.sql.analyzer.SemanticExceptions
 
MIXED_SPLIT_QUEUES_FULL_AND_WAITING_FOR_SOURCE - io.prestosql.execution.scheduler.ScheduleResult.BlockedReason
 
mod(double, double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
mod(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
modFloat(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
modInteger(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
modSmallint(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
modTinyint(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
modulus(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
modulus(long, long) - Static method in class io.prestosql.type.BigintOperators
 
modulus(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
modulus(long, long) - Static method in class io.prestosql.type.RealOperators
 
modulus(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
modulus(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
modulusLongLongLong(Slice, Slice, int, int) - Static method in class io.prestosql.type.DecimalOperators
 
modulusLongShortLong(Slice, long, int, int) - Static method in class io.prestosql.type.DecimalOperators
 
modulusLongShortShort(Slice, long, int, int) - Static method in class io.prestosql.type.DecimalOperators
 
modulusScalarFunction(Signature) - Static method in class io.prestosql.type.DecimalOperators
 
modulusShortLongLong(long, Slice, int, int) - Static method in class io.prestosql.type.DecimalOperators
 
modulusShortLongShort(long, Slice, int, int) - Static method in class io.prestosql.type.DecimalOperators
 
modulusShortShortShort(long, long, int, int) - Static method in class io.prestosql.type.DecimalOperators
 
modulusSignatureBuilder() - Static method in class io.prestosql.type.DecimalOperators
 
monthFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
monthFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
MoreLists - Class in io.prestosql.util
 
MoreMaps - Class in io.prestosql.util
 
MoreMath - Class in io.prestosql.util
 
moreMemoryAvailable() - Method in class io.prestosql.operator.DriverContext
 
moreMemoryAvailable() - Method in class io.prestosql.operator.OperatorContext
 
moreMemoryAvailable() - Method in class io.prestosql.operator.PipelineContext
 
moreMemoryAvailable() - Method in class io.prestosql.operator.TaskContext
 
MorePredicates - Class in io.prestosql.util
 
MultiChannelGroupByHash - Class in io.prestosql.operator
 
MultiChannelGroupByHash(List<? extends Type>, int[], Optional<Integer>, int, boolean, JoinCompiler, BlockTypeOperators, UpdateMemory) - Constructor for class io.prestosql.operator.MultiChannelGroupByHash
 
MultilevelSplitQueue - Class in io.prestosql.execution.executor
 
MultilevelSplitQueue(double) - Constructor for class io.prestosql.execution.executor.MultilevelSplitQueue
 
MultilevelSplitQueue(TaskManagerConfig) - Constructor for class io.prestosql.execution.executor.MultilevelSplitQueue
 
MultimapAggregationFunction - Class in io.prestosql.operator.aggregation.multimapagg
 
MultimapAggregationFunction(BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
MultimapAggregationState - Interface in io.prestosql.operator.aggregation.multimapagg
 
MultimapAggregationStateConsumer - Interface in io.prestosql.operator.aggregation.multimapagg
 
MultimapAggregationStateFactory - Class in io.prestosql.operator.aggregation.multimapagg
 
MultimapAggregationStateFactory(Type, Type) - Constructor for class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateFactory
 
MultimapAggregationStateSerializer - Class in io.prestosql.operator.aggregation.multimapagg
 
MultimapAggregationStateSerializer(Type, Type) - Constructor for class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateSerializer
 
multimapFromEntries(MapType, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, Block) - Method in class io.prestosql.operator.scalar.MultimapFromEntriesFunction
 
MultimapFromEntriesFunction - Class in io.prestosql.operator.scalar
 
MultimapFromEntriesFunction(Type) - Constructor for class io.prestosql.operator.scalar.MultimapFromEntriesFunction
 
MULTIPLE - io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties.StreamDistribution
 
MultipleDistinctAggregationToMarkDistinct - Class in io.prestosql.sql.planner.iterative.rule
Implements distinct aggregations with different inputs by transforming plans of the following shape:
MultipleDistinctAggregationToMarkDistinct() - Constructor for class io.prestosql.sql.planner.iterative.rule.MultipleDistinctAggregationToMarkDistinct
 
multiply(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
multiply(long, long) - Static method in class io.prestosql.type.BigintOperators
 
multiply(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
multiply(long, long) - Static method in class io.prestosql.type.RealOperators
 
multiply(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
multiply(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
multiplyByBigint(long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
multiplyByBigint(long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
multiplyByDouble(long, double) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
multiplyByDouble(long, double) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
multiplyLongLongLong(Slice, Slice) - Static method in class io.prestosql.type.DecimalOperators
 
multiplyLongShortLong(Slice, long) - Static method in class io.prestosql.type.DecimalOperators
 
multiplyShortLongLong(long, Slice) - Static method in class io.prestosql.type.DecimalOperators
 
multiplyShortShortLong(long, long) - Static method in class io.prestosql.type.DecimalOperators
 
multiplyShortShortShort(long, long) - Static method in class io.prestosql.type.DecimalOperators
 
murmur3(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 

N

n - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
The current table size.
n - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
The current table size.
name() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
name(String) - Method in class io.prestosql.metadata.SignatureBuilder
 
NAME - Static variable in class io.prestosql.connector.system.GlobalSystemConnector
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.AttributeJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.CatalogJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.ColumnJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.ProcedureColumnJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.ProcedureJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.PseudoColumnJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.SchemaJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.SuperTableJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.SuperTypeJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.TableJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.TableTypeJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.TypesJdbcTable
 
NAME - Static variable in class io.prestosql.connector.system.jdbc.UdtJdbcTable
 
NAME - Static variable in class io.prestosql.operator.aggregation.histogram.Histogram
 
NAME - Static variable in class io.prestosql.operator.aggregation.MapAggregationFunction
 
NAME - Static variable in class io.prestosql.operator.aggregation.MapUnionAggregation
 
NAME - Static variable in class io.prestosql.operator.aggregation.MaxDataSizeForStats
 
NAME - Static variable in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
NAME - Static variable in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
NAME - Static variable in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
NAME - Static variable in class io.prestosql.operator.aggregation.SumDataSizeForStats
 
NAME - Static variable in class io.prestosql.operator.scalar.FormatFunction
 
NAME - Static variable in class io.prestosql.operator.scalar.MapTransformKeysFunction
 
NAME - Static variable in class io.prestosql.operator.scalar.TryFunction
 
NAME - Static variable in class io.prestosql.type.CodePointsType
 
NAME - Static variable in class io.prestosql.type.ColorType
 
NAME - Static variable in class io.prestosql.type.FunctionType
 
NAME - Static variable in class io.prestosql.type.JoniRegexpType
 
NAME - Static variable in class io.prestosql.type.JsonPathType
 
NAME - Static variable in class io.prestosql.type.LikePatternType
 
NAME - Static variable in class io.prestosql.type.Re2JRegexpType
 
NAME - Static variable in class io.prestosql.type.setdigest.SetDigestType
 
NAME - Static variable in class io.prestosql.type.UnknownType
 
NaN() - Static method in class io.prestosql.operator.scalar.MathFunctions
 
NANOSECONDS_PER_DAY - Static variable in class io.prestosql.type.DateTimes
 
NANOSECONDS_PER_HOUR - Static variable in class io.prestosql.type.DateTimes
 
NANOSECONDS_PER_MICROSECOND - Static variable in class io.prestosql.type.DateTimes
 
NANOSECONDS_PER_MILLISECOND - Static variable in class io.prestosql.type.DateTimes
 
NANOSECONDS_PER_MINUTE - Static variable in class io.prestosql.type.DateTimes
 
NANOSECONDS_PER_SECOND - Static variable in class io.prestosql.type.DateTimes
 
nearlyEqual(double, double, double) - Static method in class io.prestosql.util.MoreMath
See http://floating-point-gui.de/errors/comparison/
nearlyEqual(float, float, float) - Static method in class io.prestosql.util.MoreMath
See http://floating-point-gui.de/errors/comparison/
needsInput() - Method in class io.prestosql.operator.AggregationOperator
 
needsInput() - Method in class io.prestosql.operator.BasicWorkProcessorOperatorAdapter
 
needsInput() - Method in class io.prestosql.operator.DeleteOperator
 
needsInput() - Method in class io.prestosql.operator.DevNullOperator
 
needsInput() - Method in class io.prestosql.operator.DistinctLimitOperator
 
needsInput() - Method in class io.prestosql.operator.DynamicFilterSourceOperator
 
needsInput() - Method in class io.prestosql.operator.EnforceSingleRowOperator
 
needsInput() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator
 
needsInput() - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator
 
needsInput() - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator
 
needsInput() - Method in class io.prestosql.operator.ExchangeOperator
 
needsInput() - Method in class io.prestosql.operator.ExplainAnalyzeOperator
 
needsInput() - Method in class io.prestosql.operator.FinishedOperator
 
needsInput() - Method in class io.prestosql.operator.GroupIdOperator
 
needsInput() - Method in class io.prestosql.operator.HashAggregationOperator
 
needsInput() - Method in class io.prestosql.operator.HashBuilderOperator
 
needsInput() - Method in class io.prestosql.operator.index.IndexSourceOperator
 
needsInput() - Method in class io.prestosql.operator.index.PageBufferOperator
 
needsInput() - Method in class io.prestosql.operator.index.PagesIndexBuilderOperator
 
needsInput() - Method in class io.prestosql.operator.LimitOperator
 
needsInput() - Method in class io.prestosql.operator.LookupJoinOperator
 
needsInput() - Method in class io.prestosql.operator.LookupOuterOperator
 
needsInput() - Method in class io.prestosql.operator.MarkDistinctOperator
 
needsInput() - Method in class io.prestosql.operator.MergeOperator
 
needsInput() - Method in class io.prestosql.operator.NestedLoopBuildOperator
 
needsInput() - Method in class io.prestosql.operator.NestedLoopJoinOperator
 
needsInput() - Method in interface io.prestosql.operator.Operator
Returns true if and only if this operator can accept an input page.
needsInput() - Method in class io.prestosql.operator.OrderByOperator
 
needsInput() - Method in class io.prestosql.operator.PageSourceOperator
 
needsInput() - Method in class io.prestosql.operator.PartitionedOutputOperator
 
needsInput() - Method in class io.prestosql.operator.RowNumberOperator
 
needsInput() - Method in class io.prestosql.operator.SetBuilderOperator
 
needsInput() - Method in class io.prestosql.operator.SpatialIndexBuilderOperator
 
needsInput() - Method in class io.prestosql.operator.SpatialJoinOperator
 
needsInput() - Method in class io.prestosql.operator.StatisticsWriterOperator
 
needsInput() - Method in class io.prestosql.operator.TableDeleteOperator
 
needsInput() - Method in class io.prestosql.operator.TableFinishOperator
 
needsInput() - Method in class io.prestosql.operator.TableScanOperator
 
needsInput() - Method in class io.prestosql.operator.TableWriterOperator
 
needsInput() - Method in class io.prestosql.operator.TaskOutputOperator
 
needsInput() - Method in class io.prestosql.operator.TopNOperator
 
needsInput() - Method in class io.prestosql.operator.TopNRowNumberOperator
 
needsInput() - Method in class io.prestosql.operator.unnest.UnnestOperator
 
needsInput() - Method in class io.prestosql.operator.ValuesOperator
 
needsInput() - Method in class io.prestosql.operator.WindowOperator
 
needsInput() - Method in interface io.prestosql.operator.WorkProcessorOperatorAdapter.AdapterWorkProcessorOperator
 
needsInput() - Method in class io.prestosql.operator.WorkProcessorOperatorAdapter
 
needsInput() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
needsInput() - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
needsInput() - Method in class io.prestosql.testing.NullOutputOperator
 
needsInput() - Method in class io.prestosql.testing.PageConsumerOperator
 
needsMoreData() - Static method in class io.prestosql.operator.WorkProcessor.TransformationState
Signals that transformation requires more data in order to continue and no result has been produced.
negate(double) - Static method in class io.prestosql.type.DoubleOperators
 
negate(long) - Static method in class io.prestosql.type.BigintOperators
 
negate(long) - Static method in class io.prestosql.type.DecimalOperators.Negation
 
negate(long) - Static method in class io.prestosql.type.IntegerOperators
 
negate(long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
negate(long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
negate(long) - Static method in class io.prestosql.type.RealOperators
 
negate(long) - Static method in class io.prestosql.type.SmallintOperators
 
negate(long) - Static method in class io.prestosql.type.TinyintOperators
 
negate(Slice) - Static method in class io.prestosql.type.DecimalOperators.Negation
 
Negation() - Constructor for class io.prestosql.type.DecimalOperators.Negation
 
nElements(int, IntFunction<T>) - Static method in class io.prestosql.util.MoreLists
 
NestedLoopBuildOperator - Class in io.prestosql.operator
 
NestedLoopBuildOperator(OperatorContext, NestedLoopJoinBridge) - Constructor for class io.prestosql.operator.NestedLoopBuildOperator
 
NestedLoopBuildOperator.NestedLoopBuildOperatorFactory - Class in io.prestosql.operator
 
NestedLoopBuildOperatorFactory(int, PlanNodeId, JoinBridgeManager<NestedLoopJoinBridge>) - Constructor for class io.prestosql.operator.NestedLoopBuildOperator.NestedLoopBuildOperatorFactory
 
NestedLoopJoinBridge - Interface in io.prestosql.operator
 
NestedLoopJoinOperator - Class in io.prestosql.operator
 
NestedLoopJoinOperator.NestedLoopJoinOperatorFactory - Class in io.prestosql.operator
 
NestedLoopJoinOperatorFactory(int, PlanNodeId, JoinBridgeManager<NestedLoopJoinBridge>, List<Integer>, List<Integer>) - Constructor for class io.prestosql.operator.NestedLoopJoinOperator.NestedLoopJoinOperatorFactory
 
NestedLoopJoinPages - Class in io.prestosql.operator
 
NestedLoopJoinPagesBuilder - Class in io.prestosql.operator
 
NestedLoopJoinPagesSupplier - Class in io.prestosql.operator
 
NestedLoopJoinPagesSupplier() - Constructor for class io.prestosql.operator.NestedLoopJoinPagesSupplier
 
NetworkLocation - Class in io.prestosql.execution.scheduler
Represents a location in the network topology.
NetworkLocation(String...) - Constructor for class io.prestosql.execution.scheduler.NetworkLocation
 
NetworkLocation(Collection<String>) - Constructor for class io.prestosql.execution.scheduler.NetworkLocation
 
NetworkTopology - Interface in io.prestosql.execution.scheduler
Implementations of this interface must be thread safe.
newAggregateRevocableMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
newAggregateSystemMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
newAggregateUserMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
newContext() - Method in class io.prestosql.execution.buffer.PagesSerde
 
newHashSymbol() - Method in class io.prestosql.sql.planner.SymbolAllocator
 
newHyperLogLog() - Static method in class io.prestosql.operator.aggregation.ApproximateSetAggregation
 
newInstance(Slice) - Static method in class io.prestosql.type.setdigest.SetDigest
 
newInstance(Metadata, Expression...) - Static method in class io.prestosql.sql.planner.EqualityInference
 
newInstance(Metadata, Collection<Expression>) - Static method in class io.prestosql.sql.planner.EqualityInference
 
newInstance(PlanNodeId, TableHandle, List<Symbol>, Map<Symbol, ColumnHandle>, boolean) - Static method in class io.prestosql.sql.planner.plan.TableScanNode
 
newLocalSpillContext() - Method in interface io.prestosql.operator.SpillContext
 
newLocalSystemMemoryContext(String) - Method in class io.prestosql.operator.OperatorContext
 
newPagesIndex(List<Type>, int) - Method in class io.prestosql.operator.PagesIndex.DefaultFactory
 
newPagesIndex(List<Type>, int) - Method in interface io.prestosql.operator.PagesIndex.Factory
 
newPagesIndex(List<Type>, int) - Method in class io.prestosql.operator.PagesIndex.TestingFactory
 
newQualified(QualifiedName, Optional<String>, Type, boolean, Optional<QualifiedObjectName>, Optional<String>, boolean) - Static method in class io.prestosql.sql.analyzer.Field
 
newSessionWithDefaultProperties(Session, Optional<String>, ResourceGroupId) - Method in class io.prestosql.server.SessionPropertyDefaults
 
newSinkFactoryId() - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeFactory
 
newSourcePartitionedSchedulerAsSourceScheduler(SqlStageExecution, PlanNodeId, SplitSource, SplitPlacementPolicy, int, boolean, DynamicFilterService, BooleanSupplier) - Static method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
Obtains a SourceScheduler suitable for use in FixedSourcePartitionedScheduler.
newSourcePartitionedSchedulerAsStageScheduler(SqlStageExecution, PlanNodeId, SplitSource, SplitPlacementPolicy, int, DynamicFilterService, BooleanSupplier) - Static method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
Obtains an instance of SourcePartitionedScheduler suitable for use as a stage scheduler.
newSymbol(Field) - Method in class io.prestosql.sql.planner.SymbolAllocator
 
newSymbol(Symbol) - Method in class io.prestosql.sql.planner.SymbolAllocator
 
newSymbol(Symbol, String) - Method in class io.prestosql.sql.planner.SymbolAllocator
 
newSymbol(Expression, Type) - Method in class io.prestosql.sql.planner.SymbolAllocator
 
newSymbol(Expression, Type, String) - Method in class io.prestosql.sql.planner.SymbolAllocator
 
newSymbol(String, Type) - Method in class io.prestosql.sql.planner.SymbolAllocator
 
newSymbol(String, Type, String) - Method in class io.prestosql.sql.planner.SymbolAllocator
 
NewTableLayout - Class in io.prestosql.metadata
 
NewTableLayout(CatalogName, ConnectorTransactionHandle, ConnectorNewTableLayout) - Constructor for class io.prestosql.metadata.NewTableLayout
 
newUnqualified(String, Type) - Static method in class io.prestosql.sql.analyzer.Field
 
newUnqualified(Optional<String>, Type) - Static method in class io.prestosql.sql.analyzer.Field
 
newUnqualified(Optional<String>, Type, Optional<QualifiedObjectName>, Optional<String>, boolean) - Static method in class io.prestosql.sql.analyzer.Field
 
newWindowFunction(List<Integer>, boolean, List<LambdaProvider>) - Method in class io.prestosql.operator.window.AbstractWindowFunctionSupplier
Create window function instance using the supplied arguments.
newWindowFunction(List<Integer>, boolean, List<LambdaProvider>) - Method in class io.prestosql.operator.window.ReflectionWindowFunctionSupplier
 
next() - Method in class io.prestosql.execution.scheduler.ResettableRandomizedIterator
 
next(int, int, Page) - Method in class io.prestosql.operator.ArrayPositionLinks
 
next(int, int, Page) - Method in interface io.prestosql.operator.PositionLinks
Iterate over position links.
next(int, int, Page) - Method in class io.prestosql.operator.SortedPositionLinks
 
nextBucketId(int, int, int) - Static method in class io.prestosql.operator.aggregation.histogram.HashUtil
 
nextChild() - Method in class io.prestosql.util.HeapTraversal
 
nextProbeLinear(int) - Static method in class io.prestosql.operator.aggregation.histogram.HashUtil
 
nextSumOfCount(int) - Static method in class io.prestosql.operator.aggregation.histogram.HashUtil
 
nextSumOfSquares(int) - Static method in class io.prestosql.operator.aggregation.histogram.HashUtil
 
ngrams(Block, long) - Static method in class io.prestosql.operator.scalar.ArrayNgramsFunction
 
NO_ACTIVE_DRIVER_GROUP - io.prestosql.execution.scheduler.ScheduleResult.BlockedReason
 
NO_CHECKSUM - Static variable in class io.prestosql.execution.buffer.PagesSerdeUtil
Special checksum value used to verify configuration consistency across nodes (all nodes need to have data integrity configured the same way).
NO_DEPENDENCIES - Static variable in class io.prestosql.metadata.FunctionDependencyDeclaration
 
NO_MORE_BUFFERS - io.prestosql.execution.buffer.BufferState
No more buffers can be added.
NO_MORE_PAGES - io.prestosql.execution.buffer.BufferState
No more pages can be added.
NO_MORE_POSITIONS - Static variable in interface io.prestosql.operator.index.IndexedData
 
NO_SPILL_EPOCH - Static variable in class io.prestosql.operator.PartitionedLookupSourceFactory
 
NoChannelGroupByHash - Class in io.prestosql.operator
 
NoChannelGroupByHash() - Constructor for class io.prestosql.operator.NoChannelGroupByHash
 
NodeAndMappings - Class in io.prestosql.sql.planner
 
NodeAndMappings(PlanNode, List<Symbol>) - Constructor for class io.prestosql.sql.planner.NodeAndMappings
 
NodeAssignmentStats - Class in io.prestosql.execution.scheduler
 
NodeAssignmentStats(NodeTaskMap, NodeMap, List<RemoteTask>) - Constructor for class io.prestosql.execution.scheduler.NodeAssignmentStats
 
NodeMap - Class in io.prestosql.execution.scheduler
 
NodeMap(SetMultimap<HostAddress, InternalNode>, SetMultimap<InetAddress, InternalNode>, SetMultimap<NetworkLocation, InternalNode>, Set<String>) - Constructor for class io.prestosql.execution.scheduler.NodeMap
 
NodeMemoryConfig - Class in io.prestosql.memory
 
NodeMemoryConfig() - Constructor for class io.prestosql.memory.NodeMemoryConfig
 
NodePartitioningManager - Class in io.prestosql.sql.planner
 
NodePartitioningManager(NodeScheduler, BlockTypeOperators) - Constructor for class io.prestosql.sql.planner.NodePartitioningManager
 
NodePartitionMap - Class in io.prestosql.sql.planner
 
NodePartitionMap(List<InternalNode>, int[], ToIntFunction<Split>) - Constructor for class io.prestosql.sql.planner.NodePartitionMap
 
NodePartitionMap(List<InternalNode>, ToIntFunction<Split>) - Constructor for class io.prestosql.sql.planner.NodePartitionMap
 
NodeRepresentation - Class in io.prestosql.sql.planner.planprinter
 
NodeRepresentation(PlanNodeId, String, String, String, List<NodeRepresentation.TypedSymbol>, Optional<PlanNodeStats>, List<PlanNodeStatsEstimate>, List<PlanCostEstimate>, Optional<PlanNodeStatsAndCostSummary>, List<PlanNodeId>, List<PlanFragmentId>) - Constructor for class io.prestosql.sql.planner.planprinter.NodeRepresentation
 
NodeRepresentation.TypedSymbol - Class in io.prestosql.sql.planner.planprinter
 
NodeResource - Class in io.prestosql.server
 
NodeResource(HeartbeatFailureDetector) - Constructor for class io.prestosql.server.NodeResource
 
NODES_TABLE - Static variable in class io.prestosql.connector.system.NodeSystemTable
 
NODES_TABLE_NAME - Static variable in class io.prestosql.connector.system.NodeSystemTable
 
NodeScheduler - Class in io.prestosql.execution.scheduler
 
NodeScheduler(NodeSelectorFactory) - Constructor for class io.prestosql.execution.scheduler.NodeScheduler
 
NodeSchedulerConfig - Class in io.prestosql.execution.scheduler
 
NodeSchedulerConfig() - Constructor for class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
NodeSchedulerConfig.NodeSchedulerPolicy - Enum in io.prestosql.execution.scheduler
 
NodeSchedulerExporter - Class in io.prestosql.execution.scheduler
 
NodeSchedulerExporter(TopologyAwareNodeSelectorFactory, MBeanExporter) - Constructor for class io.prestosql.execution.scheduler.NodeSchedulerExporter
 
NodeSelector - Interface in io.prestosql.execution.scheduler
 
NodeSelectorFactory - Interface in io.prestosql.execution.scheduler
 
NodeSpillConfig - Class in io.prestosql.spiller
 
NodeSpillConfig() - Constructor for class io.prestosql.spiller.NodeSpillConfig
 
NodeState - Enum in io.prestosql.metadata
 
NodeStatus - Class in io.prestosql.server
 
NodeStatus(String, NodeVersion, String, boolean, Duration, String, String, MemoryInfo, int, double, double, long, long, long) - Constructor for class io.prestosql.server.NodeStatus
 
NodeSystemTable - Class in io.prestosql.connector.system
 
NodeSystemTable(InternalNodeManager) - Constructor for class io.prestosql.connector.system.NodeSystemTable
 
NodeTaskMap - Class in io.prestosql.execution
 
NodeTaskMap(FinalizerService) - Constructor for class io.prestosql.execution.NodeTaskMap
 
NodeTaskMap.PartitionedSplitCountTracker - Class in io.prestosql.execution
 
NodeUtils - Class in io.prestosql.sql
 
NoDuplicatePlanNodeIdsChecker - Class in io.prestosql.sql.planner.sanity
 
NoDuplicatePlanNodeIdsChecker() - Constructor for class io.prestosql.sql.planner.sanity.NoDuplicatePlanNodeIdsChecker
 
NoIdentifierLeftChecker - Class in io.prestosql.sql.planner.sanity
 
NoIdentifierLeftChecker() - Constructor for class io.prestosql.sql.planner.sanity.NoIdentifierLeftChecker
 
noLookup() - Static method in interface io.prestosql.sql.planner.iterative.Lookup
A Lookup implementation that does not perform lookup.
noMoreDrivers() - Method in class io.prestosql.operator.DriverFactory
 
noMoreDrivers(Lifespan) - Method in class io.prestosql.operator.DriverFactory
 
noMoreLifespans() - Method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
 
noMoreLifespans() - Method in interface io.prestosql.execution.scheduler.SourceScheduler
 
noMoreLocations() - Method in class io.prestosql.operator.ExchangeClient
 
noMoreOperators() - Method in class io.prestosql.operator.AggregationOperator.AggregationOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.DeleteOperator.DeleteOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.DevNullOperator.DevNullOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.DistinctLimitOperator.DistinctLimitOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.DynamicFilterSourceOperator.DynamicFilterSourceOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.EnforceSingleRowOperator.EnforceSingleRowOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator.LocalExchangeSinkOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.exchange.LocalExchangeSourceOperator.LocalExchangeSourceOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.exchange.LocalMergeSourceOperator.LocalMergeSourceOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.ExchangeOperator.ExchangeOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.ExplainAnalyzeOperator.ExplainAnalyzeOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.GroupIdOperator.GroupIdOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.HashAggregationOperator.HashAggregationOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.HashBuilderOperator.HashBuilderOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.index.IndexSourceOperator.IndexSourceOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.index.PageBufferOperator.PageBufferOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.index.PagesIndexBuilderOperator.PagesIndexBuilderOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.LimitOperator.LimitOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.LookupOuterOperator.LookupOuterOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.MarkDistinctOperator.MarkDistinctOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.MergeOperator.MergeOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.NestedLoopBuildOperator.NestedLoopBuildOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.NestedLoopJoinOperator.NestedLoopJoinOperatorFactory
 
noMoreOperators() - Method in interface io.prestosql.operator.OperatorFactory
Declare that createOperator will not be called any more and release any resources associated with this factory.
noMoreOperators() - Method in class io.prestosql.operator.OrderByOperator.OrderByOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.RowNumberOperator.RowNumberOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.SetBuilderOperator.SetBuilderOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.SpatialIndexBuilderOperator.SpatialIndexBuilderOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.SpatialJoinOperator.SpatialJoinOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.StatisticsWriterOperator.StatisticsWriterOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.TableDeleteOperator.TableDeleteOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.TableFinishOperator.TableFinishOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.TableScanOperator.TableScanOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.TableWriterOperator.TableWriterOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.TaskOutputOperator.TaskOutputOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.TopNRowNumberOperator.TopNRowNumberOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.unnest.UnnestOperator.UnnestOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.ValuesOperator.ValuesOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.WindowOperator.WindowOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator.WorkProcessorPipelineSourceOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.testing.NullOutputOperator.NullOutputOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.testing.PageConsumerOperator.PageConsumerOperatorFactory
 
noMoreOperators(Lifespan) - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator.LocalExchangeSinkOperatorFactory
 
noMoreOperators(Lifespan) - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
noMoreOperators(Lifespan) - Method in class io.prestosql.operator.LookupOuterOperator.LookupOuterOperatorFactory
 
noMoreOperators(Lifespan) - Method in class io.prestosql.operator.NestedLoopJoinOperator.NestedLoopJoinOperatorFactory
 
noMoreOperators(Lifespan) - Method in interface io.prestosql.operator.OperatorFactory
Declare that createOperator will not be called any more for the specified Lifespan, and release any resources associated with this factory.
noMoreOperators(Lifespan) - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator.WorkProcessorPipelineSourceOperatorFactory
 
noMoreOutput() - Method in class io.prestosql.operator.TopNProcessor
 
noMoreSinkFactories() - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeFactory
 
noMoreSinkFactories() - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeSinkFactory
 
noMoreSplits() - Method in class io.prestosql.operator.ExchangeOperator
 
noMoreSplits() - Method in class io.prestosql.operator.index.IndexSourceOperator
 
noMoreSplits() - Method in class io.prestosql.operator.MergeOperator
 
noMoreSplits() - Method in interface io.prestosql.operator.SourceOperator
 
noMoreSplits() - Method in class io.prestosql.operator.TableScanOperator
 
noMoreSplits() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
noMoreSplits() - Method in class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
noMoreSplits(PlanNodeId) - Method in interface io.prestosql.execution.RemoteTask
 
noMoreSplits(PlanNodeId) - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
noMoreSplits(PlanNodeId, Lifespan) - Method in interface io.prestosql.execution.RemoteTask
 
noMoreSplits(PlanNodeId, Lifespan) - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
none() - Static method in enum io.prestosql.execution.buffer.PageCodecMarker
The byte value of no PageCodecMarker values set to true
none() - Static method in class io.prestosql.sql.planner.optimizations.LocalProperties
 
NONE - io.prestosql.memory.MemoryManagerConfig.LowMemoryKillerPolicy
 
NONE - io.prestosql.sql.analyzer.FeaturesConfig.DataIntegrityVerification
 
NONE - io.prestosql.sql.analyzer.FeaturesConfig.JoinReorderingStrategy
 
NoneLowMemoryKiller - Class in io.prestosql.memory
 
NoneLowMemoryKiller() - Constructor for class io.prestosql.memory.NoneLowMemoryKiller
 
noneMatchBoolean(Type, Block, BooleanToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayNoneMatchFunction
 
noneMatchDouble(Type, Block, DoubleToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayNoneMatchFunction
 
noneMatchLong(Type, Block, LongToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayNoneMatchFunction
 
noneMatchObject(Type, Block, ObjectToBooleanFunction) - Static method in class io.prestosql.operator.scalar.ArrayNoneMatchFunction
 
nonInferrableConjuncts(Metadata, Expression) - Static method in class io.prestosql.sql.planner.EqualityInference
Provides a convenience Iterable of Expression conjuncts which have not been added to the inference
nonTracking(Supplier<LookupSource>) - Static method in interface io.prestosql.operator.TrackingLookupSourceSupplier
 
NOOP - Static variable in interface io.prestosql.execution.warnings.WarningCollector
 
NOOP - Static variable in interface io.prestosql.operator.UpdateMemory
 
NoOpFailureDetector - Class in io.prestosql.failuredetector
 
NoOpFailureDetector() - Constructor for class io.prestosql.failuredetector.NoOpFailureDetector
 
NoOpResourceGroupManager - Class in io.prestosql.execution.resourcegroups
Used on workers.
NoOpResourceGroupManager() - Constructor for class io.prestosql.execution.resourcegroups.NoOpResourceGroupManager
 
NoOpSessionSupplier - Class in io.prestosql.server
Used on workers.
NoOpSessionSupplier() - Constructor for class io.prestosql.server.NoOpSessionSupplier
 
NoOpSymbolResolver - Class in io.prestosql.sql.planner
 
NoOpSymbolResolver() - Constructor for class io.prestosql.sql.planner.NoOpSymbolResolver
 
NoOpTransactionManager - Class in io.prestosql.transaction
Used on workers.
NoOpTransactionManager() - Constructor for class io.prestosql.transaction.NoOpTransactionManager
 
normalCdf(double, double, double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
normalize(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
normalize(PlanNodeStatsEstimate, TypeProvider) - Method in class io.prestosql.cost.StatsNormalizer
 
normalize(PlanNodeStatsEstimate, Collection<Symbol>, TypeProvider) - Method in class io.prestosql.cost.StatsNormalizer
 
normalize(List<? extends LocalProperty<T>>) - Static method in class io.prestosql.sql.planner.optimizations.LocalProperties
Normalizes the local properties by removing redundant symbols, but retains the original local property positions
normalizeAndPrune(List<? extends LocalProperty<T>>) - Static method in class io.prestosql.sql.planner.optimizations.LocalProperties
Normalizes the local properties and potentially consolidates it to the smallest possible list NOTE: When normalized, each symbol will only appear once
NoSubqueryExpressionLeftChecker - Class in io.prestosql.sql.planner.sanity
 
NoSubqueryExpressionLeftChecker() - Constructor for class io.prestosql.sql.planner.sanity.NoSubqueryExpressionLeftChecker
 
not(boolean) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
not(boolean) - Static method in class io.prestosql.type.BooleanOperators
 
NOT_BLOCKED - Static variable in interface io.prestosql.operator.Operator
 
NotInTransactionException - Exception in io.prestosql
 
NotInTransactionException() - Constructor for exception io.prestosql.NotInTransactionException
 
NotInTransactionException(TransactionId) - Constructor for exception io.prestosql.NotInTransactionException
 
now(ConnectorSession) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
NoWebUiAuthenticationFilter - Class in io.prestosql.server.ui
 
NoWebUiAuthenticationFilter() - Constructor for class io.prestosql.server.ui.NoWebUiAuthenticationFilter
 
nowInMillis() - Method in class io.prestosql.execution.QueryIdGenerator
 
NthValueFunction - Class in io.prestosql.operator.window
 
NthValueFunction(List<Integer>, boolean) - Constructor for class io.prestosql.operator.window.NthValueFunction
 
NTileFunction - Class in io.prestosql.operator.window
 
NTileFunction(List<Integer>) - Constructor for class io.prestosql.operator.window.NTileFunction
 
NULL_HASH_CODE - Static variable in class io.prestosql.type.TypeUtils
 
NULL_IF - io.prestosql.sql.relational.SpecialForm.Form
 
NULL_VALUE - Static variable in interface io.prestosql.operator.aggregation.state.TriStateBooleanState
 
NullabilityAnalyzer - Class in io.prestosql.sql.planner
 
NULLABLE_BLOCK_INPUT_CHANNEL - io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata.ParameterType
 
NullableBooleanState - Interface in io.prestosql.operator.aggregation.state
 
NullableBooleanStateSerializer - Class in io.prestosql.operator.aggregation.state
 
NullableBooleanStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.NullableBooleanStateSerializer
 
NullableDoubleState - Interface in io.prestosql.operator.aggregation.state
 
NullableDoubleStateSerializer - Class in io.prestosql.operator.aggregation.state
 
NullableDoubleStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.NullableDoubleStateSerializer
 
NullableLongState - Interface in io.prestosql.operator.aggregation.state
 
NullableLongStateSerializer - Class in io.prestosql.operator.aggregation.state
 
NullableLongStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.NullableLongStateSerializer
 
NullablePosition - Annotation Type in io.prestosql.operator.aggregation
 
nullableResult(boolean) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
NullIfCodeGenerator - Class in io.prestosql.sql.gen
 
NullIfCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.NullIfCodeGenerator
 
NullOutputFactory() - Constructor for class io.prestosql.testing.NullOutputOperator.NullOutputFactory
 
NullOutputOperator - Class in io.prestosql.testing
 
NullOutputOperator(OperatorContext) - Constructor for class io.prestosql.testing.NullOutputOperator
 
NullOutputOperator.NullOutputFactory - Class in io.prestosql.testing
 
NullOutputOperator.NullOutputOperatorFactory - Class in io.prestosql.testing
 
NullOutputOperatorFactory(int, PlanNodeId) - Constructor for class io.prestosql.testing.NullOutputOperator.NullOutputOperatorFactory
 
number() - Method in class io.prestosql.operator.PartitionedConsumption.Partition
 
NUMBER_OF_BUCKETS - Static variable in class io.prestosql.type.setdigest.SetDigest
 
numberOfElements - Variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
NumericHistogram - Class in io.prestosql.operator.aggregation
 
NumericHistogram(int) - Constructor for class io.prestosql.operator.aggregation.NumericHistogram
 
NumericHistogram(int, int) - Constructor for class io.prestosql.operator.aggregation.NumericHistogram
 
NumericHistogram(Slice, int) - Constructor for class io.prestosql.operator.aggregation.NumericHistogram
 
NumericHistogramStateFactory - Class in io.prestosql.operator.aggregation
 
NumericHistogramStateFactory() - Constructor for class io.prestosql.operator.aggregation.NumericHistogramStateFactory
 
NumericHistogramStateFactory.GroupedState - Class in io.prestosql.operator.aggregation
 
NumericHistogramStateFactory.SingleState - Class in io.prestosql.operator.aggregation
 

O

OAuth2CallbackResource - Class in io.prestosql.server.security.oauth2
 
OAuth2CallbackResource(OAuth2Service) - Constructor for class io.prestosql.server.security.oauth2.OAuth2CallbackResource
 
OAuth2Client - Interface in io.prestosql.server.security.oauth2
 
OAuth2Client.AccessToken - Class in io.prestosql.server.security.oauth2
 
OAuth2Config - Class in io.prestosql.server.security.oauth2
 
OAuth2Config() - Constructor for class io.prestosql.server.security.oauth2.OAuth2Config
 
OAuth2Service - Class in io.prestosql.server.security.oauth2
 
OAuth2Service(OAuth2Client, SigningKeyResolver, OAuth2Config) - Constructor for class io.prestosql.server.security.oauth2.OAuth2Service
 
OAuth2Service.OAuthResult - Class in io.prestosql.server.security.oauth2
 
OAuth2ServiceModule - Class in io.prestosql.server.security.oauth2
 
OAuth2ServiceModule() - Constructor for class io.prestosql.server.security.oauth2.OAuth2ServiceModule
 
OAuth2WebUiAuthenticationFilter - Class in io.prestosql.server.ui
 
OAuth2WebUiAuthenticationFilter(OAuth2Service, OAuth2Config) - Constructor for class io.prestosql.server.ui.OAuth2WebUiAuthenticationFilter
 
OAuth2WebUiLogoutResource - Class in io.prestosql.server.ui
 
OAuth2WebUiLogoutResource() - Constructor for class io.prestosql.server.ui.OAuth2WebUiLogoutResource
 
OAuth2WebUiModule - Class in io.prestosql.server.ui
 
OAuth2WebUiModule() - Constructor for class io.prestosql.server.ui.OAuth2WebUiModule
 
OAuthResult(String, Instant) - Constructor for class io.prestosql.server.security.oauth2.OAuth2Service.OAuthResult
 
OAuthWebUiCookie - Class in io.prestosql.server.ui
 
ObjectAndBlockPositionValueState - Interface in io.prestosql.operator.aggregation.minmaxby
 
objectArrayMax(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMaxFunction
 
objectArrayMin(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMinFunction
 
ObjectBooleanState - Interface in io.prestosql.operator.aggregation.minmaxby
 
ObjectDoubleState - Interface in io.prestosql.operator.aggregation.minmaxby
 
ObjectFieldJsonExtractor(String, JsonExtract.JsonExtractor<? extends T>) - Constructor for class io.prestosql.operator.scalar.JsonExtract.ObjectFieldJsonExtractor
 
ObjectFieldJsonExtractor(String, JsonExtract.JsonExtractor<? extends T>, boolean) - Constructor for class io.prestosql.operator.scalar.JsonExtract.ObjectFieldJsonExtractor
 
ObjectLongState - Interface in io.prestosql.operator.aggregation.minmaxby
 
objectSubscript(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
ObjectToBooleanFunction - Interface in io.prestosql.operator.scalar
 
of() - Static method in class io.prestosql.sql.planner.plan.Assignments
 
of(double, double, double) - Static method in class io.prestosql.cost.LocalCostEstimate
 
of(PageCodecMarker) - Static method in class io.prestosql.execution.buffer.PageCodecMarker.MarkerSet
 
of(Session) - Static method in class io.prestosql.security.SecurityContext
 
of(SchemaTableName) - Static method in enum io.prestosql.connector.informationschema.InformationSchemaTable
 
of(Symbol, Expression) - Static method in class io.prestosql.sql.planner.plan.Assignments
 
of(Symbol, Expression, Symbol, Expression) - Static method in class io.prestosql.sql.planner.plan.Assignments
 
of(Node) - Static method in class io.prestosql.sql.analyzer.RelationId
Creates RelationId equal to any RelationId created from exactly the same source.
of(Collection<? extends Expression>, Session, SymbolAllocator, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.plan.Assignments
 
of(Supplier<AccessControl>) - Static method in class io.prestosql.security.ForwardingAccessControl
 
of(T...) - Static method in class io.prestosql.operator.ParametricImplementationsGroup
 
of(T...) - Static method in interface io.prestosql.operator.WorkProcessor
 
ofCpu(double) - Static method in class io.prestosql.cost.LocalCostEstimate
 
offer(PrioritizedSplitRunner) - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
During periods of time when a level has no waiting splits, it will not accumulate scheduled time and will fall behind relative to other levels.
offset() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
OffsetNode - Class in io.prestosql.sql.planner.plan
 
OffsetNode(PlanNodeId, PlanNode, long) - Constructor for class io.prestosql.sql.planner.plan.OffsetNode
 
ofNetwork(double) - Static method in class io.prestosql.cost.LocalCostEstimate
 
ofPlanNode(PlanNode) - Static method in class io.prestosql.sql.planner.iterative.Rule.Result
 
ofResult(T) - Static method in class io.prestosql.operator.WorkProcessor.ProcessState
Signals that process has produced a result.
ofResult(T) - Static method in class io.prestosql.operator.WorkProcessor.TransformationState
Signals that transformation has produced a result from its input.
ofResult(T, boolean) - Static method in class io.prestosql.operator.WorkProcessor.TransformationState
Signals that transformation has produced a result.
OMIT_DATETIME_TYPE_PRECISION - Static variable in class io.prestosql.SystemSessionProperties
 
onFailure(Throwable) - Method in class io.prestosql.server.remotetask.SimpleHttpResponseHandler
 
onLifespanFinished(Iterable<Lifespan>) - Method in class io.prestosql.execution.scheduler.group.DynamicLifespanScheduler
 
onLifespanFinished(Iterable<Lifespan>) - Method in class io.prestosql.execution.scheduler.group.FixedLifespanScheduler
 
onLifespanFinished(Iterable<Lifespan>) - Method in interface io.prestosql.execution.scheduler.group.LifespanScheduler
 
onMemoryReserved(MemoryPool) - Method in interface io.prestosql.memory.MemoryPoolListener
Invoked when memory reservation completes successfully.
onMemoryReserved(Consumer<? super MemoryPool>) - Static method in interface io.prestosql.memory.MemoryPoolListener
onShutdown() - Method in class io.prestosql.server.DefaultShutdownAction
 
onShutdown() - Method in interface io.prestosql.server.ShutdownAction
 
onShutdown() - Method in class io.prestosql.server.testing.TestingPrestoServer.TestShutdownAction
 
onSuccess(FullJsonResponseHandler.JsonResponse<T>) - Method in class io.prestosql.server.remotetask.SimpleHttpResponseHandler
 
OPEN - io.prestosql.execution.buffer.BufferState
Additional buffers can be added.
Operator - Interface in io.prestosql.operator
 
OperatorContext - Class in io.prestosql.operator
Contains information about Operator execution.
OperatorContext(int, PlanNodeId, String, DriverContext, Executor, MemoryTrackingContext) - Constructor for class io.prestosql.operator.OperatorContext
 
OperatorFactory - Interface in io.prestosql.operator
 
OperatorImplementationDependency - Class in io.prestosql.operator.annotations
 
OperatorImplementationDependency(OperatorType, List<TypeSignature>, InvocationConvention, Class<?>) - Constructor for class io.prestosql.operator.annotations.OperatorImplementationDependency
 
OperatorInfo - Interface in io.prestosql.operator
 
operatorInputStats - Variable in class io.prestosql.sql.planner.planprinter.PlanNodeStats
 
OperatorNotFoundException - Exception in io.prestosql.metadata
 
OperatorNotFoundException(OperatorType, List<? extends Type>) - Constructor for exception io.prestosql.metadata.OperatorNotFoundException
 
OperatorNotFoundException(OperatorType, List<? extends Type>, TypeSignature) - Constructor for exception io.prestosql.metadata.OperatorNotFoundException
 
OperatorStats - Class in io.prestosql.operator
 
OperatorStats(int, int, int, PlanNodeId, String, long, long, Duration, Duration, DataSize, long, DataSize, long, DataSize, DataSize, long, double, long, Duration, Duration, DataSize, long, long, DataSize, Duration, long, Duration, Duration, DataSize, DataSize, DataSize, DataSize, DataSize, DataSize, DataSize, DataSize, Optional<BlockedReason>, OperatorInfo) - Constructor for class io.prestosql.operator.OperatorStats
 
operatorType(OperatorType) - Method in class io.prestosql.metadata.SignatureBuilder
 
OperatorValidator - Class in io.prestosql.operator.scalar.annotations
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.iterative.IterativeOptimizer
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveUnsupportedDynamicFilters
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.AddExchanges
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.AddLocalExchanges
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.BeginTableWrite
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.CheckSubqueryNodesAreRewritten
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.HashGenerationOptimizer
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.IndexJoinOptimizer
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.LimitPushDown
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.MetadataQueryOptimizer
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.OptimizeMixedDistinctAggregations
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in interface io.prestosql.sql.planner.optimizations.PlanOptimizer
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.PredicatePushDown
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.PruneUnreferencedOutputs
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.ReplicateSemiJoinInDelete
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.StatsRecordingPlanOptimizer
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.TableDeleteOptimizer
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.TransformQuantifiedComparisonApplyToCorrelatedJoin
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.UnaliasSymbolReferences
 
optimize(PlanNode, Session, TypeProvider, SymbolAllocator, PlanNodeIdAllocator, WarningCollector) - Method in class io.prestosql.sql.planner.optimizations.WindowFilterPushDown
 
optimize(SymbolResolver) - Method in class io.prestosql.sql.planner.ExpressionInterpreter
 
optimize(RowExpression) - Method in class io.prestosql.sql.relational.optimizer.ExpressionOptimizer
 
OPTIMIZE_DISTINCT_AGGREGATIONS - Static variable in class io.prestosql.SystemSessionProperties
 
OPTIMIZE_HASH_GENERATION - Static variable in class io.prestosql.SystemSessionProperties
 
OPTIMIZE_METADATA_QUERIES - Static variable in class io.prestosql.SystemSessionProperties
 
OPTIMIZE_TOP_N_ROW_NUMBER - Static variable in class io.prestosql.SystemSessionProperties
 
OPTIMIZED - io.prestosql.sql.planner.LogicalPlanner.Stage
 
OPTIMIZED_AND_VALIDATED - io.prestosql.sql.planner.LogicalPlanner.Stage
 
OptimizeMixedDistinctAggregations - Class in io.prestosql.sql.planner.optimizations
 
OptimizeMixedDistinctAggregations(Metadata) - Constructor for class io.prestosql.sql.planner.optimizations.OptimizeMixedDistinctAggregations
 
OptimizerStats - Class in io.prestosql.sql.planner.optimizations
 
OptimizerStats() - Constructor for class io.prestosql.sql.planner.optimizations.OptimizerStats
 
OptimizerStatsRecorder - Class in io.prestosql.sql.planner
 
OptimizerStatsRecorder() - Constructor for class io.prestosql.sql.planner.OptimizerStatsRecorder
 
Optionals - Class in io.prestosql.util
 
or(boolean, boolean) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
or(Expression...) - Static method in class io.prestosql.sql.ExpressionUtils
 
or(Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
OR - io.prestosql.sql.relational.SpecialForm.Form
 
OrCodeGenerator - Class in io.prestosql.sql.gen
 
OrCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.OrCodeGenerator
 
order(Block, int, Block, int) - Method in interface io.prestosql.type.BlockTypeOperators.BlockPositionOrdering
 
orderableTypeParameter(String) - Static method in class io.prestosql.metadata.Signature
 
orderableWithVariadicBound(String, String) - Static method in class io.prestosql.metadata.Signature
 
OrderByOperator - Class in io.prestosql.operator
 
OrderByOperator(OperatorContext, List<Type>, List<Integer>, int, List<Integer>, List<SortOrder>, PagesIndex.Factory, boolean, Optional<SpillerFactory>, OrderingCompiler) - Constructor for class io.prestosql.operator.OrderByOperator
 
OrderByOperator.OrderByOperatorFactory - Class in io.prestosql.operator
 
OrderByOperatorFactory(int, PlanNodeId, List<? extends Type>, List<Integer>, int, List<Integer>, List<SortOrder>, PagesIndex.Factory, boolean, Optional<SpillerFactory>, OrderingCompiler) - Constructor for class io.prestosql.operator.OrderByOperator.OrderByOperatorFactory
 
OrderingCompiler - Class in io.prestosql.sql.gen
 
OrderingCompiler(TypeOperators) - Constructor for class io.prestosql.sql.gen.OrderingCompiler
 
OrderingScheme - Class in io.prestosql.sql.planner
 
OrderingScheme(List<Symbol>, Map<Symbol, SortOrder>) - Constructor for class io.prestosql.sql.planner.OrderingScheme
 
OuterLookupSource - Class in io.prestosql.operator
 
outerOperatorClosed(Lifespan) - Method in class io.prestosql.operator.JoinBridgeManager
 
outerOperatorCreated(Lifespan) - Method in class io.prestosql.operator.JoinBridgeManager
 
outerOperatorFactoryClosed(Lifespan) - Method in class io.prestosql.operator.JoinBridgeManager
 
OuterOperatorFactoryResult(OperatorFactory, PipelineExecutionStrategy) - Constructor for class io.prestosql.operator.JoinOperatorFactory.OuterOperatorFactoryResult
 
OuterPositionIterator - Interface in io.prestosql.operator
 
output() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
output(BigintApproximateMostFrequent.State, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.BigintApproximateMostFrequent
 
output(DoubleHistogramAggregation.State, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DoubleHistogramAggregation
 
output(DoubleHistogramAggregation.State, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealHistogramAggregation
 
output(LongDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DoubleSumAggregation
 
output(LongLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.LongSumAggregation
 
output(HyperLogLogState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.MergeHyperLogLogAggregation
 
output(KeyValuePairsState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.MapAggregationFunction
 
output(KeyValuePairsState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.MapUnionAggregation
 
output(LongAndDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.AverageAggregations
 
output(LongAndDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.GeometricMeanAggregations
 
output(LongAndDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondAverageAggregation
 
output(LongAndDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthAverageAggregation
 
output(LongAndDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealGeometricMeanAggregations
 
output(LongState, DoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
output(LongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.CountAggregation
 
output(LongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.CountColumn
 
output(LongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.CountIfAggregation
 
output(NullableDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealSumAggregation
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.BitwiseAndAggregation
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.BitwiseOrAggregation
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondSumAggregation
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthSumAggregation
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.MaxDataSizeForStats
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.SumDataSizeForStats
 
output(QuantileDigestAndPercentileState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
output(QuantileDigestAndPercentileState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
output(QuantileDigestAndPercentileState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
output(QuantileDigestStateSerializer, QuantileDigestState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
output(TDigestAndPercentileArrayState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileArrayAggregations
 
output(TDigestAndPercentileArrayState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileArrayAggregations
 
output(TDigestAndPercentileArrayState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileArrayAggregations
 
output(TDigestAndPercentileState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
output(TDigestAndPercentileState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
output(TDigestAndPercentileState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
output(TDigestState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.MergeTDigestAggregation
 
output(TDigestState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.TDigestAggregationFunction
 
output(TriStateBooleanState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.BooleanAndAggregation
 
output(TriStateBooleanState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.BooleanOrAggregation
 
output(VarcharApproximateMostFrequent.State, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.VarcharApproximateMostFrequent
 
output(ArrayType, MinMaxByNState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
output(ArrayType, MinMaxNState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
output(Type, ArrayAggregationState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
output(Type, HistogramState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.histogram.Histogram
 
output(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, Type, MultimapAggregationState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
output(SetDigestState, BlockBuilder) - Static method in class io.prestosql.type.setdigest.BuildSetDigestAggregation
 
output(SetDigestState, BlockBuilder) - Static method in class io.prestosql.type.setdigest.MergeSetDigestAggregation
 
Output - Class in io.prestosql.sql.analyzer
 
Output(String, String, String) - Constructor for class io.prestosql.sql.analyzer.Output
 
OutputBuffer - Interface in io.prestosql.execution.buffer
 
OutputBufferId(int) - Constructor for class io.prestosql.execution.buffer.OutputBuffers.OutputBufferId
 
OutputBufferInfo - Class in io.prestosql.execution.buffer
 
OutputBufferInfo(String, BufferState, boolean, boolean, long, long, long, long, List<BufferInfo>) - Constructor for class io.prestosql.execution.buffer.OutputBufferInfo
 
OutputBuffers - Class in io.prestosql.execution.buffer
 
OutputBuffers(OutputBuffers.BufferType, long, boolean, Map<OutputBuffers.OutputBufferId, Integer>) - Constructor for class io.prestosql.execution.buffer.OutputBuffers
 
OutputBuffers.BufferType - Enum in io.prestosql.execution.buffer
 
OutputBuffers.OutputBufferId - Class in io.prestosql.execution.buffer
 
OutputFactory - Interface in io.prestosql.operator
 
outputLongDecimal(DecimalType, LongDecimalWithOverflowAndLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
outputLongDecimal(DecimalType, LongDecimalWithOverflowState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DecimalSumAggregation
 
OutputNode - Class in io.prestosql.sql.planner.plan
 
OutputNode(PlanNodeId, PlanNode, List<String>, List<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.OutputNode
 
outputShortDecimal(DecimalType, LongDecimalWithOverflowAndLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
OutputStatsRule - Class in io.prestosql.cost
 
OutputStatsRule() - Constructor for class io.prestosql.cost.OutputStatsRule
 
outputSymbolMap(int) - Method in class io.prestosql.sql.planner.plan.SetOperationNode
Returns the input to output symbol mapping for the given source channel.
OutputTableHandle - Class in io.prestosql.metadata
 
OutputTableHandle(CatalogName, ConnectorTransactionHandle, ConnectorOutputTableHandle) - Constructor for class io.prestosql.metadata.OutputTableHandle
 
outputTableHandleModule(HandleResolver) - Static method in class io.prestosql.metadata.HandleJsonModule
 
overflow - Variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
overflows - Variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
overlapPercentWith(StatisticRange) - Method in class io.prestosql.cost.StatisticRange
 

P

packDateTimeWithZone(DateTime) - Static method in class io.prestosql.util.DateTimeZoneIndex
 
page(Page) - Method in class io.prestosql.testing.MaterializedResult.Builder
 
pageBlockGetter(Page) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
PageBuffer - Class in io.prestosql.operator.index
 
PageBuffer - Class in io.prestosql.operator
Provides a bridge between classic Operator push input model and WorkProcessorOperator pull model.
PageBuffer() - Constructor for class io.prestosql.operator.PageBuffer
 
PageBuffer(int) - Constructor for class io.prestosql.operator.index.PageBuffer
 
PageBuffer(ListenableFuture<?>) - Constructor for class io.prestosql.operator.PageBuffer
 
PageBufferClientStatus - Class in io.prestosql.operator
 
PageBufferClientStatus(URI, String, DateTime, long, int, OptionalLong, OptionalInt, int, int, int, String) - Constructor for class io.prestosql.operator.PageBufferClientStatus
 
PageBufferInfo - Class in io.prestosql.execution.buffer
 
PageBufferInfo(int, long, long, long, long) - Constructor for class io.prestosql.execution.buffer.PageBufferInfo
 
PageBufferOperator - Class in io.prestosql.operator.index
 
PageBufferOperator(OperatorContext, PageBuffer) - Constructor for class io.prestosql.operator.index.PageBufferOperator
 
PageBufferOperator.PageBufferOperatorFactory - Class in io.prestosql.operator.index
 
PageBufferOperatorFactory(int, PlanNodeId, PageBuffer) - Constructor for class io.prestosql.operator.index.PageBufferOperator.PageBufferOperatorFactory
 
PageChannelSelector - Class in io.prestosql.operator.exchange
 
PageChannelSelector(int...) - Constructor for class io.prestosql.operator.exchange.PageChannelSelector
 
PageCodecMarker - Enum in io.prestosql.execution.buffer
Encodes boolean properties for SerializedPage by using a bitmasking strategy, allowing up to 8 such properties to be stored in a single byte
PageCodecMarker.MarkerSet - Class in io.prestosql.execution.buffer
 
PageConsumerOperator - Class in io.prestosql.testing
 
PageConsumerOperator(OperatorContext, Consumer<Page>, Function<Page, Page>) - Constructor for class io.prestosql.testing.PageConsumerOperator
 
PageConsumerOperator.PageConsumerOperatorFactory - Class in io.prestosql.testing
 
PageConsumerOperator.PageConsumerOutputFactory - Class in io.prestosql.testing
 
PageConsumerOperatorFactory(int, PlanNodeId, Consumer<Page>, Function<Page, Page>) - Constructor for class io.prestosql.testing.PageConsumerOperator.PageConsumerOperatorFactory
 
PageConsumerOutputFactory(Function<List<Type>, Consumer<Page>>) - Constructor for class io.prestosql.testing.PageConsumerOperator.PageConsumerOutputFactory
 
PageFieldsToInputParametersRewriter - Class in io.prestosql.operator.project
Rewrite input references from columns in the input page (to the filter/project node) into a compact list that can be used for method parameters.
PageFieldsToInputParametersRewriter.Result - Class in io.prestosql.operator.project
 
PageFilter - Interface in io.prestosql.operator.project
 
PageFunctionCompiler - Class in io.prestosql.sql.gen
 
PageFunctionCompiler(Metadata, int) - Constructor for class io.prestosql.sql.gen.PageFunctionCompiler
 
PageFunctionCompiler(Metadata, CompilerConfig) - Constructor for class io.prestosql.sql.gen.PageFunctionCompiler
 
PageProcessor - Class in io.prestosql.operator.project
 
PageProcessor(Optional<PageFilter>, List<? extends PageProjection>) - Constructor for class io.prestosql.operator.project.PageProcessor
 
PageProcessor(Optional<PageFilter>, List<? extends PageProjection>, OptionalInt) - Constructor for class io.prestosql.operator.project.PageProcessor
 
PageProcessor(Optional<PageFilter>, List<? extends PageProjection>, OptionalInt, ExpressionProfiler) - Constructor for class io.prestosql.operator.project.PageProcessor
 
PageProjection - Interface in io.prestosql.operator.project
 
PageRecordSet - Class in io.prestosql.operator.index
 
PageRecordSet(List<Type>, Page) - Constructor for class io.prestosql.operator.index.PageRecordSet
 
PageRecordSet.PageRecordCursor - Class in io.prestosql.operator.index
 
pages() - Method in class io.prestosql.operator.exchange.LocalExchangeSource
 
pages() - Method in class io.prestosql.operator.ExchangeClient
 
pages() - Method in class io.prestosql.operator.PageBuffer
 
pages(Iterable<Page>) - Method in class io.prestosql.testing.MaterializedResult.Builder
 
PagesHash - Class in io.prestosql.operator
 
PagesHash(LongArrayList, PagesHashStrategy, PositionLinks.FactoryBuilder) - Constructor for class io.prestosql.operator.PagesHash
 
PagesHashStrategy - Interface in io.prestosql.operator
 
PagesHashStrategyFactory(Class<? extends PagesHashStrategy>) - Constructor for class io.prestosql.sql.gen.JoinCompiler.PagesHashStrategyFactory
 
PagesIndex - Class in io.prestosql.operator
PagesIndex a low-level data structure which contains the address of every value position of every channel.
PagesIndex.DefaultFactory - Class in io.prestosql.operator
 
PagesIndex.Factory - Interface in io.prestosql.operator
 
PagesIndex.TestingFactory - Class in io.prestosql.operator
 
PagesIndexBuilderOperator - Class in io.prestosql.operator.index
 
PagesIndexBuilderOperator(OperatorContext, IndexSnapshotBuilder) - Constructor for class io.prestosql.operator.index.PagesIndexBuilderOperator
 
PagesIndexBuilderOperator.PagesIndexBuilderOperatorFactory - Class in io.prestosql.operator.index
 
PagesIndexBuilderOperatorFactory(int, PlanNodeId, IndexSnapshotBuilder) - Constructor for class io.prestosql.operator.index.PagesIndexBuilderOperator.PagesIndexBuilderOperatorFactory
 
PagesIndexComparator - Interface in io.prestosql.operator
 
PagesIndexOrdering - Class in io.prestosql.operator
 
PagesIndexOrdering(PagesIndexComparator) - Constructor for class io.prestosql.operator.PagesIndexOrdering
 
PagesIndexPageSorter - Class in io.prestosql
 
PagesIndexPageSorter(PagesIndex.Factory) - Constructor for class io.prestosql.PagesIndexPageSorter
 
PageSinkManager - Class in io.prestosql.split
 
PageSinkManager() - Constructor for class io.prestosql.split.PageSinkManager
 
PageSinkProvider - Interface in io.prestosql.split
 
pageSource(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.RuleStatsSystemTable
 
PageSourceManager - Class in io.prestosql.split
 
PageSourceManager() - Constructor for class io.prestosql.split.PageSourceManager
 
PageSourceOperator - Class in io.prestosql.operator
 
PageSourceOperator(ConnectorPageSource, OperatorContext) - Constructor for class io.prestosql.operator.PageSourceOperator
 
PageSourceProvider - Interface in io.prestosql.split
 
PageSplitterUtil - Class in io.prestosql.execution.buffer
 
PagesResponseWriter - Class in io.prestosql.server
 
PagesResponseWriter(FeaturesConfig) - Constructor for class io.prestosql.server.PagesResponseWriter
 
PagesRTreeIndex - Class in io.prestosql.operator
 
PagesRTreeIndex(Session, LongArrayList, List<Type>, List<Integer>, List<List<Block>>, STRtree, Optional<Integer>, SpatialIndexBuilderOperator.SpatialPredicate, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, Map<Integer, Rectangle>) - Constructor for class io.prestosql.operator.PagesRTreeIndex
 
PagesRTreeIndex.GeometryWithPosition - Class in io.prestosql.operator
 
PagesSerde - Class in io.prestosql.execution.buffer
 
PagesSerde(BlockEncodingSerde, Optional<Compressor>, Optional<Decompressor>, Optional<SpillCipher>) - Constructor for class io.prestosql.execution.buffer.PagesSerde
 
PagesSerde.PagesSerdeContext - Class in io.prestosql.execution.buffer
 
PagesSerdeContext() - Constructor for class io.prestosql.execution.buffer.PagesSerde.PagesSerdeContext
 
PagesSerdeFactory - Class in io.prestosql.execution.buffer
 
PagesSerdeFactory(BlockEncodingSerde, boolean) - Constructor for class io.prestosql.execution.buffer.PagesSerdeFactory
 
PagesSerdeUtil - Class in io.prestosql.execution.buffer
 
PagesSpatialIndex - Interface in io.prestosql.operator
 
PagesSpatialIndexFactory - Class in io.prestosql.operator
This factory is used to pass spatial index built by SpatialIndexBuilderOperator to SpatialJoinOperators.
PagesSpatialIndexFactory(List<Type>, List<Type>) - Constructor for class io.prestosql.operator.PagesSpatialIndexFactory
 
PagesSpatialIndexSupplier - Class in io.prestosql.operator
 
PagesSpatialIndexSupplier(Session, LongArrayList, List<Type>, List<Integer>, List<List<Block>>, int, Optional<Integer>, Optional<Integer>, SpatialIndexBuilderOperator.SpatialPredicate, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, Map<Integer, Rectangle>) - Constructor for class io.prestosql.operator.PagesSpatialIndexSupplier
 
PagesWindowIndex - Class in io.prestosql.operator.window
 
PagesWindowIndex(PagesIndex, int, int) - Constructor for class io.prestosql.operator.window.PagesWindowIndex
 
PageTooLargeException - Exception in io.prestosql.operator
 
PageTooLargeException() - Constructor for exception io.prestosql.operator.PageTooLargeException
 
PageTransportErrorException - Exception in io.prestosql.operator
 
PageTransportErrorException(HostAddress, String) - Constructor for exception io.prestosql.operator.PageTransportErrorException
 
PageTransportErrorException(HostAddress, String, Throwable) - Constructor for exception io.prestosql.operator.PageTransportErrorException
 
PageTransportTimeoutException - Exception in io.prestosql.operator
 
PageTransportTimeoutException(HostAddress, String, Throwable) - Constructor for exception io.prestosql.operator.PageTransportTimeoutException
 
PageUtils - Class in io.prestosql.operator
 
PageWithPositionComparator - Interface in io.prestosql.operator
 
parameterExtractor(Statement, List<Expression>) - Static method in class io.prestosql.sql.ParameterUtils
 
ParameterExtractor - Class in io.prestosql.execution
 
ParameterMetadata(AggregationMetadata.ParameterMetadata.ParameterType) - Constructor for class io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata
 
ParameterMetadata(AggregationMetadata.ParameterMetadata.ParameterType, Type) - Constructor for class io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata
 
ParameterRewriter - Class in io.prestosql.sql.planner
 
ParameterRewriter(Analysis) - Constructor for class io.prestosql.sql.planner.ParameterRewriter
 
ParameterRewriter(Map<NodeRef<Parameter>, Expression>) - Constructor for class io.prestosql.sql.planner.ParameterRewriter
 
ParameterUtils - Class in io.prestosql.sql
 
ParametricAggregation - Class in io.prestosql.operator.aggregation
 
ParametricAggregation(Signature, AggregationHeader, ParametricImplementationsGroup<AggregationImplementation>, boolean) - Constructor for class io.prestosql.operator.aggregation.ParametricAggregation
 
ParametricFunctionHelpers - Class in io.prestosql.operator
 
ParametricImplementation - Interface in io.prestosql.operator
 
ParametricImplementationsGroup<T extends ParametricImplementation> - Class in io.prestosql.operator
This class represents set of three collections representing implementations of operators similar to partial template specialization from C++ allowing more optimized implementations to be provided for specific types.
ParametricImplementationsGroup(Map<Signature, T>, List<T>, List<T>, Signature) - Constructor for class io.prestosql.operator.ParametricImplementationsGroup
 
ParametricImplementationsGroup.Builder<T extends ParametricImplementation> - Class in io.prestosql.operator
 
ParametricScalar - Class in io.prestosql.operator.scalar
 
ParametricScalar(Signature, ScalarHeader, ParametricImplementationsGroup<ParametricScalarImplementation>, boolean) - Constructor for class io.prestosql.operator.scalar.ParametricScalar
 
ParametricScalarImplementation - Class in io.prestosql.operator.scalar.annotations
 
ParametricScalarImplementation.Builder - Class in io.prestosql.operator.scalar.annotations
 
ParametricScalarImplementation.ParametricScalarImplementationChoice - Class in io.prestosql.operator.scalar.annotations
 
ParametricScalarImplementation.Parser - Class in io.prestosql.operator.scalar.annotations
 
ParametricScalarImplementation.SpecializedSignature - Class in io.prestosql.operator.scalar.annotations
 
parentGroupContext(SelectionContext<LegacyResourceGroupConfigurationManager.VoidContext>) - Method in class io.prestosql.execution.resourcegroups.LegacyResourceGroupConfigurationManager
 
PARSE_DECIMAL_LITERALS_AS_DOUBLE - Static variable in class io.prestosql.SystemSessionProperties
 
parseClaimsJws(String) - Method in class io.prestosql.server.security.oauth2.OAuth2Service
 
parseDate(String) - Static method in class io.prestosql.util.DateTimeUtils
 
parseDatetime(ConnectorSession, Slice, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
parseDayTimeInterval(String, IntervalLiteral.IntervalField, Optional<IntervalLiteral.IntervalField>) - Static method in class io.prestosql.util.DateTimeUtils
 
parseDescription(AnnotatedElement) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
parseDescription(AnnotatedElement, AnnotatedElement) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
parseDuration(Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
parseFunctionDefinition(Class<?>) - Static method in class io.prestosql.operator.aggregation.AggregationFromAnnotationsParser
 
parseFunctionDefinition(Class<?>) - Static method in class io.prestosql.operator.scalar.annotations.ScalarFromAnnotationsParser
 
parseFunctionDefinition(Class<? extends WindowFunction>) - Static method in class io.prestosql.operator.window.WindowAnnotationsParser
 
parseFunctionDefinitions(Class<?>) - Static method in class io.prestosql.operator.aggregation.AggregationFromAnnotationsParser
 
parseFunctionDefinitions(Class<?>) - Static method in class io.prestosql.operator.scalar.annotations.ScalarFromAnnotationsParser
 
parseFunctionDefinitionWithTypesConstraint(Class<?>, TypeSignature, List<TypeSignature>) - Static method in class io.prestosql.operator.aggregation.AggregationFromAnnotationsParser
 
parseImplementation(Class<?>, AggregationHeader, Class<?>, Method, Optional<Method>, Method, Method) - Static method in class io.prestosql.operator.aggregation.AggregationImplementation.Parser
 
parseImplementationDependencies(Method) - Method in class io.prestosql.operator.aggregation.AggregationImplementation.Parser
 
parseJsonToSingleRowBlock(JsonParser, SingleRowBlockWriter, JsonUtil.BlockBuilderAppender[], Optional<Map<String, Integer>>) - Static method in class io.prestosql.util.JsonUtil
 
parseLegacyTime(TimeZoneKey, String) - Static method in class io.prestosql.util.DateTimeUtils
Deprecated.
applicable in legacy timestamp semantics only
parseLiteralParameters(Method) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
parseLongTimeWithTimeZone(String) - Static method in class io.prestosql.type.DateTimes
 
parseLongVariableConstraints(Method) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
parsePeriodMillis(PeriodFormatter, String, IntervalLiteral.IntervalField, IntervalLiteral.IntervalField) - Static method in class io.prestosql.util.DateTimeUtils
 
parsePrestoDataSize(Slice) - Static method in class io.prestosql.operator.scalar.DataSizeFunctions
 
parseShortTimeWithTimeZone(String) - Static method in class io.prestosql.type.DateTimes
 
parseSignatureArgumentsTypes(Method) - Static method in class io.prestosql.operator.aggregation.AggregationImplementation.Parser
 
parseTime(String) - Static method in class io.prestosql.type.DateTimes
 
parseTimestamp(int, String) - Static method in class io.prestosql.type.DateTimes
 
parseTimestampWithTimeZone(int, String) - Static method in class io.prestosql.type.DateTimes
 
parseTimeWithTimeZone(int, String) - Static method in class io.prestosql.type.DateTimes
 
parseTypeSignature(String, Set<String>) - Static method in class io.prestosql.sql.analyzer.TypeSignatureTranslator
 
parseYearMonthInterval(String, IntervalLiteral.IntervalField, Optional<IntervalLiteral.IntervalField>) - Static method in class io.prestosql.util.DateTimeUtils
 
ParsingUtil - Class in io.prestosql.sql
 
PARTIAL - io.prestosql.sql.planner.plan.AggregationNode.Step
 
PARTIAL - io.prestosql.sql.planner.plan.TopNNode.Step
 
partialCancel(QueryId, int, String, long) - Method in class io.prestosql.server.protocol.ExecutingStatementResource
 
partialInput(AggregationNode.Step) - Static method in enum io.prestosql.sql.planner.plan.AggregationNode.Step
 
partialOutput(AggregationNode.Step) - Static method in enum io.prestosql.sql.planner.plan.AggregationNode.Step
 
PartialTranslator - Class in io.prestosql.sql.planner
 
Partition(int, int, IntFunction<ListenableFuture<T>>, ListenableFuture<?>, IntConsumer) - Constructor for class io.prestosql.operator.PartitionedConsumption.Partition
 
partitionAndSpill(Page, IntPredicate) - Method in class io.prestosql.spiller.GenericPartitioningSpiller
 
partitionAndSpill(Page, IntPredicate) - Method in interface io.prestosql.spiller.PartitioningSpiller
Partition page and enqueue partitioned pages to spill writers.
PARTITIONED - io.prestosql.execution.buffer.OutputBuffers.BufferType
 
PARTITIONED - io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType
 
PARTITIONED - io.prestosql.sql.planner.plan.JoinNode.DistributionType
 
PARTITIONED - io.prestosql.sql.planner.plan.SemiJoinNode.DistributionType
 
PARTITIONED - io.prestosql.sql.planner.plan.SpatialJoinNode.DistributionType
 
PartitionedConsumption<T> - Class in io.prestosql.operator
 
PartitionedConsumption.Partition<T> - Class in io.prestosql.operator
 
partitionedExchange(PlanNodeId, ExchangeNode.Scope, PlanNode, PartitioningScheme) - Static method in class io.prestosql.sql.planner.plan.ExchangeNode
 
partitionedExchange(PlanNodeId, ExchangeNode.Scope, PlanNode, List<Symbol>, Optional<Symbol>) - Static method in class io.prestosql.sql.planner.plan.ExchangeNode
 
partitionedExchange(PlanNodeId, ExchangeNode.Scope, PlanNode, List<Symbol>, Optional<Symbol>, boolean) - Static method in class io.prestosql.sql.planner.plan.ExchangeNode
 
PartitionedLookupSource - Class in io.prestosql.operator
 
PartitionedLookupSourceFactory - Class in io.prestosql.operator
 
PartitionedLookupSourceFactory(List<Type>, List<Type>, List<Type>, int, boolean, BlockTypeOperators) - Constructor for class io.prestosql.operator.PartitionedLookupSourceFactory
 
partitionedOn(PartitioningHandle, List<Symbol>, Optional<List<Symbol>>) - Static method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
partitionedOn(Partitioning, Optional<Partitioning>) - Static method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
PartitionedOutputBuffer - Class in io.prestosql.execution.buffer
 
PartitionedOutputBuffer(String, StateMachine<BufferState>, OutputBuffers, DataSize, Supplier<LocalMemoryContext>, Executor) - Constructor for class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
PartitionedOutputBufferManager - Class in io.prestosql.execution.scheduler
 
PartitionedOutputBufferManager(PartitioningHandle, int, Consumer<OutputBuffers>) - Constructor for class io.prestosql.execution.scheduler.PartitionedOutputBufferManager
 
PartitionedOutputFactory(PartitionFunction, List<Integer>, List<Optional<NullableValue>>, boolean, OptionalInt, OutputBuffer, DataSize) - Constructor for class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputFactory
 
PartitionedOutputInfo(long, long, long) - Constructor for class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputInfo
 
PartitionedOutputOperator - Class in io.prestosql.operator
 
PartitionedOutputOperator(OperatorContext, List<Type>, Function<Page, Page>, PartitionFunction, List<Integer>, List<Optional<NullableValue>>, boolean, OptionalInt, OutputBuffer, PagesSerdeFactory, DataSize) - Constructor for class io.prestosql.operator.PartitionedOutputOperator
 
PartitionedOutputOperator.PartitionedOutputFactory - Class in io.prestosql.operator
 
PartitionedOutputOperator.PartitionedOutputInfo - Class in io.prestosql.operator
 
PartitionedOutputOperator.PartitionedOutputOperatorFactory - Class in io.prestosql.operator
 
PartitionedOutputOperatorFactory(int, PlanNodeId, List<Type>, Function<Page, Page>, PartitionFunction, List<Integer>, List<Optional<NullableValue>>, boolean, OptionalInt, OutputBuffer, PagesSerdeFactory, DataSize) - Constructor for class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputOperatorFactory
 
PartitionedSplitCountTracker(IntConsumer) - Constructor for class io.prestosql.execution.NodeTaskMap.PartitionedSplitCountTracker
 
PartitionFunction - Interface in io.prestosql.operator
 
Partitioning - Class in io.prestosql.sql.planner
 
Partitioning.ArgumentBinding - Class in io.prestosql.sql.planner
 
Partitioning.Translator - Class in io.prestosql.sql.planner
 
PartitioningHandle - Class in io.prestosql.sql.planner
 
PartitioningHandle(Optional<CatalogName>, Optional<ConnectorTransactionHandle>, ConnectorPartitioningHandle) - Constructor for class io.prestosql.sql.planner.PartitioningHandle
 
partitioningHandleModule(HandleResolver) - Static method in class io.prestosql.metadata.HandleJsonModule
 
PartitioningScheme - Class in io.prestosql.sql.planner
 
PartitioningScheme(Partitioning, List<Symbol>) - Constructor for class io.prestosql.sql.planner.PartitioningScheme
 
PartitioningScheme(Partitioning, List<Symbol>, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.PartitioningScheme
 
PartitioningScheme(Partitioning, List<Symbol>, Optional<Symbol>, boolean, Optional<int[]>) - Constructor for class io.prestosql.sql.planner.PartitioningScheme
 
PartitioningSpiller - Interface in io.prestosql.spiller
 
PartitioningSpiller.PartitioningSpillResult - Class in io.prestosql.spiller
 
PartitioningSpillerFactory - Interface in io.prestosql.spiller
 
PartitioningSpillResult(ListenableFuture<?>, Page) - Constructor for class io.prestosql.spiller.PartitioningSpiller.PartitioningSpillResult
 
partitions() - Method in class io.prestosql.operator.index.IndexLookupSourceFactory
 
partitions() - Method in interface io.prestosql.operator.LookupSourceFactory
 
partitions() - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
Parts(StatisticAggregations, StatisticAggregations, Map<Symbol, Symbol>) - Constructor for class io.prestosql.sql.planner.plan.StatisticAggregations.Parts
 
PassthroughExchanger - Class in io.prestosql.operator.exchange
 
PassthroughExchanger(LocalExchangeSource, long, LongConsumer) - Constructor for class io.prestosql.operator.exchange.PassthroughExchanger
 
PasswordAuthenticator - Class in io.prestosql.server.security
 
PasswordAuthenticator(PasswordAuthenticatorManager, PasswordAuthenticatorConfig) - Constructor for class io.prestosql.server.security.PasswordAuthenticator
 
PasswordAuthenticatorConfig - Class in io.prestosql.server.security
 
PasswordAuthenticatorConfig() - Constructor for class io.prestosql.server.security.PasswordAuthenticatorConfig
 
PasswordAuthenticatorManager - Class in io.prestosql.server.security
 
PasswordAuthenticatorManager() - Constructor for class io.prestosql.server.security.PasswordAuthenticatorManager
 
PasswordManagerFormAuthenticator - Class in io.prestosql.server.ui
 
PasswordManagerFormAuthenticator(PasswordAuthenticatorManager, SecurityConfig) - Constructor for class io.prestosql.server.ui.PasswordManagerFormAuthenticator
 
pattern() - Method in class io.prestosql.operator.scalar.JsonPath
 
pattern() - Method in class io.prestosql.type.JoniRegexp
 
pattern() - Method in class io.prestosql.type.Re2JRegexp
 
patternConstantPrefixBytes(Slice, Optional<Slice>) - Static method in class io.prestosql.type.LikeFunctions
 
Patterns - Class in io.prestosql.sql.planner.plan
 
Patterns.Aggregation - Class in io.prestosql.sql.planner.plan
 
Patterns.Apply - Class in io.prestosql.sql.planner.plan
 
Patterns.CorrelatedJoin - Class in io.prestosql.sql.planner.plan
 
Patterns.DistinctLimit - Class in io.prestosql.sql.planner.plan
 
Patterns.Except - Class in io.prestosql.sql.planner.plan
 
Patterns.Exchange - Class in io.prestosql.sql.planner.plan
 
Patterns.Intersect - Class in io.prestosql.sql.planner.plan
 
Patterns.Join - Class in io.prestosql.sql.planner.plan
 
Patterns.Limit - Class in io.prestosql.sql.planner.plan
 
Patterns.Sample - Class in io.prestosql.sql.planner.plan
 
Patterns.SemiJoin - Class in io.prestosql.sql.planner.plan
 
Patterns.TopN - Class in io.prestosql.sql.planner.plan
 
Patterns.Values - Class in io.prestosql.sql.planner.plan
 
payload() - Method in annotation type io.prestosql.util.PowerOfTwo
 
peek() - Method in class io.prestosql.execution.resourcegroups.IndexedPriorityQueue
 
PercentRankFunction - Class in io.prestosql.operator.window
 
PercentRankFunction() - Constructor for class io.prestosql.operator.window.PercentRankFunction
 
PhasedExecutionPolicy - Class in io.prestosql.execution.scheduler
 
PhasedExecutionPolicy() - Constructor for class io.prestosql.execution.scheduler.PhasedExecutionPolicy
 
PhasedExecutionSchedule - Class in io.prestosql.execution.scheduler
 
PhasedExecutionSchedule(Collection<SqlStageExecution>) - Constructor for class io.prestosql.execution.scheduler.PhasedExecutionSchedule
 
pi() - Static method in class io.prestosql.operator.scalar.MathFunctions
 
PICOSECONDS_PER_DAY - Static variable in class io.prestosql.type.DateTimes
 
PICOSECONDS_PER_HOUR - Static variable in class io.prestosql.type.DateTimes
 
PICOSECONDS_PER_MICROSECOND - Static variable in class io.prestosql.type.DateTimes
 
PICOSECONDS_PER_MILLISECOND - Static variable in class io.prestosql.type.DateTimes
 
PICOSECONDS_PER_MINUTE - Static variable in class io.prestosql.type.DateTimes
 
PICOSECONDS_PER_NANOSECOND - Static variable in class io.prestosql.type.DateTimes
 
PICOSECONDS_PER_SECOND - Static variable in class io.prestosql.type.DateTimes
 
PipelineContext - Class in io.prestosql.operator
 
PipelineContext(int, TaskContext, Executor, ScheduledExecutorService, MemoryTrackingContext, boolean, boolean, boolean) - Constructor for class io.prestosql.operator.PipelineContext
 
PipelineExecutionStrategy - Enum in io.prestosql.operator
 
PipelineStats - Class in io.prestosql.operator
 
PipelineStats(int, DateTime, DateTime, DateTime, boolean, boolean, int, int, int, int, int, int, int, DataSize, DataSize, DataSize, Distribution.DistributionSnapshot, Distribution.DistributionSnapshot, Duration, Duration, Duration, boolean, Set<BlockedReason>, DataSize, long, Duration, DataSize, long, DataSize, long, DataSize, long, DataSize, long, DataSize, List<OperatorStats>, List<DriverStats>) - Constructor for class io.prestosql.operator.PipelineStats
 
PipelineStatus - Class in io.prestosql.operator
 
PipelineStatus(int, int, int, int, int) - Constructor for class io.prestosql.operator.PipelineStatus
 
plan(TaskContext, StageExecutionDescriptor, PlanNode, List<Symbol>, TypeProvider, List<PlanNodeId>, OutputFactory) - Method in class io.prestosql.sql.planner.LocalExecutionPlanner
 
plan(TaskContext, PlanNode, TypeProvider, PartitioningScheme, StageExecutionDescriptor, List<PlanNodeId>, OutputBuffer) - Method in class io.prestosql.sql.planner.LocalExecutionPlanner
 
plan(Analysis) - Method in class io.prestosql.sql.planner.LogicalPlanner
 
plan(Analysis, LogicalPlanner.Stage) - Method in class io.prestosql.sql.planner.LogicalPlanner
 
plan(Analysis, LogicalPlanner.Stage, boolean) - Method in class io.prestosql.sql.planner.LogicalPlanner
 
plan(SubPlan, Session) - Method in class io.prestosql.sql.planner.DistributedExecutionPlanner
 
Plan - Class in io.prestosql.sql.planner
 
Plan(PlanNode, TypeProvider, StatsAndCosts) - Constructor for class io.prestosql.sql.planner.Plan
 
PLAN_WITH_TABLE_NODE_PARTITIONING - Static variable in class io.prestosql.SystemSessionProperties
 
PlanCopier - Class in io.prestosql.sql.planner
Clones plan and assigns new PlanNodeIds to the copied PlanNodes.
PlanCostEstimate - Class in io.prestosql.cost
 
PlanCostEstimate(double, double, double, double) - Constructor for class io.prestosql.cost.PlanCostEstimate
 
PlanCostEstimate(double, double, double, double, LocalCostEstimate) - Constructor for class io.prestosql.cost.PlanCostEstimate
 
PlanFragment - Class in io.prestosql.sql.planner
 
PlanFragment(PlanFragmentId, PlanNode, Map<Symbol, Type>, PartitioningHandle, List<PlanNodeId>, PartitioningScheme, StageExecutionDescriptor, StatsAndCosts, Optional<String>) - Constructor for class io.prestosql.sql.planner.PlanFragment
 
PlanFragmenter - Class in io.prestosql.sql.planner
Splits a logical plan into fragments that can be shipped and executed on distributed nodes
PlanFragmenter(Metadata, NodePartitioningManager, QueryManagerConfig) - Constructor for class io.prestosql.sql.planner.PlanFragmenter
 
PlanFragmentId - Class in io.prestosql.sql.planner.plan
 
PlanFragmentId(String) - Constructor for class io.prestosql.sql.planner.plan.PlanFragmentId
 
PLANNED - io.prestosql.execution.StageState
Stage is planned but has not been scheduled yet.
PLANNED - io.prestosql.execution.TaskState
Task is planned but has not been scheduled yet.
PLANNING - io.prestosql.execution.QueryState
Query is being planned.
PlanNode - Class in io.prestosql.sql.planner.plan
 
PlanNode(PlanNodeId) - Constructor for class io.prestosql.sql.planner.plan.PlanNode
 
PlanNodeDecorrelator - Class in io.prestosql.sql.planner.optimizations
 
PlanNodeDecorrelator(Metadata, SymbolAllocator, Lookup) - Constructor for class io.prestosql.sql.planner.optimizations.PlanNodeDecorrelator
 
PlanNodeDecorrelator.DecorrelatedNode - Class in io.prestosql.sql.planner.optimizations
 
PlanNodeId - Class in io.prestosql.sql.planner.plan
 
PlanNodeId(String) - Constructor for class io.prestosql.sql.planner.plan.PlanNodeId
 
PlanNodeIdAllocator - Class in io.prestosql.sql.planner
 
PlanNodeIdAllocator() - Constructor for class io.prestosql.sql.planner.PlanNodeIdAllocator
 
PlanNodeSearcher - Class in io.prestosql.sql.planner.optimizations
 
PlanNodeStats - Class in io.prestosql.sql.planner.planprinter
 
PlanNodeStatsAndCostSummary - Class in io.prestosql.cost
 
PlanNodeStatsAndCostSummary(double, double, double, double, double) - Constructor for class io.prestosql.cost.PlanNodeStatsAndCostSummary
 
PlanNodeStatsEstimate - Class in io.prestosql.cost
 
PlanNodeStatsEstimate(double, Map<Symbol, SymbolStatsEstimate>) - Constructor for class io.prestosql.cost.PlanNodeStatsEstimate
 
PlanNodeStatsEstimate.Builder - Class in io.prestosql.cost
 
PlanNodeStatsEstimateMath - Class in io.prestosql.cost
 
PlanNodeStatsSummarizer - Class in io.prestosql.sql.planner.planprinter
 
PlanNodeWithCost - Class in io.prestosql.sql.planner.iterative.rule
 
PlanNodeWithCost(PlanCostEstimate, PlanNode) - Constructor for class io.prestosql.sql.planner.iterative.rule.PlanNodeWithCost
 
PlanOptimizer - Interface in io.prestosql.sql.planner.optimizations
 
PlanOptimizers - Class in io.prestosql.sql.planner
 
PlanOptimizers(Metadata, TypeOperators, TypeAnalyzer, TaskManagerConfig, boolean, MBeanExporter, SplitManager, PageSourceManager, StatsCalculator, CostCalculator, CostCalculator, CostComparator, TaskCountEstimator, RuleStatsRecorder) - Constructor for class io.prestosql.sql.planner.PlanOptimizers
 
PlanOptimizers(Metadata, TypeOperators, TypeAnalyzer, TaskManagerConfig, MBeanExporter, SplitManager, PageSourceManager, StatsCalculator, CostCalculator, CostCalculator, CostComparator, TaskCountEstimator, RuleStatsRecorder) - Constructor for class io.prestosql.sql.planner.PlanOptimizers
 
PlanPrinter - Class in io.prestosql.sql.planner.planprinter
 
Plans - Class in io.prestosql.sql.planner.iterative
 
PlanSanityChecker - Class in io.prestosql.sql.planner.sanity
It is going to be executed to verify logical planner correctness
PlanSanityChecker(boolean) - Constructor for class io.prestosql.sql.planner.sanity.PlanSanityChecker
 
PlanSanityChecker.Checker - Interface in io.prestosql.sql.planner.sanity
 
planStatement(Analysis, Statement) - Method in class io.prestosql.sql.planner.LogicalPlanner
 
PlanVisitor<R,​C> - Class in io.prestosql.sql.planner.plan
 
PlanVisitor() - Constructor for class io.prestosql.sql.planner.plan.PlanVisitor
 
planWithTableNodePartitioning(Session) - Static method in class io.prestosql.SystemSessionProperties
 
PluginManager - Class in io.prestosql.server
 
PluginManager(NodeInfo, PluginManagerConfig, ConnectorManager, MetadataManager, ResourceGroupManager<?>, AccessControlManager, PasswordAuthenticatorManager, CertificateAuthenticatorManager, EventListenerManager, GroupProviderManager, SessionPropertyDefaults) - Constructor for class io.prestosql.server.PluginManager
 
PluginManagerConfig - Class in io.prestosql.server
 
PluginManagerConfig() - Constructor for class io.prestosql.server.PluginManagerConfig
 
poll() - Method in class io.prestosql.execution.resourcegroups.IndexedPriorityQueue
 
poll() - Method in class io.prestosql.operator.index.PageBuffer
Return a page from the buffer, or null if none exists
pollNextSplit() - Method in class io.prestosql.execution.executor.TaskHandle
 
pollPage() - Method in class io.prestosql.operator.ExchangeClient
 
PolymorphicScalarFunctionBuilder - Class in io.prestosql.metadata
 
PolymorphicScalarFunctionBuilder(Class<?>) - Constructor for class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
PolymorphicScalarFunctionBuilder.ChoiceBuilder - Class in io.prestosql.metadata
 
PolymorphicScalarFunctionBuilder.MethodsGroupBuilder - Class in io.prestosql.metadata
 
PolymorphicScalarFunctionBuilder.SpecializeContext - Class in io.prestosql.metadata
 
pop(BlockBuilder) - Method in class io.prestosql.operator.aggregation.TypedHeap
 
pop(BlockBuilder) - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
popAll(BlockBuilder) - Method in class io.prestosql.operator.aggregation.TypedHeap
 
popAll(BlockBuilder) - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
positionEqualsPosition(int, int, int, int) - Method in interface io.prestosql.operator.PagesHashStrategy
Compares the hashed columns in this PagesHashStrategy at the specified positions.
positionEqualsPosition(int, int, int, int) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
positionEqualsPosition(PagesHashStrategy, int, int) - Method in class io.prestosql.operator.PagesIndex
 
positionEqualsPositionIgnoreNulls(int, int, int, int) - Method in interface io.prestosql.operator.PagesHashStrategy
Compares the hashed columns in this PagesHashStrategy at the specified positions.
positionEqualsPositionIgnoreNulls(int, int, int, int) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
positionEqualsRow(int, int, int, Page) - Method in interface io.prestosql.operator.PagesHashStrategy
Compares the hashed columns in this PagesHashStrategy to the values in the specified page.
positionEqualsRow(int, int, int, Page) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
positionEqualsRow(PagesHashStrategy, int, int, Page) - Method in class io.prestosql.operator.PagesIndex
 
positionEqualsRowIgnoreNulls(int, int, int, Page) - Method in interface io.prestosql.operator.PagesHashStrategy
Compares the hashed columns in this PagesHashStrategy to the values in the specified page.
positionEqualsRowIgnoreNulls(int, int, int, Page) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
PositionLinks - Interface in io.prestosql.operator
This class is responsible for iterating over build rows, which have same values in hash columns as given probe row (but according to filterFunction can have non matching values on some other column).
PositionLinks.Factory - Interface in io.prestosql.operator
 
PositionLinks.FactoryBuilder - Interface in io.prestosql.operator
 
positionNotDistinctFromRow(int, int, int, Page, int[]) - Method in interface io.prestosql.operator.PagesHashStrategy
Compares the hashed columns in this PagesHashStrategy to the hashed columns in the Page.
positionNotDistinctFromRow(int, int, int, Page, int[]) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
positionOf(Block, int) - Method in class io.prestosql.operator.aggregation.TypedSet
 
positionsArrayToSelectedPositions(boolean[], int) - Static method in interface io.prestosql.operator.project.PageFilter
 
positionsList(int[], int, int) - Static method in class io.prestosql.operator.project.SelectedPositions
 
positionsRange(int, int) - Static method in class io.prestosql.operator.project.SelectedPositions
 
postFile(String) - Method in class io.prestosql.server.ui.WebUiStaticResource
 
postStatement(String, HttpServletRequest, HttpHeaders, UriInfo) - Method in class io.prestosql.dispatcher.QueuedStatementResource
 
power(double, double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
PowerOfTwo - Annotation Type in io.prestosql.util
 
PowerOfTwoValidator - Class in io.prestosql.util
 
PowerOfTwoValidator() - Constructor for class io.prestosql.util.PowerOfTwoValidator
 
PrecomputedHashGenerator - Class in io.prestosql.operator
 
PrecomputedHashGenerator(int) - Constructor for class io.prestosql.operator.PrecomputedHashGenerator
 
PREDICATE_PUSHDOWN_USE_TABLE_PROPERTIES - Static variable in class io.prestosql.SystemSessionProperties
 
PredicatePushDown - Class in io.prestosql.sql.planner.optimizations
 
PredicatePushDown(Metadata, TypeOperators, TypeAnalyzer, boolean, boolean) - Constructor for class io.prestosql.sql.planner.optimizations.PredicatePushDown
 
preemptQuery(QueryId, String, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.QueryResource
 
preemptQuery(QueryId, String, HttpServletRequest, HttpHeaders) - Method in class io.prestosql.server.ui.UiQueryResource
 
PREFER_PARTIAL_AGGREGATION - Static variable in class io.prestosql.SystemSessionProperties
 
PREFER_STREAMING_OPERATORS - Static variable in class io.prestosql.SystemSessionProperties
 
preferPartialAggregation(Session) - Static method in class io.prestosql.SystemSessionProperties
 
preferStreamingOperators(Session) - Static method in class io.prestosql.SystemSessionProperties
 
PrefixObjectNameGenerator(String, String) - Constructor for class io.prestosql.server.PrefixObjectNameGeneratorModule.PrefixObjectNameGenerator
 
PrefixObjectNameGeneratorModule - Class in io.prestosql.server
Replaces the prefix given by packagePrefix with the domain base provided via configuration.
PrefixObjectNameGeneratorModule(String) - Constructor for class io.prestosql.server.PrefixObjectNameGeneratorModule
 
PrefixObjectNameGeneratorModule.PrefixObjectNameGenerator - Class in io.prestosql.server
 
preGenerateLambdaExpression(LambdaDefinitionExpression, String, ClassDefinition, Map<LambdaDefinitionExpression, LambdaBytecodeGenerator.CompiledLambda>, CallSiteBinder, CachedInstanceBinder, Metadata) - Static method in class io.prestosql.sql.gen.LambdaBytecodeGenerator
 
preOrder(ConnectorExpression) - Static method in class io.prestosql.sql.planner.ConnectorExpressions
 
prepareAdd() - Method in class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
This method should be called before AbstractGroupCollectionAggregationState.appendAtChannel(int, Block, int) to update the internal linked list, where AbstractGroupCollectionAggregationState.appendAtChannel(int, Block, int) is called for each channel that has a new entry to be added.
PreparedQuery(Statement, List<Expression>, Optional<String>) - Constructor for class io.prestosql.execution.QueryPreparer.PreparedQuery
 
prepareFinal() - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
prepareQuery(Session, Statement) - Method in class io.prestosql.execution.QueryPreparer
 
prepareQuery(Session, String) - Method in class io.prestosql.execution.QueryPreparer
 
PrepareTask - Class in io.prestosql.execution
 
PrepareTask(SqlParser) - Constructor for class io.prestosql.execution.PrepareTask
 
prependElement(Type, boolean, Block) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
prependElement(Type, double, Block) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
prependElement(Type, long, Block) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
prependElement(Type, Slice, Block) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
prependElement(Type, Object, Block) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
PRESTO_PAGES - Static variable in class io.prestosql.PrestoMediaTypes
 
PRESTO_PAGES_TYPE - Static variable in class io.prestosql.PrestoMediaTypes
 
PrestoExceptionAssert - Class in io.prestosql.testing.assertions
 
PrestoMediaTypes - Class in io.prestosql
 
PRIME64 - Static variable in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
printDate(int) - Static method in class io.prestosql.util.DateTimeUtils
 
printDistributed(SubPlan) - Static method in class io.prestosql.util.GraphvizPrinter
 
printLogical(List<PlanFragment>) - Static method in class io.prestosql.util.GraphvizPrinter
 
printPlan() - Method in class io.prestosql.testing.LocalQueryRunner
 
printTimestampWithTimeZone(long) - Static method in class io.prestosql.util.DateTimeUtils
 
printTimeWithoutTimeZone(long) - Static method in class io.prestosql.util.DateTimeUtils
 
printTimeWithoutTimeZone(TimeZoneKey, long) - Static method in class io.prestosql.util.DateTimeUtils
Deprecated.
applicable in legacy timestamp semantics only
printTimeWithTimeZone(long) - Static method in class io.prestosql.util.DateTimeUtils
 
PrioritizedSplitRunner - Class in io.prestosql.execution.executor
 
priority - Variable in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
priority - Variable in class io.prestosql.execution.executor.TaskHandle
 
Priority - Class in io.prestosql.execution.executor
Task (and split) priority is composed of a level and a within-level priority.
Priority(int, long) - Constructor for class io.prestosql.execution.executor.Priority
 
privilege(String, TestingAccessControlManager.TestingPrivilegeType) - Static method in class io.prestosql.testing.TestingAccessControlManager
 
privilege(String, String, TestingAccessControlManager.TestingPrivilegeType) - Static method in class io.prestosql.testing.TestingAccessControlManager
 
PROBE_OUTER - io.prestosql.operator.LookupJoinOperators.JoinType
 
probeOperatorClosed(Lifespan) - Method in class io.prestosql.operator.JoinBridgeManager
 
probeOperatorCreated(Lifespan) - Method in class io.prestosql.operator.JoinBridgeManager
 
probeOperatorFactoryClosed(Lifespan) - Method in class io.prestosql.operator.JoinBridgeManager
 
probeOperatorFactoryClosedForAllLifespans() - Method in class io.prestosql.operator.JoinBridgeManager
Invoked when a probe operator factory indicates that it will not create any more operators, for any lifespan.
probeOuterJoin(int, PlanNodeId, JoinBridgeManager<? extends LookupSourceFactory>, List<Type>, List<Integer>, OptionalInt, Optional<List<Integer>>, OptionalInt, PartitioningSpillerFactory, BlockTypeOperators) - Method in class io.prestosql.operator.LookupJoinOperators
 
ProcedureColumnJdbcTable - Class in io.prestosql.connector.system.jdbc
 
ProcedureColumnJdbcTable() - Constructor for class io.prestosql.connector.system.jdbc.ProcedureColumnJdbcTable
 
ProcedureJdbcTable - Class in io.prestosql.connector.system.jdbc
 
ProcedureJdbcTable() - Constructor for class io.prestosql.connector.system.jdbc.ProcedureJdbcTable
 
ProcedureRegistry - Class in io.prestosql.metadata
 
ProcedureRegistry() - Constructor for class io.prestosql.metadata.ProcedureRegistry
 
ProcedureTester - Class in io.prestosql.testing
 
ProcedureTester() - Constructor for class io.prestosql.testing.ProcedureTester
 
process() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
process() - Method in class io.prestosql.operator.CompletedWork
 
process() - Method in class io.prestosql.operator.Driver
 
process() - Method in class io.prestosql.operator.TransformWork
 
process() - Method in interface io.prestosql.operator.Work
Call the method to do the work.
process() - Method in interface io.prestosql.operator.WorkProcessor
Call the method to progress the work.
process() - Method in interface io.prestosql.operator.WorkProcessor.Process
Does some work and returns current state.
process(ConnectorSession, DriverYieldSignal, LocalMemoryContext, Page) - Method in class io.prestosql.operator.project.PageProcessor
 
process(ConnectorSession, DriverYieldSignal, LocalMemoryContext, Page, boolean) - Method in class io.prestosql.operator.project.PageProcessor
 
process(ConnectorSession, DriverYieldSignal, RecordCursor, PageBuilder) - Method in interface io.prestosql.operator.project.CursorProcessor
 
process(Iterable<QueryExecution>, Supplier<List<BasicQueryInfo>>) - Method in class io.prestosql.memory.ClusterMemoryManager
 
process(K, long) - Method in interface io.prestosql.operator.aggregation.BucketConsumer
 
process(T) - Method in interface io.prestosql.operator.WorkProcessor.Transformation
Processes input elements and returns current transformation state.
processFor(Duration) - Method in interface io.prestosql.execution.SplitRunner
 
processFor(Duration) - Method in class io.prestosql.operator.Driver
 
processJsonArray(JsonParser) - Method in class io.prestosql.operator.scalar.JsonExtract.ObjectFieldJsonExtractor
 
processJsonObject(JsonParser) - Method in class io.prestosql.operator.scalar.JsonExtract.ObjectFieldJsonExtractor
 
processNextRow(PageBuilder) - Method in class io.prestosql.operator.window.WindowPartition
 
ProcessorContext - Class in io.prestosql.operator
 
ProcessorContext(Session, MemoryTrackingContext, OperatorContext) - Constructor for class io.prestosql.operator.ProcessorContext
 
processPage(Page) - Method in interface io.prestosql.operator.aggregation.builder.HashAggregationBuilder
 
processPage(Page) - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
processPage(Page) - Method in class io.prestosql.operator.aggregation.builder.SpillableHashAggregationBuilder
 
processPage(Page) - Method in class io.prestosql.operator.GroupedTopNBuilder
 
processRow(BlockBuilder, boolean, int, int) - Method in class io.prestosql.operator.window.CumulativeDistributionFunction
 
processRow(BlockBuilder, boolean, int, int) - Method in class io.prestosql.operator.window.DenseRankFunction
 
processRow(BlockBuilder, boolean, int, int) - Method in class io.prestosql.operator.window.NTileFunction
 
processRow(BlockBuilder, boolean, int, int) - Method in class io.prestosql.operator.window.PercentRankFunction
 
processRow(BlockBuilder, boolean, int, int) - Method in class io.prestosql.operator.window.RankFunction
 
processRow(BlockBuilder, boolean, int, int) - Method in class io.prestosql.operator.window.RowNumberFunction
 
processRow(BlockBuilder, int, int, int) - Method in class io.prestosql.operator.window.FirstValueFunction
 
processRow(BlockBuilder, int, int, int) - Method in class io.prestosql.operator.window.LagFunction
 
processRow(BlockBuilder, int, int, int) - Method in class io.prestosql.operator.window.LastValueFunction
 
processRow(BlockBuilder, int, int, int) - Method in class io.prestosql.operator.window.LeadFunction
 
processRow(BlockBuilder, int, int, int) - Method in class io.prestosql.operator.window.NthValueFunction
 
processRow(BlockBuilder, int, int, int, int) - Method in class io.prestosql.operator.window.AggregateWindowFunction
 
producesDistinctRows() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
project() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
project(ConnectorSession, DriverYieldSignal, Page, SelectedPositions) - Method in class io.prestosql.operator.project.ConstantPageProjection
 
project(ConnectorSession, DriverYieldSignal, Page, SelectedPositions) - Method in class io.prestosql.operator.project.DictionaryAwarePageProjection
 
project(ConnectorSession, DriverYieldSignal, Page, SelectedPositions) - Method in class io.prestosql.operator.project.GeneratedPageProjection
 
project(ConnectorSession, DriverYieldSignal, Page, SelectedPositions) - Method in class io.prestosql.operator.project.InputPageProjection
 
project(ConnectorSession, DriverYieldSignal, Page, SelectedPositions) - Method in interface io.prestosql.operator.project.PageProjection
 
projectExpressionRewrite() - Method in class io.prestosql.sql.planner.iterative.rule.ExpressionRewriteRuleSet
 
ProjectNode - Class in io.prestosql.sql.planner.plan
 
ProjectNode(PlanNodeId, PlanNode, Assignments) - Constructor for class io.prestosql.sql.planner.plan.ProjectNode
 
ProjectOffPushDownRule<N extends PlanNode> - Class in io.prestosql.sql.planner.iterative.rule
 
ProjectOffPushDownRule(Pattern<N>) - Constructor for class io.prestosql.sql.planner.iterative.rule.ProjectOffPushDownRule
 
ProjectStatsRule - Class in io.prestosql.cost
 
ProjectStatsRule(ScalarStatsCalculator, StatsNormalizer) - Constructor for class io.prestosql.cost.ProjectStatsRule
 
property(String, Object) - Method in class io.prestosql.metadata.MetadataUtil.TableMetadataBuilder
 
PropertyDerivations - Class in io.prestosql.sql.planner.optimizations
 
PruneAggregationColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneAggregationColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneAggregationColumns
 
PruneAggregationSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneAggregationSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneAggregationSourceColumns
 
PruneApplyColumns - Class in io.prestosql.sql.planner.iterative.rule
This rule restricts the outputs of ApplyNode's input and subquery based on which ApplyNode's output symbols are referenced.
PruneApplyColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneApplyColumns
 
PruneApplyCorrelation - Class in io.prestosql.sql.planner.iterative.rule
This rule updates ApplyNode's correlation list.
PruneApplyCorrelation() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneApplyCorrelation
 
PruneApplySourceColumns - Class in io.prestosql.sql.planner.iterative.rule
This rule restricts outputs of ApplyNode's subquery to include only the symbols needed for subqueryAssignments.
PruneApplySourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneApplySourceColumns
 
PruneAssignUniqueIdColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneAssignUniqueIdColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneAssignUniqueIdColumns
 
pruneColumns(Metadata, TypeProvider, Session, TableScanNode, Set<Symbol>) - Static method in class io.prestosql.sql.planner.iterative.rule.PruneTableScanColumns
 
PruneCorrelatedJoinColumns - Class in io.prestosql.sql.planner.iterative.rule
This rule restricts the outputs of CorrelatedJoinNode's input and subquery based on which CorrelatedJoinNode's output symbols are referenced.
PruneCorrelatedJoinColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneCorrelatedJoinColumns
 
PruneCorrelatedJoinCorrelation - Class in io.prestosql.sql.planner.iterative.rule
This rule updates CorrelatedJoinNode's correlation list.
PruneCorrelatedJoinCorrelation() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneCorrelatedJoinCorrelation
 
PruneCountAggregationOverScalar - Class in io.prestosql.sql.planner.iterative.rule
A count over a subquery can be reduced to a VALUES(1) provided the subquery is a scalar
PruneCountAggregationOverScalar(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneCountAggregationOverScalar
 
PruneDeleteSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneDeleteSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneDeleteSourceColumns
 
PruneDistinctAggregation - Class in io.prestosql.sql.planner.iterative.rule
 
PruneDistinctAggregation() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneDistinctAggregation
 
PruneDistinctLimitSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneDistinctLimitSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneDistinctLimitSourceColumns
 
PruneEnforceSingleRowColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneEnforceSingleRowColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneEnforceSingleRowColumns
 
PruneExceptSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneExceptSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneExceptSourceColumns
 
PruneExchangeColumns - Class in io.prestosql.sql.planner.iterative.rule
This rule restricts the outputs of ExchangeNode based on which ExchangeNode's output symbols are either referenced by the parent node or used for partitioning, ordering or as a hash symbol by the ExchangeNode.
PruneExchangeColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneExchangeColumns
 
PruneExchangeSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneExchangeSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneExchangeSourceColumns
 
PruneExplainAnalyzeSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneExplainAnalyzeSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneExplainAnalyzeSourceColumns
 
PruneFilterColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneFilterColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneFilterColumns
 
PruneGroupIdColumns - Class in io.prestosql.sql.planner.iterative.rule
This rule prunes GroupIdNode's aggregationArguments.
PruneGroupIdColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneGroupIdColumns
 
PruneGroupIdSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneGroupIdSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneGroupIdSourceColumns
 
PruneIndexJoinColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneIndexJoinColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneIndexJoinColumns
 
PruneIndexSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneIndexSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneIndexSourceColumns
 
pruneInfo() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
pruneInfo() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
pruneInfo() - Method in class io.prestosql.execution.DataDefinitionExecution
 
pruneInfo() - Method in interface io.prestosql.execution.QueryTracker.TrackedQuery
 
pruneInfo() - Method in class io.prestosql.execution.SqlQueryExecution
 
PruneIntersectSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneIntersectSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneIntersectSourceColumns
 
PruneJoinChildrenColumns - Class in io.prestosql.sql.planner.iterative.rule
Joins support output symbol selection, so make any project-off of child columns explicit in project nodes.
PruneJoinChildrenColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneJoinChildrenColumns
 
PruneJoinColumns - Class in io.prestosql.sql.planner.iterative.rule
Joins support output symbol selection, so absorb any project-off into the node.
PruneJoinColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneJoinColumns
 
PruneLimitColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneLimitColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneLimitColumns
 
PruneMarkDistinctColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneMarkDistinctColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneMarkDistinctColumns
 
PruneOffsetColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneOffsetColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneOffsetColumns
 
PruneOrderByInAggregation - Class in io.prestosql.sql.planner.iterative.rule
 
PruneOrderByInAggregation(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneOrderByInAggregation
 
PruneOutputSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneOutputSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneOutputSourceColumns
 
PruneProjectColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneProjectColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneProjectColumns
 
pruneQueryInfo() - Method in class io.prestosql.execution.QueryStateMachine
 
PruneRowNumberColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneRowNumberColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneRowNumberColumns
 
PruneSampleColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneSampleColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneSampleColumns
 
PruneSemiJoinColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneSemiJoinColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneSemiJoinColumns
 
PruneSemiJoinFilteringSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneSemiJoinFilteringSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneSemiJoinFilteringSourceColumns
 
PruneSortColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneSortColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneSortColumns
 
PruneSpatialJoinChildrenColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneSpatialJoinChildrenColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneSpatialJoinChildrenColumns
 
PruneSpatialJoinColumns - Class in io.prestosql.sql.planner.iterative.rule
Spatial joins support output symbol selection, so absorb any project-off into the node.
PruneSpatialJoinColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneSpatialJoinColumns
 
PruneTableScanColumns - Class in io.prestosql.sql.planner.iterative.rule
TODO: this is a special case of PushProjectionIntoTableScan and should be merged with that rule.
PruneTableScanColumns(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneTableScanColumns
 
PruneTableWriterSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneTableWriterSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneTableWriterSourceColumns
 
PruneTopNColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneTopNColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneTopNColumns
 
PruneTopNRowNumberColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneTopNRowNumberColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneTopNRowNumberColumns
 
PruneUnionColumns - Class in io.prestosql.sql.planner.iterative.rule
Transforms
PruneUnionColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneUnionColumns
 
PruneUnionSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneUnionSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneUnionSourceColumns
 
PruneUnnestColumns - Class in io.prestosql.sql.planner.iterative.rule
Absorb pruning projection into the node.
PruneUnnestColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneUnnestColumns
 
PruneUnnestSourceColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneUnnestSourceColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneUnnestSourceColumns
 
PruneUnreferencedOutputs - Class in io.prestosql.sql.planner.optimizations
Removes all computation that does is not referenced transitively from the root of the plan
PruneUnreferencedOutputs(Metadata) - Constructor for class io.prestosql.sql.planner.optimizations.PruneUnreferencedOutputs
 
PruneValuesColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneValuesColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneValuesColumns
 
PruneWindowColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneWindowColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneWindowColumns
 
PseudoColumnJdbcTable - Class in io.prestosql.connector.system.jdbc
 
PseudoColumnJdbcTable() - Constructor for class io.prestosql.connector.system.jdbc.PseudoColumnJdbcTable
 
PUBLIC - io.prestosql.server.security.ResourceSecurity.AccessType
 
publicResource(AnnotatedElement) - Method in class io.prestosql.server.security.ResourceSecurityBinder
 
PUSH_AGGREGATION_THROUGH_OUTER_JOIN - Static variable in class io.prestosql.SystemSessionProperties
 
PUSH_PARTIAL_AGGREGATION_THROUGH_JOIN - Static variable in class io.prestosql.SystemSessionProperties
 
PUSH_TABLE_WRITE_THROUGH_UNION - Static variable in class io.prestosql.SystemSessionProperties
 
pushAggregationIntoTableScan(Metadata, Rule.Context, TableScanNode, Map<Symbol, AggregationNode.Aggregation>, List<Symbol>) - Static method in class io.prestosql.sql.planner.iterative.rule.PushAggregationIntoTableScan
 
PushAggregationIntoTableScan - Class in io.prestosql.sql.planner.iterative.rule
 
PushAggregationIntoTableScan(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushAggregationIntoTableScan
 
PushAggregationThroughOuterJoin - Class in io.prestosql.sql.planner.iterative.rule
This optimizer pushes aggregations below outer joins when: the aggregation is on top of the outer join, it groups by all columns in the outer table, and the outer rows are guaranteed to be distinct.
PushAggregationThroughOuterJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushAggregationThroughOuterJoin
 
PushDeleteIntoConnector - Class in io.prestosql.sql.planner.iterative.rule
 
PushDeleteIntoConnector(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDeleteIntoConnector
 
PushDistinctLimitIntoTableScan - Class in io.prestosql.sql.planner.iterative.rule
 
PushDistinctLimitIntoTableScan(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDistinctLimitIntoTableScan
 
PushDownDereferencesThroughAssignUniqueId - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferencesThroughAssignUniqueId(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughAssignUniqueId
 
PushDownDereferencesThroughLimit - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferencesThroughLimit(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughLimit
 
PushDownDereferencesThroughMarkDistinct - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferencesThroughMarkDistinct(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughMarkDistinct
 
PushDownDereferencesThroughRowNumber - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferencesThroughRowNumber(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughRowNumber
 
PushDownDereferencesThroughSort - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferencesThroughSort(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughSort
 
PushDownDereferencesThroughTopN - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferencesThroughTopN(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughTopN
 
PushDownDereferencesThroughTopNRowNumber - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferencesThroughTopNRowNumber(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughTopNRowNumber
 
PushDownDereferencesThroughWindow - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferencesThroughWindow(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferencesThroughWindow
 
PushDownDereferenceThroughFilter - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferenceThroughFilter(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughFilter
 
PushDownDereferenceThroughJoin - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferenceThroughJoin(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughJoin
 
PushDownDereferenceThroughProject - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferenceThroughProject(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughProject
 
PushDownDereferenceThroughSemiJoin - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferenceThroughSemiJoin(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughSemiJoin
 
PushDownDereferenceThroughUnnest - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushDownDereferenceThroughUnnest(TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushDownDereferenceThroughUnnest
 
pushDownNegations(Metadata, Expression, Map<NodeRef<Expression>, Type>) - Static method in class io.prestosql.sql.planner.iterative.rule.PushDownNegationsExpressionRewriter
 
PushDownNegationsExpressionRewriter - Class in io.prestosql.sql.planner.iterative.rule
 
pushDownProjectOff(Rule.Context, AggregationNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneAggregationColumns
 
pushDownProjectOff(Rule.Context, ApplyNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneApplyColumns
 
pushDownProjectOff(Rule.Context, AssignUniqueId, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneAssignUniqueIdColumns
 
pushDownProjectOff(Rule.Context, CorrelatedJoinNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneCorrelatedJoinColumns
 
pushDownProjectOff(Rule.Context, EnforceSingleRowNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneEnforceSingleRowColumns
 
pushDownProjectOff(Rule.Context, ExchangeNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneExchangeColumns
 
pushDownProjectOff(Rule.Context, FilterNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneFilterColumns
 
pushDownProjectOff(Rule.Context, GroupIdNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneGroupIdColumns
 
pushDownProjectOff(Rule.Context, IndexJoinNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneIndexJoinColumns
 
pushDownProjectOff(Rule.Context, IndexSourceNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneIndexSourceColumns
 
pushDownProjectOff(Rule.Context, JoinNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneJoinColumns
 
pushDownProjectOff(Rule.Context, LimitNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneLimitColumns
 
pushDownProjectOff(Rule.Context, MarkDistinctNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneMarkDistinctColumns
 
pushDownProjectOff(Rule.Context, OffsetNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneOffsetColumns
 
pushDownProjectOff(Rule.Context, ProjectNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneProjectColumns
 
pushDownProjectOff(Rule.Context, RowNumberNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneRowNumberColumns
 
pushDownProjectOff(Rule.Context, SampleNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneSampleColumns
 
pushDownProjectOff(Rule.Context, SemiJoinNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneSemiJoinColumns
 
pushDownProjectOff(Rule.Context, SortNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneSortColumns
 
pushDownProjectOff(Rule.Context, SpatialJoinNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneSpatialJoinColumns
 
pushDownProjectOff(Rule.Context, TableScanNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneTableScanColumns
 
pushDownProjectOff(Rule.Context, TopNNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneTopNColumns
 
pushDownProjectOff(Rule.Context, TopNRowNumberNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneTopNRowNumberColumns
 
pushDownProjectOff(Rule.Context, UnionNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneUnionColumns
 
pushDownProjectOff(Rule.Context, UnnestNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneUnnestColumns
 
pushDownProjectOff(Rule.Context, ValuesNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneValuesColumns
 
pushDownProjectOff(Rule.Context, WindowNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneWindowColumns
 
pushDownProjectOff(Rule.Context, N, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.ProjectOffPushDownRule
 
pushFilterIntoTableScan(TableScanNode, Expression, boolean, Session, TypeProvider, PlanNodeIdAllocator, Metadata, TypeOperators, TypeAnalyzer, DomainTranslator) - Static method in class io.prestosql.sql.planner.iterative.rule.PushPredicateIntoTableScan
 
PushLimitIntoTableScan - Class in io.prestosql.sql.planner.iterative.rule
 
PushLimitIntoTableScan(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushLimitIntoTableScan
 
PushLimitThroughMarkDistinct - Class in io.prestosql.sql.planner.iterative.rule
 
PushLimitThroughMarkDistinct() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushLimitThroughMarkDistinct
 
PushLimitThroughOffset - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushLimitThroughOffset() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushLimitThroughOffset
 
PushLimitThroughOuterJoin - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushLimitThroughOuterJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushLimitThroughOuterJoin
 
PushLimitThroughProject - Class in io.prestosql.sql.planner.iterative.rule
 
PushLimitThroughProject() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushLimitThroughProject
 
PushLimitThroughSemiJoin - Class in io.prestosql.sql.planner.iterative.rule
 
PushLimitThroughSemiJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushLimitThroughSemiJoin
 
PushLimitThroughUnion - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushLimitThroughUnion() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushLimitThroughUnion
 
PushOffsetThroughProject - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushOffsetThroughProject() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushOffsetThroughProject
 
PushPartialAggregationThroughExchange - Class in io.prestosql.sql.planner.iterative.rule
 
PushPartialAggregationThroughExchange(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushPartialAggregationThroughExchange
 
PushPartialAggregationThroughJoin - Class in io.prestosql.sql.planner.iterative.rule
 
PushPartialAggregationThroughJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushPartialAggregationThroughJoin
 
PushPredicateIntoTableScan - Class in io.prestosql.sql.planner.iterative.rule
These rules should not be run after AddExchanges so as not to overwrite the TableLayout chosen by AddExchanges
PushPredicateIntoTableScan(Metadata, TypeOperators, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushPredicateIntoTableScan
 
PushPredicateThroughProjectIntoRowNumber - Class in io.prestosql.sql.planner.iterative.rule
This rule pushes filter predicate concerning row number symbol into RowNumberNode by modifying maxRowCountPerPartition.
PushPredicateThroughProjectIntoRowNumber(Metadata, TypeOperators) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushPredicateThroughProjectIntoRowNumber
 
PushPredicateThroughProjectIntoWindow - Class in io.prestosql.sql.planner.iterative.rule
This rule pushes filter predicate concerning row number symbol into WindowNode by converting it into TopNRowNumberNode.
PushPredicateThroughProjectIntoWindow(Metadata, TypeOperators) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushPredicateThroughProjectIntoWindow
 
PushProjectionIntoTableScan - Class in io.prestosql.sql.planner.iterative.rule
 
PushProjectionIntoTableScan(Metadata, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushProjectionIntoTableScan
 
PushProjectionThroughExchange - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushProjectionThroughExchange() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushProjectionThroughExchange
 
pushProjectionThroughJoin(Metadata, ProjectNode, Lookup, PlanNodeIdAllocator) - Static method in class io.prestosql.sql.planner.iterative.rule.PushProjectionThroughJoin
 
PushProjectionThroughJoin - Class in io.prestosql.sql.planner.iterative.rule
Utility class for pushing projections through inner join so that joins are not separated by a project node and can participate in cross join elimination or join reordering.
PushProjectionThroughUnion - Class in io.prestosql.sql.planner.iterative.rule
 
PushProjectionThroughUnion() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushProjectionThroughUnion
 
PushRemoteExchangeThroughAssignUniqueId - Class in io.prestosql.sql.planner.iterative.rule
Pushes RemoteExchange node down through the AssignUniqueId to preserve partitioned_on(unique) and grouped(unique) properties for the output of the AssignUniqueId.
PushRemoteExchangeThroughAssignUniqueId() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushRemoteExchangeThroughAssignUniqueId
 
PushSampleIntoTableScan - Class in io.prestosql.sql.planner.iterative.rule
 
PushSampleIntoTableScan(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushSampleIntoTableScan
 
PushTableWriteThroughUnion - Class in io.prestosql.sql.planner.iterative.rule
 
PushTableWriteThroughUnion() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushTableWriteThroughUnion
 
PushTopNIntoTableScan - Class in io.prestosql.sql.planner.iterative.rule
 
PushTopNIntoTableScan(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushTopNIntoTableScan
 
PushTopNThroughOuterJoin - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushTopNThroughOuterJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushTopNThroughOuterJoin
 
PushTopNThroughProject - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushTopNThroughProject() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushTopNThroughProject
 
PushTopNThroughUnion - Class in io.prestosql.sql.planner.iterative.rule
 
PushTopNThroughUnion() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushTopNThroughUnion
 
put(long, long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
put(long, long, long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
put(Symbol, Symbol) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper.Builder
 
put(Symbol, Expression) - Method in class io.prestosql.sql.planner.plan.Assignments.Builder
 
put(Map.Entry<Symbol, Expression>) - Method in class io.prestosql.sql.planner.plan.Assignments.Builder
 
putAll(Assignments) - Method in class io.prestosql.sql.planner.plan.Assignments.Builder
 
putAll(Map<? extends Long, ? extends Long>) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
putAll(Map<Symbol, ? extends Expression>) - Method in class io.prestosql.sql.planner.plan.Assignments.Builder
 
putIdentities(Iterable<Symbol>) - Method in class io.prestosql.sql.planner.plan.Assignments.Builder
 
putIdentity(Symbol) - Method in class io.prestosql.sql.planner.plan.Assignments.Builder
 
putIfAbsent(long, long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
putIfAbsent(long, long, long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 

Q

QDIGEST_AGG - Static variable in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
QDIGEST_AGG_WITH_WEIGHT - Static variable in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
QDIGEST_AGG_WITH_WEIGHT_AND_ERROR - Static variable in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
QualifiedObjectName - Class in io.prestosql.metadata
 
QualifiedObjectName(String, String, String) - Constructor for class io.prestosql.metadata.QualifiedObjectName
 
QualifiedTablePrefix - Class in io.prestosql.metadata
 
QualifiedTablePrefix(String) - Constructor for class io.prestosql.metadata.QualifiedTablePrefix
 
QualifiedTablePrefix(String, String) - Constructor for class io.prestosql.metadata.QualifiedTablePrefix
 
QualifiedTablePrefix(String, String, String) - Constructor for class io.prestosql.metadata.QualifiedTablePrefix
 
QualifiedTablePrefix(String, Optional<String>, Optional<String>) - Constructor for class io.prestosql.metadata.QualifiedTablePrefix
 
QuantileDigestAggregationFunction - Class in io.prestosql.operator.aggregation
 
QuantileDigestAndPercentileState - Interface in io.prestosql.operator.aggregation.state
 
QuantileDigestAndPercentileStateFactory - Class in io.prestosql.operator.aggregation.state
 
QuantileDigestAndPercentileStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory
 
QuantileDigestAndPercentileStateFactory.GroupedQuantileDigestAndPercentileState - Class in io.prestosql.operator.aggregation.state
 
QuantileDigestAndPercentileStateFactory.SingleQuantileDigestAndPercentileState - Class in io.prestosql.operator.aggregation.state
 
QuantileDigestAndPercentileStateSerializer - Class in io.prestosql.operator.aggregation.state
 
QuantileDigestAndPercentileStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateSerializer
 
QuantileDigestFunctions - Class in io.prestosql.operator.scalar
 
QuantileDigestOperators - Class in io.prestosql.type
 
QuantileDigestState - Interface in io.prestosql.operator.aggregation.state
 
QuantileDigestStateFactory - Class in io.prestosql.operator.aggregation.state
 
QuantileDigestStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory
 
QuantileDigestStateFactory.GroupedQuantileDigestState - Class in io.prestosql.operator.aggregation.state
 
QuantileDigestStateFactory.SingleQuantileDigestState - Class in io.prestosql.operator.aggregation.state
 
QuantileDigestStateSerializer - Class in io.prestosql.operator.aggregation.state
 
QuantileDigestStateSerializer(Type) - Constructor for class io.prestosql.operator.aggregation.state.QuantileDigestStateSerializer
 
QUARTER_OF_YEAR - Static variable in class io.prestosql.operator.scalar.QuarterOfYearDateTimeField
 
quarterFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
QuarterOfYearDateTimeField - Class in io.prestosql.operator.scalar
 
QUERY_MAX_CPU_TIME - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_MAX_EXECUTION_TIME - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_MAX_MEMORY - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_MAX_MEMORY_PER_NODE - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_MAX_MEMORY_PER_NODE_CONFIG - Static variable in class io.prestosql.memory.NodeMemoryConfig
 
QUERY_MAX_RUN_TIME - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_MAX_SCAN_PHYSICAL_BYTES - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_MAX_STAGE_COUNT - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_MAX_TOTAL_MEMORY - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_MAX_TOTAL_MEMORY_PER_NODE - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_MAX_TOTAL_MEMORY_PER_NODE_CONFIG - Static variable in class io.prestosql.memory.NodeMemoryConfig
 
QUERY_PRIORITY - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_TABLE - Static variable in class io.prestosql.connector.system.QuerySystemTable
 
QUERY_TABLE_NAME - Static variable in class io.prestosql.connector.system.QuerySystemTable
 
QueryCardinalityUtil - Class in io.prestosql.sql.planner.optimizations
 
queryCompleted(QueryCompletedEvent) - Method in class io.prestosql.eventlistener.EventListenerManager
 
queryCompleted(QueryCompletedEvent) - Method in class io.prestosql.testing.TestingEventListenerManager
 
queryCompletedEvent(QueryInfo) - Method in class io.prestosql.event.QueryMonitor
 
QueryContext - Class in io.prestosql.memory
 
QueryContext(QueryId, DataSize, DataSize, MemoryPool, GcMonitor, Executor, ScheduledExecutorService, DataSize, SpillSpaceTracker) - Constructor for class io.prestosql.memory.QueryContext
 
QueryContextVisitor<C,​R> - Interface in io.prestosql.memory
 
queryCreated(QueryCreatedEvent) - Method in class io.prestosql.eventlistener.EventListenerManager
 
queryCreated(QueryCreatedEvent) - Method in class io.prestosql.testing.TestingEventListenerManager
 
queryCreatedEvent(BasicQueryInfo) - Method in class io.prestosql.event.QueryMonitor
 
QueryExecution - Interface in io.prestosql.execution
 
QueryExecution.QueryExecutionFactory<T extends QueryExecution> - Interface in io.prestosql.execution
 
QueryExecution.QueryOutputInfo - Class in io.prestosql.execution
Output schema and buffer URIs for query.
QueryExecutionFactoryModule - Class in io.prestosql.server
 
QueryExecutionFactoryModule() - Constructor for class io.prestosql.server.QueryExecutionFactoryModule
 
QueryExecutionMBean - Class in io.prestosql.execution
 
QueryExecutionMBean(ExecutorService) - Constructor for class io.prestosql.execution.QueryExecutionMBean
 
QueryExplainer - Class in io.prestosql.sql.analyzer
 
QueryExplainer(PlanOptimizers, PlanFragmenter, Metadata, TypeOperators, GroupProvider, AccessControl, SqlParser, StatsCalculator, CostCalculator, Map<Class<? extends Statement>, DataDefinitionTask<?>>) - Constructor for class io.prestosql.sql.analyzer.QueryExplainer
 
QueryExplainer(List<PlanOptimizer>, PlanFragmenter, Metadata, TypeOperators, GroupProvider, AccessControl, SqlParser, StatsCalculator, CostCalculator, Map<Class<? extends Statement>, DataDefinitionTask<?>>) - Constructor for class io.prestosql.sql.analyzer.QueryExplainer
 
QueryIdGenerator - Class in io.prestosql.execution
 
QueryIdGenerator() - Constructor for class io.prestosql.execution.QueryIdGenerator
 
queryImmediateFailureEvent(BasicQueryInfo, ExecutionFailureInfo) - Method in class io.prestosql.event.QueryMonitor
 
QueryInfo - Class in io.prestosql.execution
 
QueryInfo(QueryId, SessionRepresentation, QueryState, MemoryPoolId, boolean, URI, List<String>, String, Optional<String>, QueryStats, Optional<String>, Optional<String>, Optional<String>, Map<String, String>, Set<String>, Map<String, SelectedRole>, Map<String, String>, Set<String>, Optional<TransactionId>, boolean, String, Optional<StageInfo>, ExecutionFailureInfo, ErrorCode, List<PrestoWarning>, Set<Input>, Optional<Output>, List<TableInfo>, List<RoutineInfo>, boolean, Optional<ResourceGroupId>, Optional<QueryType>) - Constructor for class io.prestosql.execution.QueryInfo
 
QueryManager - Interface in io.prestosql.execution
 
QueryManagerConfig - Class in io.prestosql.execution
 
QueryManagerConfig() - Constructor for class io.prestosql.execution.QueryManagerConfig
 
QueryManagerStats - Class in io.prestosql.execution
 
QueryManagerStats() - Constructor for class io.prestosql.execution.QueryManagerStats
 
QueryMemoryInfo(QueryId, MemoryPoolId, long) - Constructor for class io.prestosql.memory.LowMemoryKiller.QueryMemoryInfo
 
QueryMonitor - Class in io.prestosql.event
 
QueryMonitor(JsonCodec<StageInfo>, JsonCodec<OperatorStats>, JsonCodec<ExecutionFailureInfo>, JsonCodec<StatsAndCosts>, EventListenerManager, NodeInfo, NodeVersion, SessionPropertyManager, Metadata, QueryMonitorConfig) - Constructor for class io.prestosql.event.QueryMonitor
 
QueryMonitorConfig - Class in io.prestosql.event
 
QueryMonitorConfig() - Constructor for class io.prestosql.event.QueryMonitorConfig
 
QueryOutputInfo(List<String>, List<Type>, Set<URI>, boolean) - Constructor for class io.prestosql.execution.QueryExecution.QueryOutputInfo
 
QueryOutputManager(Executor) - Constructor for class io.prestosql.execution.QueryStateMachine.QueryOutputManager
 
QueryPerformanceFetcher - Interface in io.prestosql.execution
 
QueryPreparer - Class in io.prestosql.execution
 
QueryPreparer(SqlParser) - Constructor for class io.prestosql.execution.QueryPreparer
 
QueryPreparer.PreparedQuery - Class in io.prestosql.execution
 
QueryProgressStats - Class in io.prestosql.server
 
QueryProgressStats(long, long, long, long, long, long, long, long, boolean, OptionalDouble) - Constructor for class io.prestosql.server.QueryProgressStats
 
QueryQueueFullException - Exception in io.prestosql.execution.resourcegroups
 
QueryQueueFullException(ResourceGroupId) - Constructor for exception io.prestosql.execution.resourcegroups.QueryQueueFullException
 
QueryResource - Class in io.prestosql.server
Manage queries scheduled on this node
QueryResource(DispatchManager, AccessControl, GroupProvider) - Constructor for class io.prestosql.server.QueryResource
 
QueryResultRows - Class in io.prestosql.server.protocol
 
QueryResultRows.Builder - Class in io.prestosql.server.protocol
 
queryResultRowsBuilder(Session) - Static method in class io.prestosql.server.protocol.QueryResultRows
 
QueryRunner - Interface in io.prestosql.testing
 
QueryRunner.MaterializedResultWithPlan - Class in io.prestosql.testing
 
QuerySessionSupplier - Class in io.prestosql.server
 
QuerySessionSupplier(TransactionManager, AccessControl, SessionPropertyManager, SqlEnvironmentConfig) - Constructor for class io.prestosql.server.QuerySessionSupplier
 
QueryState - Enum in io.prestosql.execution
 
QueryStateInfo - Class in io.prestosql.server
 
QueryStateInfo(QueryId, QueryState, Optional<ResourceGroupId>, String, DateTime, String, Optional<String>, Optional<String>, Optional<String>, Optional<String>, Optional<List<ResourceGroupInfo>>, Optional<QueryProgressStats>) - Constructor for class io.prestosql.server.QueryStateInfo
 
QueryStateInfoResource - Class in io.prestosql.server
 
QueryStateInfoResource(DispatchManager, ResourceGroupManager<?>, AccessControl, GroupProvider) - Constructor for class io.prestosql.server.QueryStateInfoResource
 
QueryStateMachine - Class in io.prestosql.execution
 
QueryStateMachine.QueryOutputManager - Class in io.prestosql.execution
 
QueryStats - Class in io.prestosql.execution
 
QueryStats(DateTime, DateTime, DateTime, DateTime, Duration, Duration, Duration, Duration, Duration, Duration, Duration, Duration, int, int, int, int, int, int, int, int, double, DataSize, DataSize, DataSize, DataSize, DataSize, DataSize, DataSize, DataSize, DataSize, DataSize, boolean, Duration, Duration, Duration, boolean, Set<BlockedReason>, DataSize, long, Duration, DataSize, long, DataSize, long, DataSize, long, DataSize, long, DataSize, List<StageGcStatistics>, DynamicFilterService.DynamicFiltersStats, List<OperatorStats>) - Constructor for class io.prestosql.execution.QueryStats
 
QuerySystemTable - Class in io.prestosql.connector.system
 
QuerySystemTable(Optional<DispatchManager>, AccessControl) - Constructor for class io.prestosql.connector.system.QuerySystemTable
 
QueryTracker<T extends QueryTracker.TrackedQuery> - Class in io.prestosql.execution
 
QueryTracker(QueryManagerConfig, ScheduledExecutorService) - Constructor for class io.prestosql.execution.QueryTracker
 
QueryTracker.TrackedQuery - Interface in io.prestosql.execution
 
queued(Duration, Duration) - Static method in class io.prestosql.dispatcher.DispatchInfo
 
QUEUED - io.prestosql.execution.QueryState
Query has been accepted and is awaiting execution.
QUEUED_QUERY - io.prestosql.server.protocol.Slug.Context
 
queuedLeafSplits - Variable in class io.prestosql.execution.executor.TaskHandle
 
QueuedStatementResource - Class in io.prestosql.dispatcher
 
QueuedStatementResource(GroupProvider, DispatchManager, DispatchExecutor, ServerConfig) - Constructor for class io.prestosql.dispatcher.QueuedStatementResource
 

R

radians(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
random() - Static method in class io.prestosql.operator.scalar.MathFunctions
 
random(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
random(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
randomInteger(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
randomInteger(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
randomizedNodes(NodeMap, boolean, Set<InternalNode>) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
randomSmallint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
randomSmallint(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
randomTinyint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
randomTinyint(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
RangeJsonSerde - Class in io.prestosql.server
 
RangeJsonSerde.Deserializer - Class in io.prestosql.server
 
RangeJsonSerde.Serializer - Class in io.prestosql.server
 
rangeMax(double, double) - Static method in class io.prestosql.util.MoreMath
 
rangeMin(double, double) - Static method in class io.prestosql.util.MoreMath
 
RankFunction - Class in io.prestosql.operator.window
 
RankFunction() - Constructor for class io.prestosql.operator.window.RankFunction
 
RE2J - io.prestosql.sql.analyzer.RegexLibrary
 
RE2J_REGEXP_SIGNATURE - Static variable in class io.prestosql.type.Re2JRegexpType
 
Re2JCastToRegexpFunction - Class in io.prestosql.operator.scalar
 
Re2JRegexp - Class in io.prestosql.type
 
Re2JRegexp(int, int, Slice) - Constructor for class io.prestosql.type.Re2JRegexp
 
Re2JRegexpFunctions - Class in io.prestosql.operator.scalar
 
Re2JRegexpReplaceLambdaFunction - Class in io.prestosql.operator.scalar
 
Re2JRegexpReplaceLambdaFunction() - Constructor for class io.prestosql.operator.scalar.Re2JRegexpReplaceLambdaFunction
 
Re2JRegexpType - Class in io.prestosql.type
 
Re2JRegexpType(int, int) - Constructor for class io.prestosql.type.Re2JRegexpType
 
read(Block, int, long) - Method in interface io.prestosql.operator.aggregation.histogram.HistogramValueReader
 
read(ContainerRequestContext) - Static method in class io.prestosql.server.ui.OAuthWebUiCookie
 
READ_BLOCK - Static variable in class io.prestosql.block.BlockSerdeUtil
 
READ_BLOCK_VALUE - Static variable in class io.prestosql.block.BlockSerdeUtil
 
readAllValues(HistogramValueReader) - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
readAllValues(HistogramValueReader) - Method in class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
readAllValues(HistogramValueReader) - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
readBlock(BlockEncodingSerde, Slice) - Static method in class io.prestosql.block.BlockSerdeUtil
 
readBlock(BlockEncodingSerde, SliceInput) - Static method in class io.prestosql.block.BlockSerdeUtil
 
readBlockValue(BlockEncodingSerde, Type, Slice) - Static method in class io.prestosql.block.BlockSerdeUtil
 
readCommitted() - Method in class io.prestosql.transaction.TransactionBuilder
 
readOnly() - Method in class io.prestosql.transaction.TransactionBuilder
 
readPages(PagesSerde, SliceInput) - Static method in class io.prestosql.execution.buffer.PagesSerdeUtil
 
readSerializedPages(SliceInput) - Static method in class io.prestosql.execution.buffer.PagesSerdeUtil
 
readUncommitted() - Method in class io.prestosql.transaction.TransactionBuilder
 
REAL_AVERAGE_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.RealAverageAggregation
 
REAL_TO_DECIMAL_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
RealAverageAggregation - Class in io.prestosql.operator.aggregation
 
RealAverageAggregation() - Constructor for class io.prestosql.operator.aggregation.RealAverageAggregation
 
RealCorrelationAggregation - Class in io.prestosql.operator.aggregation
 
RealCovarianceAggregation - Class in io.prestosql.operator.aggregation
 
RealGeometricMeanAggregations - Class in io.prestosql.operator.aggregation
 
RealHistogramAggregation - Class in io.prestosql.operator.aggregation
 
reallocateSymbols(PlanNode, List<Symbol>, SymbolAllocator) - Method in class io.prestosql.sql.planner.optimizations.UnaliasSymbolReferences
Replace all symbols in the plan with new symbols.
RealOperators - Class in io.prestosql.type
 
RealRegressionAggregation - Class in io.prestosql.operator.aggregation
 
RealSumAggregation - Class in io.prestosql.operator.aggregation
 
realToLongDecimal(long, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
realToShortDecimal(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
realTypeArrayMax(Block) - Static method in class io.prestosql.operator.scalar.ArrayMaxFunction
 
record(long) - Method in class io.prestosql.sql.planner.optimizations.OptimizerStats
 
record(long, boolean) - Method in class io.prestosql.sql.planner.iterative.RuleStats
 
record(Rule<?>, long, boolean) - Method in class io.prestosql.sql.planner.RuleStatsRecorder
 
record(PlanOptimizer, long) - Method in class io.prestosql.sql.planner.OptimizerStatsRecorder
 
recordBlocked(ListenableFuture<?>) - Method in class io.prestosql.operator.DriverContext
 
recordBlocked(ListenableFuture<?>) - Method in class io.prestosql.operator.OperatorContext
 
recordCalled(String, Object...) - Method in class io.prestosql.testing.ProcedureTester
 
recordCalled(String, List<Object>) - Method in class io.prestosql.testing.ProcedureTester
 
recordDynamicFilterSplitProcessed(long) - Method in class io.prestosql.operator.OperatorContext
 
recordFailure() - Method in class io.prestosql.sql.planner.iterative.RuleStats
 
recordFailure() - Method in class io.prestosql.sql.planner.optimizations.OptimizerStats
 
recordFailure(Rule<?>) - Method in class io.prestosql.sql.planner.RuleStatsRecorder
 
recordFailure(PlanOptimizer) - Method in class io.prestosql.sql.planner.OptimizerStatsRecorder
 
recordFailure(Exception) - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
recordGetSplitTime(long) - Method in class io.prestosql.execution.SqlStageExecution
 
recordGetSplitTime(long) - Method in class io.prestosql.execution.StageStateMachine
 
recordHashCollision(long, double) - Method in class io.prestosql.operator.HashCollisionsCounter
 
recordHashCollisions(HashCollisionsCounter) - Method in interface io.prestosql.operator.aggregation.builder.HashAggregationBuilder
 
recordHashCollisions(HashCollisionsCounter) - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
recordHashCollisions(HashCollisionsCounter) - Method in class io.prestosql.operator.aggregation.builder.SpillableHashAggregationBuilder
 
recordHeartbeat() - Method in interface io.prestosql.dispatcher.DispatchQuery
 
recordHeartbeat() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
recordHeartbeat() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
recordHeartbeat() - Method in class io.prestosql.execution.DataDefinitionExecution
 
recordHeartbeat() - Method in interface io.prestosql.execution.QueryExecution
 
recordHeartbeat() - Method in class io.prestosql.execution.QueryStateMachine
 
recordHeartbeat() - Method in class io.prestosql.execution.SqlQueryExecution
 
recordHeartbeat() - Method in class io.prestosql.execution.SqlTask
 
recordHeartbeat(QueryId) - Method in interface io.prestosql.execution.QueryManager
Updates the client heartbeat time, to prevent the query from be automatically purged.
recordHeartbeat(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
recordIndexJoinLookup() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
recordIntermediateSplit(PrioritizedSplitRunner) - Method in class io.prestosql.execution.executor.TaskHandle
 
recordMaterializedBytes(Page, LongConsumer) - Static method in class io.prestosql.operator.PageUtils
 
recordNetworkInput(long, long) - Method in class io.prestosql.operator.OperatorContext
Record the amount of network bytes that were read by an operator.
recordOutput(long, long) - Method in class io.prestosql.operator.OperatorContext
 
RecordPageSourceProvider - Class in io.prestosql.split
 
RecordPageSourceProvider(ConnectorRecordSetProvider) - Constructor for class io.prestosql.split.RecordPageSourceProvider
 
recordPhysicalInputWithTiming(long, long, long) - Method in class io.prestosql.operator.OperatorContext
Record the amount of physical bytes that were read by an operator and the time it took to read the data.
recordPhysicalWrittenData(long) - Method in class io.prestosql.operator.OperatorContext
 
recordProbe(int) - Method in class io.prestosql.operator.JoinStatisticsCounter
 
recordProcessed(OperationTimer) - Method in class io.prestosql.operator.DriverContext
 
recordProcessedInput(long, long) - Method in class io.prestosql.operator.OperatorContext
Record the size in bytes of input blocks that were processed by an operator.
recordStart() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
recordStreamedIndexJoinLookup() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
recordSubqueries(Node, ExpressionAnalysis) - Method in class io.prestosql.sql.analyzer.Analysis
 
recordSuccess() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
recordSuccessfulIndexJoinLookupByCacheReset() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
recordSuccessfulIndexJoinLookupByLimitedRequest() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
recordSuccessfulIndexJoinLookupBySingleRequest() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
recurseOnlyWhen(Predicate<PlanNode>) - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
RED - io.prestosql.operator.scalar.ColorFunctions.SystemColor
 
redirectAllFormLoginToUi(ContainerRequestContext) - Static method in class io.prestosql.server.ui.FormWebUiAuthenticationFilter
 
redirectFromSuccessfulLoginResponse(String) - Static method in class io.prestosql.server.ui.FormWebUiAuthenticationFilter
 
REDISTRIBUTE_WRITES - Static variable in class io.prestosql.SystemSessionProperties
 
redistributeSplit(Multimap<InternalNode, Split>, InternalNode, InternalNode, SetMultimap<InetAddress, InternalNode>) - Static method in class io.prestosql.execution.scheduler.UniformNodeSelector
The method selects and removes a split from the fromNode and assigns it to the toNode.
reduce(Type, Block, Object, BinaryFunctionInterface, UnaryFunctionInterface) - Static method in class io.prestosql.operator.scalar.ArrayReduceFunction
 
REDUCE_AGG - Static variable in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
ReduceAggregationFunction - Class in io.prestosql.operator.aggregation
 
ReduceAggregationFunction() - Constructor for class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
ReferenceAwareExpressionNodeInliner - Class in io.prestosql.sql.planner
 
ReferenceCount - Class in io.prestosql.operator
 
ReferenceCount(int) - Constructor for class io.prestosql.operator.ReferenceCount
 
referencesAny(Expression, Collection<Symbol>) - Static method in class io.prestosql.sql.ExpressionUtils
 
Reflection - Class in io.prestosql.util
 
ReflectionWindowFunctionSupplier<T extends WindowFunction> - Class in io.prestosql.operator.window
 
ReflectionWindowFunctionSupplier(Signature, Class<T>) - Constructor for class io.prestosql.operator.window.ReflectionWindowFunctionSupplier
 
ReflectionWindowFunctionSupplier(String, Type, List<? extends Type>, Class<T>) - Constructor for class io.prestosql.operator.window.ReflectionWindowFunctionSupplier
 
refreshKeys() - Method in class io.prestosql.server.security.jwt.JwkService
 
RefreshMaterializedViewAnalysis(QualifiedObjectName, TableHandle, Query, List<ColumnHandle>) - Constructor for class io.prestosql.sql.analyzer.Analysis.RefreshMaterializedViewAnalysis
 
RefreshMaterializedViewReference(QualifiedObjectName, TableHandle, List<TableHandle>) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewReference
 
RefreshMaterializedViewTarget(TableHandle, InsertTableHandle, SchemaTableName, List<TableHandle>) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewTarget
 
refreshNodes() - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
refreshNodes() - Method in class io.prestosql.metadata.InMemoryNodeManager
 
refreshNodes() - Method in interface io.prestosql.metadata.InternalNodeManager
 
refreshNodes() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
refreshTopology() - Method in class io.prestosql.execution.scheduler.FileBasedNetworkTopology
 
regex() - Method in class io.prestosql.type.JoniRegexp
 
RegexLibrary - Enum in io.prestosql.sql.analyzer
 
regexpCount(Slice, JoniRegexp) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpCount(Slice, Re2JRegexp) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpExtract(Slice, JoniRegexp) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpExtract(Slice, JoniRegexp, long) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpExtract(Slice, Re2JRegexp) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpExtract(Slice, Re2JRegexp, long) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpExtractAll(Slice, JoniRegexp) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpExtractAll(Slice, JoniRegexp, long) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpExtractAll(Slice, Re2JRegexp) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpExtractAll(Slice, Re2JRegexp, long) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpLike(Slice, JoniRegexp) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpLike(Slice, Re2JRegexp) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpPosition(Slice, JoniRegexp) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpPosition(Slice, JoniRegexp, long) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpPosition(Slice, JoniRegexp, long, long) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpPosition(Slice, Re2JRegexp) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpPosition(Slice, Re2JRegexp, long) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpPosition(Slice, Re2JRegexp, long, long) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpReplace(Slice, JoniRegexp) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpReplace(Slice, JoniRegexp, Slice) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpReplace(Slice, JoniRegexp, UnaryFunctionInterface) - Method in class io.prestosql.operator.scalar.JoniRegexpReplaceLambdaFunction
 
regexpReplace(Slice, Re2JRegexp) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpReplace(Slice, Re2JRegexp, Slice) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpReplace(Slice, Re2JRegexp, UnaryFunctionInterface) - Method in class io.prestosql.operator.scalar.Re2JRegexpReplaceLambdaFunction
 
regexpSplit(Slice, JoniRegexp) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpSplit(Slice, Re2JRegexp) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
register(C) - Method in class io.prestosql.util.AutoCloseableCloser
 
register(Rule<?>) - Method in class io.prestosql.sql.planner.iterative.RuleIndex.Builder
 
register(PlanOptimizer) - Method in class io.prestosql.sql.planner.OptimizerStatsRecorder
 
register(Set<Rule<?>>) - Method in class io.prestosql.sql.planner.iterative.RuleIndex.Builder
 
registerAll(Collection<Rule<?>>) - Method in class io.prestosql.sql.planner.RuleStatsRecorder
 
registerCatalog(Catalog) - Method in class io.prestosql.metadata.CatalogManager
 
registerExpandableQuery(Query, Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
registerNamedQuery(Table, Query) - Method in class io.prestosql.sql.analyzer.Analysis
 
registerQuery(SqlQueryExecution, SubPlan) - Method in class io.prestosql.server.DynamicFilterService
 
registerQuery(QueryId, Session, Set<DynamicFilterId>, Set<DynamicFilterId>, Set<DynamicFilterId>) - Method in class io.prestosql.server.DynamicFilterService
 
registerTable(Table, Optional<TableHandle>, QualifiedObjectName, List<ViewExpression>, Map<Field, List<ViewExpression>>, String, Scope) - Method in class io.prestosql.sql.analyzer.Analysis
 
registerTableForColumnMasking(QualifiedObjectName, String, String) - Method in class io.prestosql.sql.analyzer.Analysis
 
registerTableForRowFiltering(QualifiedObjectName, String) - Method in class io.prestosql.sql.analyzer.Analysis
 
registerTableForView(Table) - Method in class io.prestosql.sql.analyzer.Analysis
 
RegressionState - Interface in io.prestosql.operator.aggregation.state
 
regrIntercept(RegressionState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DoubleRegressionAggregation
 
regrIntercept(RegressionState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealRegressionAggregation
 
regrSlope(RegressionState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DoubleRegressionAggregation
 
regrSlope(RegressionState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealRegressionAggregation
 
rehash(long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
Rehashes the map.
rehash(long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Rehashes the map.
RelationId - Class in io.prestosql.sql.analyzer
 
RelationType - Class in io.prestosql.sql.analyzer
TODO: this needs to be merged with RowType at some point (when the type system is unified)
RelationType(Field...) - Constructor for class io.prestosql.sql.analyzer.RelationType
 
RelationType(List<Field>) - Constructor for class io.prestosql.sql.analyzer.RelationType
 
release() - Method in class io.prestosql.operator.PartitionedConsumption.Partition
 
release() - Method in class io.prestosql.operator.ReferenceCount
 
REMOTE - io.prestosql.sql.planner.plan.ExchangeNode.Scope
 
REMOTE_CONNECTOR_ID - Static variable in class io.prestosql.operator.ExchangeOperator
 
REMOTE_TASK_MISMATCH_ERROR - Static variable in class io.prestosql.util.Failures
 
RemoteHandleResolver - Class in io.prestosql.metadata
 
RemoteHandleResolver() - Constructor for class io.prestosql.metadata.RemoteHandleResolver
 
RemoteNodeMemory - Class in io.prestosql.memory
 
RemoteNodeMemory(InternalNode, HttpClient, JsonCodec<MemoryInfo>, JsonCodec<MemoryPoolAssignmentsRequest>, URI) - Constructor for class io.prestosql.memory.RemoteNodeMemory
 
RemoteNodeState - Class in io.prestosql.metadata
 
RemoteNodeState(HttpClient, URI) - Constructor for class io.prestosql.metadata.RemoteNodeState
 
RemoteSourceNode - Class in io.prestosql.sql.planner.plan
 
RemoteSourceNode(PlanNodeId, PlanFragmentId, List<Symbol>, Optional<OrderingScheme>, ExchangeNode.Type) - Constructor for class io.prestosql.sql.planner.plan.RemoteSourceNode
 
RemoteSourceNode(PlanNodeId, List<PlanFragmentId>, List<Symbol>, Optional<OrderingScheme>, ExchangeNode.Type) - Constructor for class io.prestosql.sql.planner.plan.RemoteSourceNode
 
RemoteSplit - Class in io.prestosql.split
 
RemoteSplit(URI) - Constructor for class io.prestosql.split.RemoteSplit
 
RemoteTask - Interface in io.prestosql.execution
 
RemoteTaskFactory - Interface in io.prestosql.execution
 
RemoteTaskStats - Class in io.prestosql.server.remotetask
 
RemoteTaskStats() - Constructor for class io.prestosql.server.remotetask.RemoteTaskStats
 
RemoteTransactionHandle - Enum in io.prestosql.metadata
 
remove(long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
remove(long, long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
remove(long, long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
remove(long, long, long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
remove(E) - Method in class io.prestosql.execution.resourcegroups.IndexedPriorityQueue
 
remove(PageCodecMarker) - Method in class io.prestosql.execution.buffer.PageCodecMarker.MarkerSet
 
remove(PrioritizedSplitRunner) - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
remove(MethodHandle, Type, Block, boolean) - Method in class io.prestosql.operator.scalar.ArrayRemoveFunction
 
remove(MethodHandle, Type, Block, double) - Method in class io.prestosql.operator.scalar.ArrayRemoveFunction
 
remove(MethodHandle, Type, Block, long) - Method in class io.prestosql.operator.scalar.ArrayRemoveFunction
 
remove(MethodHandle, Type, Block, Object) - Method in class io.prestosql.operator.scalar.ArrayRemoveFunction
 
RemoveAggregationInSemiJoin - Class in io.prestosql.sql.planner.iterative.rule
Remove the aggregation node that produces distinct rows from the Filtering source of a Semi join.
RemoveAggregationInSemiJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveAggregationInSemiJoin
 
removeAll() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
removeAll(Collection<PrioritizedSplitRunner>) - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
removeAssignedSplit(InternalNode) - Method in class io.prestosql.execution.scheduler.NodeAssignmentStats
 
removeCatalog(String) - Method in class io.prestosql.metadata.CatalogManager
 
removeCatalogAccessControl(CatalogName) - Method in class io.prestosql.security.AccessControlManager
 
removeCatalogHandleResolver(String) - Method in class io.prestosql.metadata.HandleResolver
 
removeConnectorPageSinkProvider(CatalogName) - Method in class io.prestosql.split.PageSinkManager
 
removeConnectorPageSourceProvider(CatalogName) - Method in class io.prestosql.split.PageSourceManager
 
removeConnectorSessionProperties(CatalogName) - Method in class io.prestosql.metadata.SessionPropertyManager
 
removeConnectorSplitManager(CatalogName) - Method in class io.prestosql.split.SplitManager
 
RemoveDuplicateConditions - Class in io.prestosql.sql.planner.iterative.rule
Flattens and removes duplicate conjuncts or disjuncts.
RemoveDuplicateConditions(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveDuplicateConditions
 
RemoveEmptyDelete - Class in io.prestosql.sql.planner.iterative.rule
If the predicate for a delete is optimized to false, the target table scan of the delete will be replaced with an empty values node.
RemoveEmptyDelete() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveEmptyDelete
 
removeFirst() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
RemoveFullSample - Class in io.prestosql.sql.planner.iterative.rule
Removes 100% sample nodes.
RemoveFullSample() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveFullSample
 
removeIndexProvider(CatalogName) - Method in class io.prestosql.index.IndexManager
 
removeInput(LongDoubleState, double) - Static method in class io.prestosql.operator.aggregation.DoubleSumAggregation
 
removeInput(LongLongState, long) - Static method in class io.prestosql.operator.aggregation.LongSumAggregation
 
removeInput(LongAndDoubleState, double) - Static method in class io.prestosql.operator.aggregation.AverageAggregations
 
removeInput(LongAndDoubleState, long) - Static method in class io.prestosql.operator.aggregation.AverageAggregations
 
removeInput(LongState) - Static method in class io.prestosql.operator.aggregation.CountAggregation
 
removeInput(LongState, boolean) - Static method in class io.prestosql.operator.aggregation.CountIfAggregation
 
removeInput(LongState, DoubleState, long) - Static method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
removeInput(LongState, Block, int) - Static method in class io.prestosql.operator.aggregation.CountColumn
 
removeInput(WindowIndex, List<Integer>, int, int) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
removeListener(MemoryPoolListener) - Method in class io.prestosql.memory.MemoryPool
 
removeNodeChangeListener(Consumer<AllNodes>) - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
removeNodeChangeListener(Consumer<AllNodes>) - Method in class io.prestosql.metadata.InMemoryNodeManager
 
removeNodeChangeListener(Consumer<AllNodes>) - Method in interface io.prestosql.metadata.InternalNodeManager
 
removeOldTasks() - Method in class io.prestosql.execution.SqlTaskManager
 
removePage() - Method in class io.prestosql.operator.exchange.LocalExchangeSource
 
removePartitioningProvider(CatalogName) - Method in class io.prestosql.sql.planner.NodePartitioningManager
 
removePreparedStatement(String) - Method in class io.prestosql.execution.QueryStateMachine
 
removeProcedures(CatalogName) - Method in class io.prestosql.metadata.ProcedureRegistry
 
removeQuery(QueryId) - Method in class io.prestosql.server.DynamicFilterService
 
RemoveRedundantCrossJoin - Class in io.prestosql.sql.planner.iterative.rule
 
RemoveRedundantCrossJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantCrossJoin
 
RemoveRedundantDistinctLimit - Class in io.prestosql.sql.planner.iterative.rule
Replace DistinctLimit node 1.
RemoveRedundantDistinctLimit() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantDistinctLimit
 
RemoveRedundantEnforceSingleRowNode - Class in io.prestosql.sql.planner.iterative.rule
 
RemoveRedundantEnforceSingleRowNode() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantEnforceSingleRowNode
 
RemoveRedundantExists - Class in io.prestosql.sql.planner.iterative.rule
Given:
RemoveRedundantExists() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantExists
 
RemoveRedundantIdentityProjections - Class in io.prestosql.sql.planner.iterative.rule
Removes projection nodes that only perform non-renaming identity projections
RemoveRedundantIdentityProjections() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantIdentityProjections
 
RemoveRedundantJoin - Class in io.prestosql.sql.planner.iterative.rule
 
RemoveRedundantJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantJoin
 
RemoveRedundantLimit - Class in io.prestosql.sql.planner.iterative.rule
Remove Limit node when the subplan is guaranteed to produce fewer rows than the limit and replace the plan with empty values if the limit count is 0.
RemoveRedundantLimit() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantLimit
 
RemoveRedundantOffset - Class in io.prestosql.sql.planner.iterative.rule
Remove Offset node and its subplan when the subplan is guaranteed to produce no more rows than the offset and replace the plan with empty values.
RemoveRedundantOffset() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantOffset
 
RemoveRedundantSort - Class in io.prestosql.sql.planner.iterative.rule
 
RemoveRedundantSort() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantSort
 
RemoveRedundantTableScanPredicate - Class in io.prestosql.sql.planner.iterative.rule
 
RemoveRedundantTableScanPredicate(Metadata, TypeOperators) - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantTableScanPredicate
 
RemoveRedundantTopN - Class in io.prestosql.sql.planner.iterative.rule
Replace TopN node 1.
RemoveRedundantTopN() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveRedundantTopN
 
removeSymbolStatistics(Symbol) - Method in class io.prestosql.cost.PlanNodeStatsEstimate.Builder
 
removeTask(TaskHandle) - Method in class io.prestosql.execution.executor.TaskExecutor
 
RemoveTrivialFilters - Class in io.prestosql.sql.planner.iterative.rule
 
RemoveTrivialFilters() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveTrivialFilters
 
RemoveUnreferencedScalarApplyNodes - Class in io.prestosql.sql.planner.iterative.rule
 
RemoveUnreferencedScalarApplyNodes() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveUnreferencedScalarApplyNodes
 
RemoveUnreferencedScalarSubqueries - Class in io.prestosql.sql.planner.iterative.rule
 
RemoveUnreferencedScalarSubqueries() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveUnreferencedScalarSubqueries
 
RemoveUnsupportedDynamicFilters - Class in io.prestosql.sql.planner.iterative.rule
Dynamic filters are supported only right after TableScan and only if the subtree is on 1.
RemoveUnsupportedDynamicFilters(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveUnsupportedDynamicFilters
 
RENAME_COLUMN - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
RENAME_SCHEMA - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
RENAME_TABLE - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
RENAME_VIEW - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
renameColumn(Session, TableHandle, ColumnHandle, String) - Method in interface io.prestosql.metadata.Metadata
Rename the specified column.
renameColumn(Session, TableHandle, ColumnHandle, String) - Method in class io.prestosql.metadata.MetadataManager
 
renameColumn(ConnectorSession, ConnectorTableHandle, ColumnHandle, String) - Method in class io.prestosql.testing.TestingMetadata
 
RenameColumnTask - Class in io.prestosql.execution
 
RenameColumnTask() - Constructor for class io.prestosql.execution.RenameColumnTask
 
renameSchema(Session, CatalogSchemaName, String) - Method in interface io.prestosql.metadata.Metadata
Renames the specified schema.
renameSchema(Session, CatalogSchemaName, String) - Method in class io.prestosql.metadata.MetadataManager
 
RenameSchemaTask - Class in io.prestosql.execution
 
RenameSchemaTask() - Constructor for class io.prestosql.execution.RenameSchemaTask
 
renameTable(Session, TableHandle, QualifiedObjectName) - Method in interface io.prestosql.metadata.Metadata
Rename the specified table.
renameTable(Session, TableHandle, QualifiedObjectName) - Method in class io.prestosql.metadata.MetadataManager
 
renameTable(ConnectorSession, ConnectorTableHandle, SchemaTableName) - Method in class io.prestosql.testing.TestingMetadata
 
RenameTableTask - Class in io.prestosql.execution
 
RenameTableTask() - Constructor for class io.prestosql.execution.RenameTableTask
 
renameView(Session, QualifiedObjectName, QualifiedObjectName) - Method in interface io.prestosql.metadata.Metadata
Rename the specified view.
renameView(Session, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.metadata.MetadataManager
 
RenameViewTask - Class in io.prestosql.execution
 
RenameViewTask() - Constructor for class io.prestosql.execution.RenameViewTask
 
render(boolean) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
render(double, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
render(long, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
render(Slice, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
render(PlanRepresentation) - Method in class io.prestosql.sql.planner.planprinter.JsonRenderer
 
render(PlanRepresentation) - Method in interface io.prestosql.sql.planner.planprinter.Renderer
 
render(PlanRepresentation) - Method in class io.prestosql.sql.planner.planprinter.TextRenderer
 
Renderer<T> - Interface in io.prestosql.sql.planner.planprinter
 
ReorderJoins - Class in io.prestosql.sql.planner.iterative.rule
 
ReorderJoins(Metadata, CostComparator) - Constructor for class io.prestosql.sql.planner.iterative.rule.ReorderJoins
 
REPARTITION - io.prestosql.sql.planner.plan.ExchangeNode.Type
 
repeat(Type, Boolean, long) - Static method in class io.prestosql.operator.scalar.RepeatFunction
 
repeat(Type, Double, long) - Static method in class io.prestosql.operator.scalar.RepeatFunction
 
repeat(Type, Long, long) - Static method in class io.prestosql.operator.scalar.RepeatFunction
 
repeat(Type, Object, long) - Static method in class io.prestosql.operator.scalar.RepeatFunction
 
repeat(Boolean, long) - Static method in class io.prestosql.operator.scalar.RepeatFunction
 
repeatableRead() - Method in class io.prestosql.transaction.TransactionBuilder
 
RepeatFunction - Class in io.prestosql.operator.scalar
 
replace(int, PlanNode, String) - Method in class io.prestosql.sql.planner.iterative.Memo
 
replace(long, long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
replace(long, long, long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
replace(long, long, long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
replace(long, long, long, long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
replace(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
replace(Slice, Slice) - Method in class io.prestosql.type.Re2JRegexp
 
replace(Slice, Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
replaceAll(PlanNode) - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
replaceChildren(PlanNode, List<PlanNode>) - Static method in class io.prestosql.sql.planner.plan.ChildReplacer
Return an identical copy of the given node with its children replaced
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.iterative.GroupReference
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.AssignUniqueId
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.CorrelatedJoinNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.DeleteNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.DistinctLimitNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.EnforceSingleRowNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.ExceptNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.ExchangeNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.ExplainAnalyzeNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.FilterNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.IndexJoinNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.IndexSourceNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.IntersectNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.JoinNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.LimitNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.MarkDistinctNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.OffsetNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.OutputNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.PlanNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.ProjectNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.RemoteSourceNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.RowNumberNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.SampleNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.SortNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.TableDeleteNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.TableFinishNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.TableScanNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.TopNNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.UnionNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.ValuesNode
 
replaceChildren(List<PlanNode>) - Method in class io.prestosql.sql.planner.plan.WindowNode
 
replaceExpression(Expression, Map<? extends Expression, ? extends Expression>) - Static method in class io.prestosql.sql.planner.ExpressionNodeInliner
 
replaceExpression(Expression, Map<NodeRef<Expression>, Expression>) - Static method in class io.prestosql.sql.planner.ReferenceAwareExpressionNodeInliner
 
replaceFirst(PlanNode) - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
REPLICATE - io.prestosql.sql.planner.plan.ExchangeNode.Type
 
REPLICATED - io.prestosql.sql.planner.plan.JoinNode.DistributionType
 
REPLICATED - io.prestosql.sql.planner.plan.SemiJoinNode.DistributionType
 
REPLICATED - io.prestosql.sql.planner.plan.SpatialJoinNode.DistributionType
 
replicatedExchange(PlanNodeId, ExchangeNode.Scope, PlanNode) - Static method in class io.prestosql.sql.planner.plan.ExchangeNode
 
ReplicateSemiJoinInDelete - Class in io.prestosql.sql.planner.optimizations
 
ReplicateSemiJoinInDelete() - Constructor for class io.prestosql.sql.planner.optimizations.ReplicateSemiJoinInDelete
 
requestComplete(HttpPageBufferClient) - Method in interface io.prestosql.operator.HttpPageBufferClient.ClientCallback
 
requestMemoryRevoking() - Method in class io.prestosql.operator.OperatorContext
Returns how much revocable memory will be revoked by the operator
requestShutdown() - Method in class io.prestosql.server.GracefulShutdownHandler
 
REQUIRED_WORKERS_COUNT - Static variable in class io.prestosql.SystemSessionProperties
 
REQUIRED_WORKERS_MAX_WAIT_TIME - Static variable in class io.prestosql.SystemSessionProperties
 
rescale(long, int, int) - Static method in class io.prestosql.type.DateTimes
Rescales a value of the given precision to another precision by adding 0s or truncating.
rescaleWithRounding(long, int, int) - Static method in class io.prestosql.type.DateTimes
 
reserve(long) - Method in class io.prestosql.spiller.SpillSpaceTracker
Reserves the given number of bytes to spill.
reserve(QueryId, String, long) - Method in class io.prestosql.memory.MemoryPool
Reserves the given number of bytes.
RESERVED_POOL - Static variable in class io.prestosql.memory.LocalMemoryManager
 
reserveRevocable(QueryId, long) - Method in class io.prestosql.memory.MemoryPool
 
reserveSpill(long) - Method in class io.prestosql.memory.QueryContext
 
reserveSpill(long) - Method in class io.prestosql.operator.DriverContext
 
reserveSpill(long) - Method in class io.prestosql.operator.PipelineContext
 
reserveSpill(long) - Method in class io.prestosql.operator.TaskContext
 
reset() - Method in class io.prestosql.execution.scheduler.ResettableRandomizedIterator
 
reset() - Method in interface io.prestosql.operator.aggregation.arrayagg.ArrayAggregationState
 
reset() - Method in class io.prestosql.operator.aggregation.arrayagg.SingleArrayAggregationState
 
reset() - Method in interface io.prestosql.operator.aggregation.multimapagg.MultimapAggregationState
 
reset() - Method in class io.prestosql.operator.aggregation.multimapagg.SingleMultimapAggregationState
 
reset() - Method in class io.prestosql.operator.DriverYieldSignal
 
reset() - Method in class io.prestosql.operator.index.IndexSnapshotBuilder
 
reset() - Method in class io.prestosql.operator.LookupJoinPageBuilder
 
reset() - Method in class io.prestosql.operator.window.CumulativeDistributionFunction
 
reset() - Method in class io.prestosql.operator.window.DenseRankFunction
 
reset() - Method in class io.prestosql.operator.window.NTileFunction
 
reset() - Method in class io.prestosql.operator.window.PercentRankFunction
 
reset() - Method in class io.prestosql.operator.window.RankFunction
 
reset() - Method in class io.prestosql.testing.ProcedureTester
 
reset() - Method in class io.prestosql.testing.TestingAccessControlManager
 
reset() - Method in class io.prestosql.testing.TestingGroupProvider
 
reset(WindowIndex) - Method in class io.prestosql.operator.window.AggregateWindowFunction
 
resetLevelPriority() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
Updates the task level priority to be greater than or equal to the minimum priority within that level.
resetLevelPriority() - Method in class io.prestosql.execution.executor.TaskHandle
 
resetMemoryRevokingRequested() - Method in class io.prestosql.operator.OperatorContext
 
ResetSessionTask - Class in io.prestosql.execution
 
ResetSessionTask() - Constructor for class io.prestosql.execution.ResetSessionTask
 
ResettableRandomizedIterator<T> - Class in io.prestosql.execution.scheduler
 
ResettableRandomizedIterator(Collection<T>) - Constructor for class io.prestosql.execution.scheduler.ResettableRandomizedIterator
 
resetTo(SqlTaskIoStats) - Method in class io.prestosql.execution.SqlTaskIoStats
 
resetUpdateType() - Method in class io.prestosql.sql.analyzer.Analysis
 
resetWithPathTo(long) - Method in class io.prestosql.util.HeapTraversal
 
resetYieldForTesting() - Method in class io.prestosql.operator.DriverYieldSignal
 
resolve(CatalogName, SchemaTableName) - Method in class io.prestosql.metadata.ProcedureRegistry
 
resolve(FunctionBinding, FunctionDependencies) - Method in interface io.prestosql.operator.annotations.ImplementationDependency
 
resolve(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.annotations.LiteralImplementationDependency
 
resolve(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.annotations.ScalarImplementationDependency
 
resolve(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.annotations.TypeImplementationDependency
 
resolve(FunctionBinding, FunctionDependencyDeclaration) - Method in class io.prestosql.metadata.MetadataManager
 
resolve(GroupReference) - Method in class io.prestosql.sql.planner.iterative.Memo
 
resolve(PlanNode) - Method in interface io.prestosql.sql.planner.iterative.Lookup
Deprecated.
resolve(String) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
resolveAsteriskedIdentifierChainBasis(QualifiedName, AllColumns) - Method in class io.prestosql.sql.analyzer.Scope
This method analyzes asterisked identifier chain in 'all fields reference', according to SQL standard.
ResolvedField - Class in io.prestosql.sql.analyzer
 
ResolvedField(Scope, Field, int, int, boolean) - Constructor for class io.prestosql.sql.analyzer.ResolvedField
 
ResolvedFunction - Class in io.prestosql.metadata
 
ResolvedFunction(BoundSignature, FunctionId, Map<TypeSignature, Type>, Set<ResolvedFunction>) - Constructor for class io.prestosql.metadata.ResolvedFunction
 
ResolvedFunction.ResolvedFunctionDecoder - Class in io.prestosql.metadata
 
ResolvedFunctionCallRewriter - Class in io.prestosql.sql.planner
 
ResolvedFunctionDecoder(Function<TypeId, Type>) - Constructor for class io.prestosql.metadata.ResolvedFunction.ResolvedFunctionDecoder
 
ResolvedIndex - Class in io.prestosql.metadata
 
ResolvedIndex(CatalogName, ConnectorTransactionHandle, ConnectorResolvedIndex) - Constructor for class io.prestosql.metadata.ResolvedIndex
 
resolveField(Expression, QualifiedName) - Method in class io.prestosql.sql.analyzer.Scope
 
resolveFields(QualifiedName) - Method in class io.prestosql.sql.analyzer.RelationType
Gets the index of all columns matching the specified name
resolveFunction(QualifiedName, List<TypeSignatureProvider>) - Method in interface io.prestosql.metadata.Metadata
 
resolveFunction(QualifiedName, List<TypeSignatureProvider>) - Method in class io.prestosql.metadata.MetadataManager
 
resolveGroup(PlanNode) - Method in interface io.prestosql.sql.planner.iterative.Lookup
Resolves nodes by materializing GroupReference nodes representing symbolic references to other nodes.
resolveGroupReferences(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.iterative.Plans
 
resolveIndex(Session, TableHandle, Set<ColumnHandle>, Set<ColumnHandle>, TupleDomain<ColumnHandle>) - Method in interface io.prestosql.metadata.Metadata
Try to locate a table index that can lookup results by indexableColumns and provide the requested outputColumns.
resolveIndex(Session, TableHandle, Set<ColumnHandle>, Set<ColumnHandle>, TupleDomain<ColumnHandle>) - Method in class io.prestosql.metadata.MetadataManager
 
resolveOperator(OperatorType, List<? extends Type>) - Method in interface io.prestosql.metadata.Metadata
 
resolveOperator(OperatorType, List<? extends Type>) - Method in class io.prestosql.metadata.MetadataManager
 
resolveSigningKey(JwsHeader, Claims) - Method in class io.prestosql.server.security.jwt.FileSigningKeyResolver
 
resolveSigningKey(JwsHeader, Claims) - Method in class io.prestosql.server.security.jwt.JwkSigningKeyResolver
 
resolveSigningKey(JwsHeader, String) - Method in class io.prestosql.server.security.jwt.FileSigningKeyResolver
 
resolveSigningKey(JwsHeader, String) - Method in class io.prestosql.server.security.jwt.JwkSigningKeyResolver
 
resolveVisibleFieldsWithRelationPrefix(Optional<QualifiedName>) - Method in class io.prestosql.sql.analyzer.RelationType
Gets all visible fields whose relation alias matches given prefix.
RESOURCE_OVERCOMMIT - Static variable in class io.prestosql.SystemSessionProperties
 
ResourceAccessType - Class in io.prestosql.server.security
 
ResourceAccessType(ResourceSecurityBinder.StaticResourceAccessTypeLoader) - Constructor for class io.prestosql.server.security.ResourceAccessType
 
ResourceAccessTypeLoader - Interface in io.prestosql.server.security
 
ResourceEstimateBuilder() - Constructor for class io.prestosql.Session.ResourceEstimateBuilder
 
ResourceGroupConfigurationManagerContextInstance - Class in io.prestosql.execution.resourcegroups
 
ResourceGroupConfigurationManagerContextInstance(ClusterMemoryPoolManager, String) - Constructor for class io.prestosql.execution.resourcegroups.ResourceGroupConfigurationManagerContextInstance
 
ResourceGroupInfo - Class in io.prestosql.server
 
ResourceGroupInfo(ResourceGroupId, ResourceGroupState, SchedulingPolicy, int, DataSize, int, int, int, DataSize, Duration, int, int, int, Optional<List<ResourceGroupInfo>>, Optional<List<QueryStateInfo>>) - Constructor for class io.prestosql.server.ResourceGroupInfo
 
ResourceGroupManager<C> - Interface in io.prestosql.execution.resourcegroups
Classes implementing this interface must be thread safe.
ResourceGroupStateInfoResource - Class in io.prestosql.server
 
ResourceGroupStateInfoResource(ResourceGroupManager<?>) - Constructor for class io.prestosql.server.ResourceGroupStateInfoResource
 
resourceOvercommit(Session) - Static method in class io.prestosql.SystemSessionProperties
 
resourceSecurity(AnnotatedElement, ResourceSecurity.AccessType) - Method in class io.prestosql.server.security.ResourceSecurityBinder
 
ResourceSecurity - Annotation Type in io.prestosql.server.security
Defines the authentication and authorization required to access a REST resource.
ResourceSecurity.AccessType - Enum in io.prestosql.server.security
 
resourceSecurityBinder(Binder) - Static method in class io.prestosql.server.security.ResourceSecurityBinder
 
ResourceSecurityBinder - Class in io.prestosql.server.security
 
ResourceSecurityBinder.StaticResourceAccessTypeLoader - Class in io.prestosql.server.security
 
ResourceSecurityDynamicFeature - Class in io.prestosql.server.security
 
ResourceSecurityDynamicFeature(ResourceAccessType, AuthenticationFilter, WebUiAuthenticationFilter, InternalAuthenticationManager, AccessControl, GroupProvider, SecurityConfig) - Constructor for class io.prestosql.server.security.ResourceSecurityDynamicFeature
 
responseSize(long) - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
Result(RowExpression, InputChannels) - Constructor for class io.prestosql.operator.project.PageFieldsToInputParametersRewriter.Result
 
RESULT - io.prestosql.operator.WorkProcessor.ProcessState.Type
 
resultBuilder(Session, Type...) - Static method in class io.prestosql.testing.MaterializedResult
 
resultBuilder(Session, Iterable<? extends Type>) - Static method in class io.prestosql.testing.MaterializedResult
 
resultBuilder(ConnectorSession, Type...) - Static method in class io.prestosql.testing.MaterializedResult
 
resultBuilder(ConnectorSession, Iterable<? extends Type>) - Static method in class io.prestosql.testing.MaterializedResult
 
retain() - Method in class io.prestosql.operator.ReferenceCount
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.operator.GroupByIdBlock
 
RETRY - io.prestosql.sql.analyzer.FeaturesConfig.DataIntegrityVerification
 
returnConvention(InvocationConvention.InvocationReturnConvention) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.ChoiceBuilder
 
returnType(TypeSignature) - Method in class io.prestosql.metadata.SignatureBuilder
 
reverse(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
reverse(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
reverse(Type, Block) - Method in class io.prestosql.operator.scalar.ArrayReverseFunction
 
reversed() - Method in interface io.prestosql.type.BlockTypeOperators.BlockPositionComparison
 
revokeRoles(Session, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in interface io.prestosql.metadata.Metadata
Revokes the specified roles from the specified grantees in the specified catalog
revokeRoles(Session, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.metadata.MetadataManager
 
RevokeRolesTask - Class in io.prestosql.execution
 
RevokeRolesTask() - Constructor for class io.prestosql.execution.RevokeRolesTask
 
revokeSchemaPrivileges(Session, CatalogSchemaName, Set<Privilege>, PrestoPrincipal, boolean) - Method in interface io.prestosql.metadata.Metadata
Revokes the specified privilege on the specified schema from the specified user.
revokeSchemaPrivileges(Session, CatalogSchemaName, Set<Privilege>, PrestoPrincipal, boolean) - Method in class io.prestosql.metadata.MetadataManager
 
revokeTablePrivileges(Session, QualifiedObjectName, Set<Privilege>, PrestoPrincipal, boolean) - Method in interface io.prestosql.metadata.Metadata
Revokes the specified privilege on the specified table from the specified user
revokeTablePrivileges(Session, QualifiedObjectName, Set<Privilege>, PrestoPrincipal, boolean) - Method in class io.prestosql.metadata.MetadataManager
 
revokeTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, PrestoPrincipal, boolean) - Method in class io.prestosql.testing.TestingMetadata
 
RevokeTask - Class in io.prestosql.execution
 
RevokeTask() - Constructor for class io.prestosql.execution.RevokeTask
 
rewrite(Session, Metadata, SqlParser, Optional<QueryExplainer>, Statement, List<Expression>, Map<NodeRef<Parameter>, Expression>, GroupProvider, AccessControl, WarningCollector, StatsCalculator) - Method in class io.prestosql.sql.rewrite.ShowStatsRewrite
 
rewrite(Session, Metadata, SqlParser, Optional<QueryExplainer>, Statement, List<Expression>, Map<NodeRef<Parameter>, Expression>, GroupProvider, AccessControl, WarningCollector, StatsCalculator) - Static method in class io.prestosql.sql.rewrite.StatementRewrite
 
rewrite(PlanNode) - Method in class io.prestosql.sql.planner.plan.SimplePlanRewriter.RewriteContext
This method is meant for invoking the rewrite logic on children while processing a node
rewrite(PlanNode, C) - Method in class io.prestosql.sql.planner.plan.SimplePlanRewriter.RewriteContext
This method is meant for invoking the rewrite logic on children while processing a node
rewrite(ExpressionRewriter<Void>) - Method in class io.prestosql.sql.planner.plan.Assignments
 
rewrite(Expression, Metadata, TypeAnalyzer, Session, SymbolAllocator) - Static method in class io.prestosql.sql.planner.DesugarTryExpressionRewriter
 
rewrite(Expression, Session, Metadata, TypeAnalyzer, SymbolAllocator) - Static method in class io.prestosql.sql.planner.DesugarAtTimeZoneRewriter
 
rewrite(Expression, Session, Metadata, TypeAnalyzer, TypeProvider) - Static method in class io.prestosql.sql.planner.DesugarArrayConstructorRewriter
 
rewrite(Expression, Session, Metadata, TypeAnalyzer, TypeProvider) - Static method in class io.prestosql.sql.planner.DesugarLikeRewriter
 
rewrite(Expression, Session, Metadata, TypeAnalyzer, TypeProvider) - Static method in class io.prestosql.sql.planner.iterative.rule.CanonicalizeExpressionRewriter
 
rewrite(Expression, Session, TypeAnalyzer, SymbolAllocator) - Static method in class io.prestosql.sql.planner.DesugarRowSubscriptRewriter
 
rewrite(Expression, Rule.Context) - Method in interface io.prestosql.sql.planner.iterative.rule.ExpressionRewriteRuleSet.ExpressionRewriter
 
rewrite(Expression, TypeProvider, SymbolAllocator) - Static method in class io.prestosql.sql.planner.iterative.rule.LambdaCaptureDesugaringRewriter
 
rewrite(Expression, Map<NodeRef<Expression>, Type>) - Static method in class io.prestosql.sql.planner.DesugarRowSubscriptRewriter
 
rewrite(Expression, Map<NodeRef<Expression>, Type>, Metadata) - Static method in class io.prestosql.sql.planner.DesugarArrayConstructorRewriter
 
rewrite(Expression, Map<NodeRef<Expression>, Type>, Metadata) - Static method in class io.prestosql.sql.planner.DesugarAtTimeZoneRewriter
 
rewrite(Expression, Map<NodeRef<Expression>, Type>, Metadata) - Static method in class io.prestosql.sql.planner.DesugarLikeRewriter
 
rewrite(Expression, Set<Symbol>) - Method in class io.prestosql.sql.planner.EqualityInference
Attempts to rewrite an Expression in terms of the symbols allowed by the symbol scope given the known equalities.
rewrite(Function<Expression, Expression>) - Method in class io.prestosql.sql.planner.plan.Assignments
 
rewriteExpression(Expression, Void, ExpressionTreeRewriter<Void>) - Method in class io.prestosql.sql.planner.ExpressionNodeInliner
 
rewriteExpression(Expression, Void, ExpressionTreeRewriter<Void>) - Method in class io.prestosql.sql.planner.ParameterRewriter
 
rewriteExpression(Expression, Void, ExpressionTreeRewriter<Void>) - Method in class io.prestosql.sql.planner.ReferenceAwareExpressionNodeInliner
 
rewriteGroupingOperation(GroupingOperation, List<Set<Integer>>, Map<NodeRef<Expression>, ResolvedField>, Optional<Symbol>) - Static method in class io.prestosql.sql.planner.GroupingOperationRewriter
 
rewriteIdentifiersToSymbolReferences(Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
rewritePageFieldsToInputParameters(RowExpression) - Static method in class io.prestosql.operator.project.PageFieldsToInputParametersRewriter
 
rewriteParameter(Parameter, Void, ExpressionTreeRewriter<Void>) - Method in class io.prestosql.sql.planner.ParameterRewriter
 
rewriteResolvedFunctions(Expression, Map<NodeRef<FunctionCall>, ResolvedFunction>) - Static method in class io.prestosql.sql.planner.ResolvedFunctionCallRewriter
 
RewriteSpatialPartitioningAggregation - Class in io.prestosql.sql.planner.iterative.rule
Re-writes spatial_partitioning(geometry) aggregations into spatial_partitioning(envelope, partition_count) on top of ST_Envelope(geometry) projection, e.g.
RewriteSpatialPartitioningAggregation(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.RewriteSpatialPartitioningAggregation
 
rewriteWith(SimplePlanRewriter<C>, PlanNode) - Static method in class io.prestosql.sql.planner.plan.SimplePlanRewriter
 
rewriteWith(SimplePlanRewriter<C>, PlanNode, C) - Static method in class io.prestosql.sql.planner.plan.SimplePlanRewriter
 
rgb(long, long, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
RIGHT - io.prestosql.sql.planner.plan.CorrelatedJoinNode.Type
 
RIGHT - io.prestosql.sql.planner.plan.JoinNode.Type
 
RIGHT - io.prestosql.util.HeapTraversal.Child
 
rightPad(Slice, long, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
rightPad(Slice, long, Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
rightTrim(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
rightTrim(Slice, int[]) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
ROLE_AUTHORIZATION_DESCRIPTORS - io.prestosql.connector.informationschema.InformationSchemaTable
 
ROLES - io.prestosql.connector.informationschema.InformationSchemaTable
 
RollbackTask - Class in io.prestosql.execution
 
RollbackTask() - Constructor for class io.prestosql.execution.RollbackTask
 
ROOT_LOCATION - Static variable in class io.prestosql.execution.scheduler.NetworkLocation
 
round(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
round(double, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
round(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
round(long, int) - Static method in class io.prestosql.type.DateTimes
 
round(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
ROUND_ROBIN - io.prestosql.sql.planner.SystemPartitioningHandle.SystemPartitionFunction
 
roundFloat(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
roundFloat(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
roundInteger(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
roundInteger(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
roundLongLong(long, Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Round
 
roundLongShort(long, Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Round
 
RoundN() - Constructor for class io.prestosql.operator.scalar.MathFunctions.RoundN
 
roundNLong(long, long, Slice, long) - Static method in class io.prestosql.operator.scalar.MathFunctions.RoundN
 
roundNShort(long, long, long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions.RoundN
 
roundNShortLong(long, long, long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions.RoundN
 
roundRobinExchange(PlanNodeId, ExchangeNode.Scope, PlanNode) - Static method in class io.prestosql.sql.planner.plan.ExchangeNode
 
roundShort(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions.Round
 
roundSmallint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
roundSmallint(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
roundTinyint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
roundTinyint(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
roundToEpochMillis(LongTimestampWithTimeZone) - Static method in class io.prestosql.type.DateTimes
 
roundToNearest(long, long) - Static method in class io.prestosql.type.DateTimes
 
row - Variable in class io.prestosql.operator.LookupJoinOperator.SavedRow
A page with exactly one Page.getPositionCount(), representing saved row.
row(Object...) - Method in class io.prestosql.testing.MaterializedResult.Builder
 
ROW - Static variable in class io.prestosql.type.RowParametricType
 
ROW_CONSTRUCTOR - io.prestosql.sql.relational.SpecialForm.Form
 
ROW_COUNT_CHANNEL - Static variable in class io.prestosql.operator.TableWriterOperator
 
ROW_TO_JSON - Static variable in class io.prestosql.operator.scalar.RowToJsonCast
 
ROW_TO_ROW_CAST - Static variable in class io.prestosql.operator.scalar.RowToRowCast
 
RowConstructorCodeGenerator - Class in io.prestosql.sql.gen
 
RowConstructorCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.RowConstructorCodeGenerator
 
rowCount() - Static method in class io.prestosql.sql.planner.plan.Patterns.Values
 
rowEqualsRow(int, Page, int, Page) - Method in interface io.prestosql.operator.PagesHashStrategy
Compares the values in the specified pages.
rowEqualsRow(int, Page, int, Page) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
RowExpression - Class in io.prestosql.sql.relational
 
RowExpression() - Constructor for class io.prestosql.sql.relational.RowExpression
 
RowExpressionCompiler - Class in io.prestosql.sql.gen
 
RowExpressionVisitor<R,​C> - Interface in io.prestosql.sql.relational
 
rowFilter(QualifiedObjectName, String, ViewExpression) - Method in class io.prestosql.testing.TestingAccessControlManager
 
rowNumber() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
RowNumberFunction - Class in io.prestosql.operator.window
 
RowNumberFunction() - Constructor for class io.prestosql.operator.window.RowNumberFunction
 
RowNumberNode - Class in io.prestosql.sql.planner.plan
 
RowNumberNode(PlanNodeId, PlanNode, List<Symbol>, boolean, Symbol, Optional<Integer>, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.RowNumberNode
 
RowNumberOperator - Class in io.prestosql.operator
 
RowNumberOperator(OperatorContext, List<Type>, List<Integer>, List<Integer>, List<Type>, Optional<Integer>, Optional<Integer>, int, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.RowNumberOperator
 
RowNumberOperator.RowNumberOperatorFactory - Class in io.prestosql.operator
 
RowNumberOperatorFactory(int, PlanNodeId, List<? extends Type>, List<Integer>, List<Integer>, List<? extends Type>, Optional<Integer>, Optional<Integer>, int, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.RowNumberOperator.RowNumberOperatorFactory
 
RowNumberStatsRule - Class in io.prestosql.cost
 
RowNumberStatsRule(StatsNormalizer) - Constructor for class io.prestosql.cost.RowNumberStatsRule
 
RowParametricType - Class in io.prestosql.type
 
RowReferencePageManager - Class in io.prestosql.operator
Page buffering manager that enables access to individual rows via stable row IDs.
RowReferencePageManager() - Constructor for class io.prestosql.operator.RowReferencePageManager
 
RowReferencePageManager.LoadCursor - Class in io.prestosql.operator
Cursor that allows callers to advance through the registered page and dictate whether a specific position should be preserved with a stable row ID.
rows() - Static method in class io.prestosql.sql.planner.plan.Patterns.Values
 
rows(Object[][]) - Method in class io.prestosql.testing.MaterializedResult.Builder
 
rows(List<MaterializedRow>) - Method in class io.prestosql.testing.MaterializedResult.Builder
 
RowToJsonCast - Class in io.prestosql.operator.scalar
 
RowToRowCast - Class in io.prestosql.operator.scalar
 
Rule<T> - Interface in io.prestosql.sql.planner.iterative
 
Rule(String) - Constructor for class io.prestosql.server.security.UserMapping.Rule
 
Rule(String, String, boolean, UserMapping.Case) - Constructor for class io.prestosql.server.security.UserMapping.Rule
 
Rule(String, Optional<String>, Optional<Boolean>, Optional<UserMapping.Case>) - Constructor for class io.prestosql.server.security.UserMapping.Rule
 
Rule.Context - Interface in io.prestosql.sql.planner.iterative
 
Rule.Result - Class in io.prestosql.sql.planner.iterative
 
RuleIndex - Class in io.prestosql.sql.planner.iterative
 
RuleIndex.Builder - Class in io.prestosql.sql.planner.iterative
 
rules() - Method in class io.prestosql.sql.planner.iterative.rule.AddExchangesBelowPartialAggregationOverGroupIdRuleSet
 
rules() - Method in class io.prestosql.sql.planner.iterative.rule.DesugarArrayConstructor
 
rules() - Method in class io.prestosql.sql.planner.iterative.rule.DesugarLike
 
rules() - Method in class io.prestosql.sql.planner.iterative.rule.ExpressionRewriteRuleSet
 
rules() - Method in class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins
 
rules() - Static method in class io.prestosql.sql.planner.iterative.rule.GatherAndMergeWindows
 
rules() - Method in class io.prestosql.sql.planner.iterative.rule.SimplifyExpressions
 
RuleStats - Class in io.prestosql.sql.planner.iterative
 
RuleStats() - Constructor for class io.prestosql.sql.planner.iterative.RuleStats
 
RuleStatsRecorder - Class in io.prestosql.sql.planner
 
RuleStatsRecorder() - Constructor for class io.prestosql.sql.planner.RuleStatsRecorder
 
RuleStatsSystemTable - Class in io.prestosql.connector.system
 
RuleStatsSystemTable(Optional<RuleStatsRecorder>, Metadata) - Constructor for class io.prestosql.connector.system.RuleStatsSystemTable
 
run(ManagedQueryExecution) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
RUNNING - io.prestosql.execution.QueryState
Query has at least one running task.
RUNNING - io.prestosql.execution.StageState
Stage is running.
RUNNING - io.prestosql.execution.TaskState
Task is running.
runningIntermediateSplits - Variable in class io.prestosql.execution.executor.TaskHandle
 
runningLeafSplits - Variable in class io.prestosql.execution.executor.TaskHandle
 

S

sample() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
Sample() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Sample
 
SampledSplitSource - Class in io.prestosql.split
 
SampledSplitSource(SplitSource, double) - Constructor for class io.prestosql.split.SampledSplitSource
 
SampleNode - Class in io.prestosql.sql.planner.plan
 
SampleNode(PlanNodeId, PlanNode, double, SampleNode.Type) - Constructor for class io.prestosql.sql.planner.plan.SampleNode
 
SampleNode.Type - Enum in io.prestosql.sql.planner.plan
 
sampleRatio() - Static method in class io.prestosql.sql.planner.plan.Patterns.Sample
 
sampleType() - Static method in class io.prestosql.sql.planner.plan.Patterns.Sample
 
sanitizeName(String) - Static method in class io.prestosql.sql.gen.BytecodeUtils
Replace characters that are not safe to use in a JVM identifier.
sanityCheck() - Method in class io.prestosql.sql.planner.SubPlan
 
saturatedFloorCastToFloat(double) - Static method in class io.prestosql.type.DoubleOperators
 
saturatedFloorCastToInteger(double) - Static method in class io.prestosql.type.DoubleOperators
 
saturatedFloorCastToInteger(long) - Static method in class io.prestosql.type.BigintOperators
 
saturatedFloorCastToSmallint(double) - Static method in class io.prestosql.type.DoubleOperators
 
saturatedFloorCastToSmallint(long) - Static method in class io.prestosql.type.BigintOperators
 
saturatedFloorCastToSmallint(long) - Static method in class io.prestosql.type.IntegerOperators
 
saturatedFloorCastToSmallint(long) - Static method in class io.prestosql.type.RealOperators
 
saturatedFloorCastToTinyint(double) - Static method in class io.prestosql.type.DoubleOperators
 
saturatedFloorCastToTinyint(long) - Static method in class io.prestosql.type.BigintOperators
 
saturatedFloorCastToTinyint(long) - Static method in class io.prestosql.type.IntegerOperators
 
saturatedFloorCastToTinyint(long) - Static method in class io.prestosql.type.RealOperators
 
saturatedFloorCastToTinyint(long) - Static method in class io.prestosql.type.SmallintOperators
 
SavedRow(Page, int, long, boolean, int) - Constructor for class io.prestosql.operator.LookupJoinOperator.SavedRow
 
scalar(Class<?>) - Method in class io.prestosql.metadata.FunctionListBuilder
 
SCALAR - io.prestosql.metadata.FunctionKind
 
ScalarFromAnnotationsParser - Class in io.prestosql.operator.scalar.annotations
 
ScalarFunctionImplementation - Interface in io.prestosql.operator.scalar
 
ScalarHeader - Class in io.prestosql.operator.scalar
 
ScalarHeader(Optional<String>, boolean, boolean) - Constructor for class io.prestosql.operator.scalar.ScalarHeader
 
ScalarImplementationChoice(InvocationConvention.InvocationReturnConvention, List<InvocationConvention.InvocationArgumentConvention>, List<Class<?>>, MethodHandle, Optional<MethodHandle>) - Constructor for class io.prestosql.operator.scalar.ChoicesScalarFunctionImplementation.ScalarImplementationChoice
 
ScalarImplementationDependency - Class in io.prestosql.operator.annotations
 
ScalarImplementationDependency(InvocationConvention, Class<?>) - Constructor for class io.prestosql.operator.annotations.ScalarImplementationDependency
 
ScalarImplementationHeader - Class in io.prestosql.operator.scalar.annotations
 
scalars(Class<?>) - Method in class io.prestosql.metadata.FunctionListBuilder
 
ScalarStatsCalculator - Class in io.prestosql.cost
 
ScalarStatsCalculator(Metadata, TypeAnalyzer) - Constructor for class io.prestosql.cost.ScalarStatsCalculator
 
ScalarValueJsonExtractor() - Constructor for class io.prestosql.operator.scalar.JsonExtract.ScalarValueJsonExtractor
 
SCALE_WRITERS - Static variable in class io.prestosql.SystemSessionProperties
 
SCALED_WRITER_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
ScaledOutputBufferManager - Class in io.prestosql.execution.scheduler
 
ScaledOutputBufferManager(Consumer<OutputBuffers>) - Constructor for class io.prestosql.execution.scheduler.ScaledOutputBufferManager
 
ScaledWriterScheduler - Class in io.prestosql.execution.scheduler
 
ScaledWriterScheduler(SqlStageExecution, Supplier<Collection<TaskStatus>>, Supplier<Collection<TaskStatus>>, NodeSelector, ScheduledExecutorService, DataSize) - Constructor for class io.prestosql.execution.scheduler.ScaledWriterScheduler
 
scaleEpochMicrosToMillis(long) - Static method in class io.prestosql.type.DateTimes
 
scaleEpochMicrosToSeconds(long) - Static method in class io.prestosql.type.DateTimes
 
scaleEpochMillisToMicros(long) - Static method in class io.prestosql.type.DateTimes
 
scaleEpochMillisToSeconds(long) - Static method in class io.prestosql.type.DateTimes
 
scaleFactor(int, int) - Static method in class io.prestosql.type.DateTimes
 
ScanFilterAndProjectOperator - Class in io.prestosql.operator
 
ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory - Class in io.prestosql.operator
 
ScanFilterAndProjectOperatorFactory(int, PlanNodeId, PlanNodeId, PageSourceProvider, Supplier<CursorProcessor>, Supplier<PageProcessor>, TableHandle, Iterable<ColumnHandle>, DynamicFilter, List<Type>, DataSize, int) - Constructor for class io.prestosql.operator.ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory
 
schedule() - Method in class io.prestosql.execution.scheduler.FixedCountScheduler
 
schedule() - Method in class io.prestosql.execution.scheduler.FixedSourcePartitionedScheduler
 
schedule() - Method in class io.prestosql.execution.scheduler.ScaledWriterScheduler
 
schedule() - Method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
 
schedule() - Method in interface io.prestosql.execution.scheduler.SourceScheduler
 
schedule() - Method in interface io.prestosql.execution.scheduler.StageScheduler
Schedules as much work as possible without blocking.
schedule(SourceScheduler) - Method in class io.prestosql.execution.scheduler.group.DynamicLifespanScheduler
 
schedule(SourceScheduler) - Method in class io.prestosql.execution.scheduler.group.FixedLifespanScheduler
 
schedule(SourceScheduler) - Method in interface io.prestosql.execution.scheduler.group.LifespanScheduler
 
SCHEDULED - io.prestosql.execution.StageState
Stage has been scheduled on nodes and ready to execute, but all tasks are still queued.
scheduledNanos - Variable in class io.prestosql.execution.executor.TaskHandle
 
ScheduledSplit - Class in io.prestosql.execution
 
ScheduledSplit(long, PlanNodeId, Split) - Constructor for class io.prestosql.execution.ScheduledSplit
 
scheduleInitial(SourceScheduler) - Method in class io.prestosql.execution.scheduler.group.DynamicLifespanScheduler
 
scheduleInitial(SourceScheduler) - Method in class io.prestosql.execution.scheduler.group.FixedLifespanScheduler
 
scheduleInitial(SourceScheduler) - Method in interface io.prestosql.execution.scheduler.group.LifespanScheduler
 
scheduleOrder(PlanNode) - Static method in class io.prestosql.sql.planner.SchedulingOrderVisitor
 
scheduleRequest() - Method in class io.prestosql.operator.HttpPageBufferClient
 
scheduleRequestIfNecessary() - Method in class io.prestosql.operator.ExchangeClient
 
ScheduleResult - Class in io.prestosql.execution.scheduler
 
ScheduleResult(boolean, Iterable<? extends RemoteTask>, int) - Constructor for class io.prestosql.execution.scheduler.ScheduleResult
 
ScheduleResult(boolean, Iterable<? extends RemoteTask>, ListenableFuture<?>, ScheduleResult.BlockedReason, int) - Constructor for class io.prestosql.execution.scheduler.ScheduleResult
 
ScheduleResult.BlockedReason - Enum in io.prestosql.execution.scheduler
 
scheduleSplits(InternalNode, Multimap<PlanNodeId, Split>, Multimap<PlanNodeId, Lifespan>) - Method in class io.prestosql.execution.SqlStageExecution
 
scheduleTask(InternalNode, int, OptionalInt) - Method in interface io.prestosql.execution.scheduler.FixedCountScheduler.TaskScheduler
 
scheduleTask(InternalNode, int, OptionalInt) - Method in class io.prestosql.execution.SqlStageExecution
 
SCHEDULING - io.prestosql.execution.StageState
Stage tasks are being scheduled on nodes.
SCHEDULING_SPLITS - io.prestosql.execution.StageState
All stage tasks have been scheduled, but splits are still being scheduled.
schedulingComplete() - Method in class io.prestosql.execution.SqlStageExecution
 
schedulingComplete(PlanNodeId) - Method in class io.prestosql.execution.SqlStageExecution
 
SchedulingOrderVisitor - Class in io.prestosql.sql.planner
 
schemaExists(Session, CatalogSchemaName) - Method in interface io.prestosql.metadata.Metadata
 
schemaExists(Session, CatalogSchemaName) - Method in class io.prestosql.metadata.MetadataManager
 
SchemaJdbcTable - Class in io.prestosql.connector.system.jdbc
 
SchemaJdbcTable(Metadata, AccessControl) - Constructor for class io.prestosql.connector.system.jdbc.SchemaJdbcTable
 
SchemaPropertiesSystemTable - Class in io.prestosql.connector.system
 
SchemaPropertiesSystemTable(TransactionManager, Metadata) - Constructor for class io.prestosql.connector.system.SchemaPropertiesSystemTable
 
SchemaPropertyManager - Class in io.prestosql.metadata
 
SchemaPropertyManager() - Constructor for class io.prestosql.metadata.SchemaPropertyManager
 
SCHEMATA - io.prestosql.connector.informationschema.InformationSchemaTable
 
scope() - Static method in class io.prestosql.sql.planner.plan.Patterns.Exchange
 
Scope - Class in io.prestosql.sql.analyzer
 
Scope.AsteriskedIdentifierChainBasis - Class in io.prestosql.sql.analyzer
 
Scope.Builder - Class in io.prestosql.sql.analyzer
 
ScopeAware<T extends Node> - Class in io.prestosql.sql.planner
A wrapper for Expressions that can be used as a key in maps and sets.
scopeAwareKey(T, Analysis, Scope) - Static method in class io.prestosql.sql.planner.ScopeAware
 
ScribeJavaOAuth2Client - Class in io.prestosql.server.security.oauth2
 
ScribeJavaOAuth2Client(OAuth2Config) - Constructor for class io.prestosql.server.security.oauth2.ScribeJavaOAuth2Client
 
searchFrom(PlanNode) - Static method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
searchFrom(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
Use it in optimizer Rule only if you truly do not have a better option
second(long) - Static method in class io.prestosql.operator.scalar.time.TimeFunctions
 
secondFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
SECONDS_PER_DAY - Static variable in class io.prestosql.type.DateTimes
 
SECONDS_PER_MINUTE - Static variable in class io.prestosql.type.DateTimes
 
secondType - Variable in class io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueStateSerializer
 
SecurityConfig - Class in io.prestosql.server.security
 
SecurityConfig() - Constructor for class io.prestosql.server.security.SecurityConfig
 
SecurityContext - Class in io.prestosql.security
 
SecurityContext(TransactionId, Identity, QueryId) - Constructor for class io.prestosql.security.SecurityContext
 
SELECT_COLUMN - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
selectCurrentNode() - Method in interface io.prestosql.execution.scheduler.NodeSelector
 
selectCurrentNode() - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
selectCurrentNode() - Method in class io.prestosql.execution.scheduler.UniformNodeSelector
 
selectDistributionNodes(NodeMap, NodeTaskMap, int, int, Set<Split>, List<RemoteTask>, BucketNodeMap) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
SelectedPositions - Class in io.prestosql.operator.project
 
selectExactNodes(NodeMap, List<HostAddress>, boolean) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
SelectExpression(Expression, Optional<List<Expression>>) - Constructor for class io.prestosql.sql.analyzer.Analysis.SelectExpression
 
selectGroup(SelectionCriteria) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
selectGroup(SelectionCriteria) - Method in class io.prestosql.execution.resourcegroups.NoOpResourceGroupManager
 
selectGroup(SelectionCriteria) - Method in interface io.prestosql.execution.resourcegroups.ResourceGroupManager
 
selectNodes(int, Iterator<InternalNode>) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
selectRandomNodes(int) - Method in interface io.prestosql.execution.scheduler.NodeSelector
 
selectRandomNodes(int, Set<InternalNode>) - Method in interface io.prestosql.execution.scheduler.NodeSelector
 
selectRandomNodes(int, Set<InternalNode>) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
selectRandomNodes(int, Set<InternalNode>) - Method in class io.prestosql.execution.scheduler.UniformNodeSelector
 
semanticException(ErrorCodeSupplier, Node, String, Object...) - Static method in class io.prestosql.sql.analyzer.SemanticExceptions
 
semanticException(ErrorCodeSupplier, Node, Throwable, String, Object...) - Static method in class io.prestosql.sql.analyzer.SemanticExceptions
 
SemanticExceptions - Class in io.prestosql.sql.analyzer
 
semiJoin() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
SemiJoin() - Constructor for class io.prestosql.sql.planner.plan.Patterns.SemiJoin
 
SemiJoinNode - Class in io.prestosql.sql.planner.plan
 
SemiJoinNode(PlanNodeId, PlanNode, PlanNode, Symbol, Symbol, Symbol, Optional<Symbol>, Optional<Symbol>, Optional<SemiJoinNode.DistributionType>, Optional<DynamicFilterId>) - Constructor for class io.prestosql.sql.planner.plan.SemiJoinNode
 
SemiJoinNode.DistributionType - Enum in io.prestosql.sql.planner.plan
 
SemiJoinStatsCalculator - Class in io.prestosql.cost
 
SemiJoinStatsRule - Class in io.prestosql.cost
 
SemiJoinStatsRule() - Constructor for class io.prestosql.cost.SemiJoinStatsRule
 
sendErrorMessage(ContainerRequestContext, Response.Status, String) - Static method in class io.prestosql.server.ServletSecurityUtils
 
sendWwwAuthenticate(ContainerRequestContext, String, Collection<String>) - Static method in class io.prestosql.server.ServletSecurityUtils
 
sequence(long, long, long) - Static method in class io.prestosql.operator.scalar.SequenceFunction
 
sequence(long, long, long) - Static method in class io.prestosql.operator.scalar.timestamp.SequenceIntervalDayToSecond
 
sequence(long, long, long) - Static method in class io.prestosql.operator.scalar.timestamp.SequenceIntervalYearToMonth
 
sequence(ConnectorSession, LongTimestamp, LongTimestamp, long) - Static method in class io.prestosql.operator.scalar.timestamp.SequenceIntervalYearToMonth
 
sequence(LongTimestamp, LongTimestamp, long) - Static method in class io.prestosql.operator.scalar.timestamp.SequenceIntervalDayToSecond
 
sequenceDateDayToSecond(long, long, long) - Static method in class io.prestosql.operator.scalar.SequenceFunction
 
sequenceDateDefaultStep(long, long) - Static method in class io.prestosql.operator.scalar.SequenceFunction
 
sequenceDateYearToMonth(ConnectorSession, long, long, long) - Static method in class io.prestosql.operator.scalar.SequenceFunction
 
sequenceDefaultStep(long, long) - Static method in class io.prestosql.operator.scalar.SequenceFunction
 
SequenceFunction - Class in io.prestosql.operator.scalar
 
SequenceIntervalDayToSecond - Class in io.prestosql.operator.scalar.timestamp
 
SequenceIntervalYearToMonth - Class in io.prestosql.operator.scalar.timestamp
 
serializable() - Method in class io.prestosql.transaction.TransactionBuilder
 
serialize() - Method in class io.prestosql.operator.aggregation.ApproximateMostFrequentHistogram
 
serialize() - Method in class io.prestosql.operator.aggregation.NumericHistogram
 
serialize() - Method in class io.prestosql.type.setdigest.SetDigest
 
serialize(Slice, JsonGenerator, SerializerProvider) - Method in class io.prestosql.server.SliceSerialization.SliceSerializer
 
serialize(PagesSerde.PagesSerdeContext, Page) - Method in class io.prestosql.execution.buffer.PagesSerde
 
serialize(ArrayAggregationState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateSerializer
 
serialize(BigintApproximateMostFrequent.State, BlockBuilder) - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateSerializer
 
serialize(DoubleHistogramAggregation.State, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.DoubleHistogramStateSerializer
 
serialize(HistogramState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.histogram.HistogramStateSerializer
 
serialize(MinMaxByNState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateSerializer
 
serialize(MultimapAggregationState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateSerializer
 
serialize(BlockPositionState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.BlockPositionStateSerializer
 
serialize(BlockState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.BlockStateSerializer
 
serialize(HyperLogLogState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateSerializer
 
serialize(KeyValuePairsState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.KeyValuePairStateSerializer
 
serialize(LongDecimalWithOverflowAndLongState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateSerializer
 
serialize(LongDecimalWithOverflowState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateSerializer
 
serialize(MinMaxNState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateSerializer
 
serialize(NullableBooleanState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.NullableBooleanStateSerializer
 
serialize(NullableDoubleState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.NullableDoubleStateSerializer
 
serialize(NullableLongState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.NullableLongStateSerializer
 
serialize(QuantileDigestAndPercentileState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateSerializer
 
serialize(QuantileDigestState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateSerializer
 
serialize(TDigestAndPercentileArrayState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateSerializer
 
serialize(TDigestAndPercentileState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateSerializer
 
serialize(TDigestState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.TDigestStateSerializer
 
serialize(TriStateBooleanState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.TriStateBooleanStateSerializer
 
serialize(VarcharApproximateMostFrequent.State, BlockBuilder) - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateSerializer
 
serialize(BlockBuilder) - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
serialize(BlockBuilder) - Method in class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
serialize(BlockBuilder) - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
serialize(BlockBuilder) - Method in class io.prestosql.operator.aggregation.KeyValuePairs
 
serialize(BlockBuilder) - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
serialize(Block, JsonGenerator, SerializerProvider) - Method in class io.prestosql.block.BlockJsonSerde.Serializer
 
serialize(Range, JsonGenerator, SerializerProvider) - Method in class io.prestosql.server.RangeJsonSerde.Serializer
 
serialize(ColumnStatisticMetadata, JsonGenerator, SerializerProvider) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.ColumnStatisticMetadataKeySerializer
 
serialize(Expression, JsonGenerator, SerializerProvider) - Method in class io.prestosql.server.ExpressionSerialization.ExpressionSerializer
 
serialize(SetDigestState, BlockBuilder) - Method in class io.prestosql.type.setdigest.SetDigestStateSerializer
 
serialize(K, long, DynamicSliceOutput) - Method in interface io.prestosql.operator.aggregation.ApproximateMostFrequentBucketSerializer
 
serialize(T, BlockBuilder) - Method in class io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueStateSerializer
 
serializeBucket(long, long, DynamicSliceOutput) - Static method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateSerializer
 
serializeBucket(Slice, Long, DynamicSliceOutput) - Static method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateSerializer
 
SERIALIZED_PAGES_MAGIC - Static variable in class io.prestosql.server.PagesResponseWriter
 
SerializedPage - Class in io.prestosql.execution.buffer
 
SerializedPage(Slice, PageCodecMarker.MarkerSet, int, int) - Constructor for class io.prestosql.execution.buffer.SerializedPage
 
Serializer() - Constructor for class io.prestosql.server.RangeJsonSerde.Serializer
 
Serializer(BlockEncodingSerde) - Constructor for class io.prestosql.block.BlockJsonSerde.Serializer
 
serializeSessionProperty(Type, Object) - Static method in class io.prestosql.metadata.SessionPropertyManager
 
Server - Class in io.prestosql.server
 
Server() - Constructor for class io.prestosql.server.Server
 
ServerConfig - Class in io.prestosql.server
 
ServerConfig() - Constructor for class io.prestosql.server.ServerConfig
 
ServerInfoResource - Class in io.prestosql.server
 
ServerInfoResource(NodeVersion, NodeInfo, ServerConfig, GracefulShutdownHandler) - Constructor for class io.prestosql.server.ServerInfoResource
 
ServerMainModule - Class in io.prestosql.server
 
ServerMainModule(String) - Constructor for class io.prestosql.server.ServerMainModule
 
ServerMainModule.ExecutorCleanup - Class in io.prestosql.server
 
ServerSecurityModule - Class in io.prestosql.server.security
 
ServerSecurityModule() - Constructor for class io.prestosql.server.security.ServerSecurityModule
 
ServletSecurityUtils - Class in io.prestosql.server
 
Session - Class in io.prestosql
 
Session(QueryId, Optional<TransactionId>, boolean, Identity, Optional<String>, Optional<String>, Optional<String>, SqlPath, Optional<String>, TimeZoneKey, Locale, Optional<String>, Optional<String>, Optional<String>, Set<String>, Set<String>, ResourceEstimates, Instant, Map<String, String>, Map<CatalogName, Map<String, String>>, Map<String, Map<String, String>>, SessionPropertyManager, Map<String, String>) - Constructor for class io.prestosql.Session
 
SESSION - Static variable in class io.prestosql.testing.TestingConnectorSession
 
Session.ResourceEstimateBuilder - Class in io.prestosql
 
Session.SessionBuilder - Class in io.prestosql
 
SessionContext - Interface in io.prestosql.server
 
SessionFunctions - Class in io.prestosql.operator.scalar
 
SessionPropertyConfigurationManagerContextInstance - Class in io.prestosql.server
 
SessionPropertyConfigurationManagerContextInstance(String) - Constructor for class io.prestosql.server.SessionPropertyConfigurationManagerContextInstance
 
SessionPropertyDefaults - Class in io.prestosql.server
 
SessionPropertyDefaults(NodeInfo) - Constructor for class io.prestosql.server.SessionPropertyDefaults
 
SessionPropertyManager - Class in io.prestosql.metadata
 
SessionPropertyManager() - Constructor for class io.prestosql.metadata.SessionPropertyManager
 
SessionPropertyManager(SystemSessionProperties) - Constructor for class io.prestosql.metadata.SessionPropertyManager
 
SessionPropertyManager(List<PropertyMetadata<?>>) - Constructor for class io.prestosql.metadata.SessionPropertyManager
 
SessionPropertyManager.SessionPropertyValue - Class in io.prestosql.metadata
 
SessionRepresentation - Class in io.prestosql
 
SessionRepresentation(String, Optional<TransactionId>, boolean, String, Set<String>, Optional<String>, Optional<String>, Optional<String>, Optional<String>, SqlPath, Optional<String>, TimeZoneKey, Locale, Optional<String>, Optional<String>, Optional<String>, Set<String>, Set<String>, ResourceEstimates, Instant, Map<String, String>, Map<CatalogName, Map<String, String>>, Map<String, Map<String, String>>, Map<String, SelectedRole>, Map<String, String>) - Constructor for class io.prestosql.SessionRepresentation
 
SessionSupplier - Interface in io.prestosql.server
 
set(byte) - Method in enum io.prestosql.execution.buffer.PageCodecMarker
 
set(ApproximateMostFrequentHistogram<Slice>) - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState
 
set(ApproximateMostFrequentHistogram<Slice>) - Method in class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory.SingleLongApproximateMostFrequentState
 
set(ApproximateMostFrequentHistogram<Slice>) - Method in interface io.prestosql.operator.aggregation.VarcharApproximateMostFrequent.State
 
set(ApproximateMostFrequentHistogram<Long>) - Method in interface io.prestosql.operator.aggregation.BigintApproximateMostFrequent.State
 
set(ApproximateMostFrequentHistogram<Long>) - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState
 
set(ApproximateMostFrequentHistogram<Long>) - Method in class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory.SingleLongApproximateMostFrequentState
 
set(KeyValuePairs) - Method in interface io.prestosql.operator.aggregation.state.KeyValuePairsState
 
set(KeyValuePairs) - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.GroupedState
 
set(KeyValuePairs) - Method in class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.SingleState
 
set(NumericHistogram) - Method in interface io.prestosql.operator.aggregation.DoubleHistogramAggregation.State
 
set(NumericHistogram) - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory.GroupedState
 
set(NumericHistogram) - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory.SingleState
 
set(T) - Method in class io.prestosql.execution.StateMachine
Sets the state.
SET_DIGEST - Static variable in class io.prestosql.type.setdigest.SetDigestType
 
SET_SESSION - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
SET_USER - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
setAccessControlFiles(String) - Method in class io.prestosql.security.AccessControlConfig
 
setAccessControlFiles(List<File>) - Method in class io.prestosql.security.AccessControlConfig
 
setAcknowledgePages(boolean) - Method in class io.prestosql.operator.ExchangeClientConfig
 
setAdditionalModule(Module) - Method in class io.prestosql.server.testing.TestingPrestoServer.Builder
 
setAddressProtocol(SubnetBasedTopology.AddressProtocol) - Method in class io.prestosql.execution.scheduler.SubnetTopologyConfig
 
setAddWarnings(boolean) - Method in class io.prestosql.testing.TestingWarningCollectorConfig
 
setAggregates(QuerySpecification, List<FunctionCall>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setAggregationOperatorUnspillMemoryLimit(DataSize) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setAllTasksFinal(Iterable<TaskInfo>) - Method in class io.prestosql.execution.StageStateMachine
 
setAnalyzeTarget(TableHandle) - Method in class io.prestosql.sql.analyzer.Analysis
 
setArguments(List<Type>, List<Expression>) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
setAuthenticatedIdentity(ContainerRequestContext, Identity) - Static method in class io.prestosql.server.ServletSecurityUtils
 
setAuthenticatedIdentity(ContainerRequestContext, String) - Static method in class io.prestosql.server.ServletSecurityUtils
 
setAuthentication(String) - Method in class io.prestosql.server.ui.WebUiAuthenticationConfig
 
setAuthenticationTypes(String) - Method in class io.prestosql.server.security.SecurityConfig
 
setAuthenticationTypes(List<String>) - Method in class io.prestosql.server.security.SecurityConfig
 
setAuthenticator(PasswordAuthenticator) - Method in class io.prestosql.server.security.PasswordAuthenticatorManager
 
setAuthUrl(String) - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
setAverageRowSize(double) - Method in class io.prestosql.cost.SymbolStatsEstimate.Builder
 
setBaseDataDir(Optional<Path>) - Method in class io.prestosql.server.testing.TestingPrestoServer.Builder
 
setBlock(Block) - Method in interface io.prestosql.operator.aggregation.state.BlockPositionState
 
setBlock(Block) - Method in interface io.prestosql.operator.aggregation.state.BlockState
 
setBoolean(boolean) - Method in interface io.prestosql.operator.aggregation.state.NullableBooleanState
 
SetBuilderOperator - Class in io.prestosql.operator
 
SetBuilderOperator(OperatorContext, SetBuilderOperator.SetSupplier, int, Optional<Integer>, int, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.SetBuilderOperator
 
SetBuilderOperator.SetBuilderOperatorFactory - Class in io.prestosql.operator
 
SetBuilderOperator.SetSupplier - Class in io.prestosql.operator
 
SetBuilderOperatorFactory(int, PlanNodeId, Type, int, Optional<Integer>, int, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.SetBuilderOperator.SetBuilderOperatorFactory
 
setByte(byte) - Method in interface io.prestosql.operator.aggregation.state.BooleanDistinctState
 
setByte(byte) - Method in interface io.prestosql.operator.aggregation.state.TriStateBooleanState
 
setC2(double) - Method in interface io.prestosql.operator.aggregation.state.CovarianceState
 
setCatalog(String) - Method in class io.prestosql.Session.SessionBuilder
 
setCatalogConfigurationDir(File) - Method in class io.prestosql.metadata.StaticCatalogStoreConfig
 
setCatalogSessionProperty(String, String, String) - Method in class io.prestosql.Session.SessionBuilder
Sets a catalog property for the session.
setChallengeTimeout(Duration) - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
setCidrPrefixLengths(String) - Method in class io.prestosql.execution.scheduler.SubnetTopologyConfig
 
setClientCapabilities(Set<String>) - Method in class io.prestosql.Session.SessionBuilder
 
setClientId(String) - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
setClientInfo(String) - Method in class io.prestosql.Session.SessionBuilder
 
setClientSecret(String) - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
setClientTags(Set<String>) - Method in class io.prestosql.Session.SessionBuilder
 
setClientThreads(int) - Method in class io.prestosql.operator.ExchangeClientConfig
 
setClientTimeout(Duration) - Method in class io.prestosql.execution.QueryManagerConfig
 
setClientTimeout(Duration) - Method in class io.prestosql.execution.TaskManagerConfig
 
setClientTransactionSupport() - Method in class io.prestosql.Session.SessionBuilder
 
setCollectPlanStatisticsForAllQueries(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setColocatedJoinsEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setColumn(Field, ColumnHandle) - Method in class io.prestosql.sql.analyzer.Analysis
 
setColumnComment(Session, TableHandle, ColumnHandle, Optional<String>) - Method in interface io.prestosql.metadata.Metadata
Comments to the specified column.
setColumnComment(Session, TableHandle, ColumnHandle, Optional<String>) - Method in class io.prestosql.metadata.MetadataManager
 
setColumns(List<String>, List<Type>) - Method in class io.prestosql.execution.QueryStateMachine.QueryOutputManager
 
setColumns(List<String>, List<Type>) - Method in class io.prestosql.execution.QueryStateMachine
 
setConcurrentLifespansPerTask(int) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setConcurrentRequestMultiplier(int) - Method in class io.prestosql.operator.ExchangeClientConfig
 
setConfigurationManager(String, Map<String, String>) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
setConfigurationManager(String, Map<String, String>) - Method in class io.prestosql.server.SessionPropertyDefaults
 
setContext(TaskContext) - Method in class io.prestosql.operator.index.IndexLoader
 
setCoordinator(boolean) - Method in class io.prestosql.server.ServerConfig
 
setCoordinator(boolean) - Method in class io.prestosql.server.testing.TestingPrestoServer.Builder
 
setCount(long) - Method in interface io.prestosql.operator.aggregation.state.CentralMomentsState
 
setCount(long) - Method in interface io.prestosql.operator.aggregation.state.CovarianceState
 
setCount(long) - Method in interface io.prestosql.operator.aggregation.state.VarianceState
 
setCpuCostWeight(double) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setCpuQuotaGenerationMillisPerSecond(long) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setCpuTime(Duration) - Method in class io.prestosql.Session.ResourceEstimateBuilder
 
setCreate(Analysis.Create) - Method in class io.prestosql.sql.analyzer.Analysis
 
setDefaultCatalog(String) - Method in class io.prestosql.sql.SqlEnvironmentConfig
 
setDefaultFilterFactorEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setDefaultSchema(String) - Method in class io.prestosql.sql.SqlEnvironmentConfig
 
setDictionaryAggregation(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setDigest(QuantileDigest) - Method in interface io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileState
 
setDigest(QuantileDigest) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.GroupedQuantileDigestAndPercentileState
 
setDigest(QuantileDigest) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.SingleQuantileDigestAndPercentileState
 
setDigest(TDigest) - Method in interface io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayState
 
setDigest(TDigest) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.GroupedTDigestAndPercentileArrayState
 
setDigest(TDigest) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.SingleTDigestAndPercentileArrayState
 
setDigest(TDigest) - Method in interface io.prestosql.operator.aggregation.state.TDigestAndPercentileState
 
setDigest(TDigest) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.GroupedTDigestAndPercentileState
 
setDigest(TDigest) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.SingleTDigestAndPercentileState
 
setDigest(SetDigest) - Method in interface io.prestosql.type.setdigest.SetDigestState
 
setDigest(SetDigest) - Method in class io.prestosql.type.setdigest.SetDigestStateFactory.GroupedSetDigestState
 
setDigest(SetDigest) - Method in class io.prestosql.type.setdigest.SetDigestStateFactory.SingleSetDigestState
 
SetDigest - Class in io.prestosql.type.setdigest
For the MinHash algorithm, see "On the resemblance and containment of documents" by Andrei Z.
SetDigest() - Constructor for class io.prestosql.type.setdigest.SetDigest
 
SetDigest(int, int) - Constructor for class io.prestosql.type.setdigest.SetDigest
 
SetDigest(int, HyperLogLog, Long2ShortSortedMap) - Constructor for class io.prestosql.type.setdigest.SetDigest
 
SetDigestFunctions - Class in io.prestosql.type.setdigest
 
SetDigestOperators - Class in io.prestosql.type.setdigest
 
SetDigestState - Interface in io.prestosql.type.setdigest
 
SetDigestStateFactory - Class in io.prestosql.type.setdigest
 
SetDigestStateFactory() - Constructor for class io.prestosql.type.setdigest.SetDigestStateFactory
 
SetDigestStateFactory.GroupedSetDigestState - Class in io.prestosql.type.setdigest
 
SetDigestStateFactory.SingleSetDigestState - Class in io.prestosql.type.setdigest
 
SetDigestStateSerializer - Class in io.prestosql.type.setdigest
 
SetDigestStateSerializer() - Constructor for class io.prestosql.type.setdigest.SetDigestStateSerializer
 
SetDigestType - Class in io.prestosql.type.setdigest
 
setDisabledCatalogs(String) - Method in class io.prestosql.metadata.StaticCatalogStoreConfig
 
setDisabledCatalogs(List<String>) - Method in class io.prestosql.metadata.StaticCatalogStoreConfig
 
setDiscoveryUri(URI) - Method in class io.prestosql.server.testing.TestingPrestoServer.Builder
 
setDistinct(boolean) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
setDistinctValuesCount(double) - Method in class io.prestosql.cost.SymbolStatsEstimate.Builder
 
setDistributedIndexJoinsEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setDistributedSortEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setDomainBase(String) - Method in class io.prestosql.server.JmxNamingConfig
 
setDouble(double) - Method in interface io.prestosql.operator.aggregation.state.DoubleState
 
setDouble(double) - Method in interface io.prestosql.operator.aggregation.state.LongAndDoubleState
 
setDouble(double) - Method in interface io.prestosql.operator.aggregation.state.NullableDoubleState
 
setDynamicFiltersStatsSupplier(Supplier<DynamicFilterService.DynamicFiltersStats>) - Method in class io.prestosql.execution.QueryStateMachine
 
setDynamicScheduleForGroupedExecutionEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setEnabled(boolean) - Method in class io.prestosql.failuredetector.FailureDetectorConfig
 
setEnabled(boolean) - Method in class io.prestosql.server.EmbeddedDiscoveryConfig
 
setEnabled(boolean) - Method in class io.prestosql.server.ui.WebUiConfig
 
setEnableDynamicFiltering(boolean) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setEnableForcedExchangeBelowGroupId(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setEnableIntermediateAggregations(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setEnableLargeDynamicFilters(boolean) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setEnableStatsCalculator(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setEnvironment(String) - Method in class io.prestosql.server.testing.TestingPrestoServer.Builder
 
setEventListenerFiles(String) - Method in class io.prestosql.eventlistener.EventListenerConfig
 
setEventListenerFiles(List<File>) - Method in class io.prestosql.eventlistener.EventListenerConfig
 
setExchangeCompressionEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setExchangeDataIntegrityVerification(FeaturesConfig.DataIntegrityVerification) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setExecutionTime(Duration) - Method in class io.prestosql.Session.ResourceEstimateBuilder
 
setExpandableBaseScope(Node, Scope) - Method in class io.prestosql.sql.analyzer.Analysis
 
setExpirationGraceInterval(Duration) - Method in class io.prestosql.failuredetector.FailureDetectorConfig
 
setExpressionCacheSize(int) - Method in class io.prestosql.sql.planner.CompilerConfig
 
setExpressionType(Expression, Type) - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
setFailureRatioThreshold(double) - Method in class io.prestosql.failuredetector.FailureDetectorConfig
 
setFilter(Expression) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
setFilter(Optional<Expression>) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
setFilterAndProjectMinOutputPageRowCount(int) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setFilterAndProjectMinOutputPageSize(DataSize) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setFirst(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanAndBlockPositionValueState
 
setFirst(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanBooleanState
 
setFirst(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanDoubleState
 
setFirst(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanLongState
 
setFirst(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleAndBlockPositionValueState
 
setFirst(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleBooleanState
 
setFirst(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleDoubleState
 
setFirst(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleLongState
 
setFirst(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.LongAndBlockPositionValueState
 
setFirst(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.LongBooleanState
 
setFirst(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.LongDoubleState
 
setFirst(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.LongLongState
 
setFirst(Object) - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectAndBlockPositionValueState
 
setFirst(Object) - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectBooleanState
 
setFirst(Object) - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectDoubleState
 
setFirst(Object) - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectLongState
 
setFirstNull(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.TwoNullableValueState
 
setFixedManagementUser(String) - Method in class io.prestosql.server.security.SecurityConfig
 
setFixedManagementUserForHttps(boolean) - Method in class io.prestosql.server.security.SecurityConfig
 
setForcedSessionTimeZone(String) - Method in class io.prestosql.sql.SqlEnvironmentConfig
 
setForceSingleNodeOutput(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setGracePeriod(Duration) - Method in class io.prestosql.server.ServerConfig
 
setGroupedExecutionEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setGroupId(long) - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
setGroupId(long) - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
setGroupId(long) - Method in class io.prestosql.operator.aggregation.state.AbstractGroupedAccumulatorState
 
setGroupId(long) - Method in class io.prestosql.type.setdigest.SetDigestStateFactory.GroupedSetDigestState
 
setGroupingOperations(QuerySpecification, List<GroupingOperation>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setGroupingSets(QuerySpecification, Analysis.GroupingSetAnalysis) - Method in class io.prestosql.sql.analyzer.Analysis
 
setHardConcurrencyLimit(int) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setHardCpuLimit(Duration) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setHaving(QuerySpecification, Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
setHeapHeadroom(DataSize) - Method in class io.prestosql.memory.NodeMemoryConfig
 
setHeartbeatInterval(Duration) - Method in class io.prestosql.failuredetector.FailureDetectorConfig
 
setHighValue(double) - Method in class io.prestosql.cost.SymbolStatsEstimate.Builder
 
setHttp2Enabled(boolean) - Method in class io.prestosql.server.InternalCommunicationConfig
 
setHttpResponseThreads(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setHttpsRequired(boolean) - Method in class io.prestosql.server.InternalCommunicationConfig
 
setHttpTimeoutThreads(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setHyperLogLog(HyperLogLog) - Method in interface io.prestosql.operator.aggregation.state.HyperLogLogState
 
setHyperLogLog(HyperLogLog) - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.GroupedHyperLogLogState
 
setHyperLogLog(HyperLogLog) - Method in class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.SingleHyperLogLogState
 
setIdentity(ConnectorIdentity) - Method in class io.prestosql.testing.TestingConnectorSession.Builder
 
setIdentity(Identity) - Method in class io.prestosql.Session.SessionBuilder
 
setIdleCheckInterval(Duration) - Method in class io.prestosql.transaction.TransactionManagerConfig
 
setIdleTimeout(Duration) - Method in class io.prestosql.transaction.TransactionManagerConfig
 
setIf(T, Predicate<T>) - Method in class io.prestosql.execution.StateMachine
Sets the state if the current state satisfies the specified predicate.
setIgnoreDownstreamPreferences(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setIgnoreStatsCalculatorFailures(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setImplicitFromScope(QuerySpecification, Scope) - Method in class io.prestosql.sql.analyzer.Analysis
 
setIncludeCoordinator(boolean) - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
setIncludeExceptionInResponse(boolean) - Method in class io.prestosql.server.ServerConfig
 
setInfoMaxAge(Duration) - Method in class io.prestosql.execution.TaskManagerConfig
 
setInfoSupplier(Supplier<OperatorInfo>) - Method in class io.prestosql.operator.OperatorContext
 
setInfoUpdateInterval(Duration) - Method in class io.prestosql.execution.TaskManagerConfig
 
setInitialHashPartitions(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setInitialSplitsPerNode(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setInputs(List<Input>) - Method in class io.prestosql.execution.QueryStateMachine
 
setInsecureAuthenticationOverHttpAllowed(boolean) - Method in class io.prestosql.server.security.SecurityConfig
 
setInsert(Analysis.Insert) - Method in class io.prestosql.sql.analyzer.Analysis
 
setInstalledPluginsDir(File) - Method in class io.prestosql.server.PluginManagerConfig
 
setIterativeOptimizerTimeout(Duration) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setIterativeRuleBasedColumnPruning(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setJmxExport(boolean) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setJoinCriteria(Join, Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
setJoinDistributionType(FeaturesConfig.JoinDistributionType) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setJoinMaxBroadcastTableSize(DataSize) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setJoinReorderingStrategy(FeaturesConfig.JoinReorderingStrategy) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setJoinUsing(Join, Analysis.JoinUsingAnalysis) - Method in class io.prestosql.sql.analyzer.Analysis
 
setJwksUrl(String) - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
setKerberosConfig(File) - Method in class io.prestosql.server.security.KerberosConfig
 
setKeyFile(String) - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
setKeyStorePassword(String) - Method in class io.prestosql.server.InternalCommunicationConfig
 
setKeyStorePath(String) - Method in class io.prestosql.server.InternalCommunicationConfig
 
setKeytab(File) - Method in class io.prestosql.server.security.KerberosConfig
 
setKillOnOutOfMemoryDelay(Duration) - Method in class io.prestosql.memory.MemoryManagerConfig
 
setLargeBroadcastMaxDistinctValuesPerDriver(int) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setLargeBroadcastMaxSizePerDriver(DataSize) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setLargeBroadcastRangeRowLimitPerDriver(int) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setLargePartitionedMaxDistinctValuesPerDriver(int) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setLargePartitionedMaxSizePerDriver(DataSize) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setLargePartitionedRangeRowLimitPerDriver(int) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setLateMaterializationEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setLevelTimeMultiplier(BigDecimal) - Method in class io.prestosql.execution.TaskManagerConfig
 
setLimit(Node, long) - Method in class io.prestosql.sql.analyzer.Analysis
 
setLimit(Node, OptionalLong) - Method in class io.prestosql.sql.analyzer.Analysis
 
setLocale(Locale) - Method in class io.prestosql.Session.SessionBuilder
 
setLocation(NodeLocation) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
setLocationSegmentNames(String) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig
 
setLocationSegmentNames(List<String>) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig
 
setLong(long) - Method in interface io.prestosql.operator.aggregation.state.LongAndDoubleState
 
setLong(long) - Method in interface io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongState
 
setLong(long) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.GroupedLongDecimalWithOverflowAndLongState
 
setLong(long) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.SingleLongDecimalWithOverflowAndLongState
 
setLong(long) - Method in interface io.prestosql.operator.aggregation.state.LongState
 
setLong(long) - Method in interface io.prestosql.operator.aggregation.state.NullableLongState
 
setLongDecimal(Slice) - Method in interface io.prestosql.operator.aggregation.state.LongDecimalWithOverflowState
 
setLongDecimal(Slice) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
setLongDecimal(Slice) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
setLowMemoryKillerPolicy(MemoryManagerConfig.LowMemoryKillerPolicy) - Method in class io.prestosql.memory.MemoryManagerConfig
 
setLowValue(double) - Method in class io.prestosql.cost.SymbolStatsEstimate.Builder
 
setM1(double) - Method in interface io.prestosql.operator.aggregation.state.CentralMomentsState
 
setM2(double) - Method in interface io.prestosql.operator.aggregation.state.CentralMomentsState
 
setM2(double) - Method in interface io.prestosql.operator.aggregation.state.VarianceState
 
setM2X(double) - Method in interface io.prestosql.operator.aggregation.state.CorrelationState
 
setM2X(double) - Method in interface io.prestosql.operator.aggregation.state.RegressionState
 
setM2Y(double) - Method in interface io.prestosql.operator.aggregation.state.CorrelationState
 
setM3(double) - Method in interface io.prestosql.operator.aggregation.state.CentralMomentsState
 
setM4(double) - Method in interface io.prestosql.operator.aggregation.state.CentralMomentsState
 
setMavenLocalRepository(String) - Method in class io.prestosql.server.PluginManagerConfig
 
setMavenRemoteRepository(String) - Method in class io.prestosql.server.PluginManagerConfig
 
setMavenRemoteRepository(List<String>) - Method in class io.prestosql.server.PluginManagerConfig
 
setMaxBufferSize(DataSize) - Method in class io.prestosql.operator.ExchangeClientConfig
 
setMaxConcurrentQueries(int) - Method in class io.prestosql.execution.QueryManagerConfig
Deprecated.
setMaxDriversPerTask(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setMaxErrorDuration(Duration) - Method in class io.prestosql.operator.ExchangeClientConfig
 
setMaxFinishingConcurrency(int) - Method in class io.prestosql.transaction.TransactionManagerConfig
 
setMaxGroupingSets(int) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setMaxIndexMemoryUsage(DataSize) - Method in class io.prestosql.execution.TaskManagerConfig
 
setMaxLocalExchangeBufferSize(DataSize) - Method in class io.prestosql.execution.TaskManagerConfig
 
setMaxOutputStageJsonSize(DataSize) - Method in class io.prestosql.event.QueryMonitorConfig
 
setMaxPagePartitioningBufferSize(DataSize) - Method in class io.prestosql.execution.TaskManagerConfig
 
setMaxPartialAggregationMemoryUsage(DataSize) - Method in class io.prestosql.execution.TaskManagerConfig
 
setMaxPendingSplitsPerTask(int) - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
setMaxQueryHistory(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setMaxQueryLength(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setMaxQueryMemory(DataSize) - Method in class io.prestosql.memory.MemoryManagerConfig
 
setMaxQueryMemoryPerNode(DataSize) - Method in class io.prestosql.memory.NodeMemoryConfig
 
setMaxQueryTotalMemory(DataSize) - Method in class io.prestosql.memory.MemoryManagerConfig
 
setMaxQueryTotalMemoryPerNode(DataSize) - Method in class io.prestosql.memory.NodeMemoryConfig
 
setMaxQueuedQueries(int) - Method in class io.prestosql.execution.QueryManagerConfig
Deprecated.
setMaxQueuedQueries(int) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setMaxRecursionDepth(int) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setMaxReorderedJoins(int) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setMaxResponseSize(DataSize) - Method in class io.prestosql.operator.ExchangeClientConfig
 
setMaxSpillPerNode(DataSize) - Method in class io.prestosql.spiller.NodeSpillConfig
 
setMaxSpillSize(DataSize) - Method in class io.prestosql.testing.TestingTaskContext.Builder
 
setMaxSplitsPerNode(int) - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
setMaxStageCount(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setMaxTotalMemory(long) - Method in class io.prestosql.memory.QueryContext
 
setMaxUserMemory(long) - Method in class io.prestosql.memory.QueryContext
 
setMaxWarnings(int) - Method in class io.prestosql.execution.warnings.WarningCollectorConfig
 
setMaxWorkerThreads(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setMean(double) - Method in interface io.prestosql.operator.aggregation.state.VarianceState
 
setMeanX(double) - Method in interface io.prestosql.operator.aggregation.state.CovarianceState
 
setMeanY(double) - Method in interface io.prestosql.operator.aggregation.state.CovarianceState
 
setMemoryCostWeight(double) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setMemoryPool(MemoryPool) - Method in class io.prestosql.memory.QueryContext
 
setMemoryPool(VersionedMemoryPoolId) - Method in class io.prestosql.execution.DataDefinitionExecution
 
setMemoryPool(VersionedMemoryPoolId) - Method in interface io.prestosql.execution.QueryExecution
 
setMemoryPool(VersionedMemoryPoolId) - Method in class io.prestosql.execution.QueryStateMachine
 
setMemoryPool(VersionedMemoryPoolId) - Method in class io.prestosql.execution.SqlQueryExecution
 
setMemoryPoolSize(DataSize) - Method in class io.prestosql.testing.TestingTaskContext.Builder
 
setMemoryRevocationRequestListener(Runnable) - Method in class io.prestosql.operator.OperatorContext
 
setMemoryRevokingTarget(double) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setMemoryRevokingThreshold(double) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setMinCandidates(int) - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
setMinDrivers(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setMinDriversPerTask(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setMinErrorDuration(Duration) - Method in class io.prestosql.operator.ExchangeClientConfig
Deprecated.
setMinQueryExpireAge(Duration) - Method in class io.prestosql.execution.QueryManagerConfig
 
setMinScheduleSplitBatchSize(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setName(QualifiedName) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
setNameType(KerberosNameType) - Method in class io.prestosql.server.security.KerberosConfig
 
setNestedOperatorStatsSupplier(Supplier<List<OperatorStats>>) - Method in class io.prestosql.operator.OperatorContext
 
setNetworkCostWeight(double) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setNetworkTopologyFile(File) - Method in class io.prestosql.execution.scheduler.TopologyFileConfig
 
setNodeSchedulerPolicy(String) - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
setNoMorePages() - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
setNoMorePages() - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
setNoMorePages() - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
setNoMorePages() - Method in interface io.prestosql.execution.buffer.OutputBuffer
Notify buffer that no more pages will be added.
setNoMorePages() - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
setNull(boolean) - Method in interface io.prestosql.operator.aggregation.state.NullableBooleanState
 
setNull(boolean) - Method in interface io.prestosql.operator.aggregation.state.NullableDoubleState
 
setNull(boolean) - Method in interface io.prestosql.operator.aggregation.state.NullableLongState
 
setNullsFraction(double) - Method in class io.prestosql.cost.SymbolStatsEstimate.Builder
 
setOffset(Offset, long) - Method in class io.prestosql.sql.analyzer.Analysis
 
setOmitDateTimeTypePrecision(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
SetOperationNode - Class in io.prestosql.sql.planner.plan
 
SetOperationNode(PlanNodeId, List<PlanNode>, ListMultimap<Symbol, Symbol>, List<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.SetOperationNode
 
SetOperationNodeTranslator - Class in io.prestosql.sql.planner.iterative.rule
 
SetOperationNodeTranslator(Metadata, SymbolAllocator, PlanNodeIdAllocator) - Constructor for class io.prestosql.sql.planner.iterative.rule.SetOperationNodeTranslator
 
SetOperationNodeTranslator.TranslationResult - Class in io.prestosql.sql.planner.iterative.rule
 
setOptimizedLocalScheduling(boolean) - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
setOptimizeHashGeneration(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setOptimizeMetadataQueries(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setOptimizeMixedDistinctAggregations(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setOptimizeTopNRowNumber(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setOrderBy(OrderBy) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
setOrderBy(Optional<OrderBy>) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
setOrderByAggregates(OrderBy, List<Expression>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setOrderByExpressions(Node, List<Expression>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setOrderByWindowFunctions(OrderBy, List<FunctionCall>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setOutput(Optional<Output>) - Method in class io.prestosql.execution.QueryStateMachine
 
setOutputBuffers(OutputBuffers) - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
setOutputBuffers(OutputBuffers) - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
setOutputBuffers(OutputBuffers) - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
setOutputBuffers(OutputBuffers) - Method in interface io.prestosql.execution.buffer.OutputBuffer
Updates the buffer configuration.
setOutputBuffers(OutputBuffers) - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
setOutputBuffers(OutputBuffers) - Method in interface io.prestosql.execution.RemoteTask
 
setOutputBuffers(OutputBuffers) - Method in class io.prestosql.execution.SqlStageExecution
 
setOutputBuffers(OutputBuffers) - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
setOutputPartial() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
setOutputRowCount(double) - Method in class io.prestosql.cost.PlanNodeStatsEstimate.Builder
 
setOverflow(long) - Method in interface io.prestosql.operator.aggregation.state.LongDecimalWithOverflowState
 
setOverflow(long) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
setOverflow(long) - Method in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
setPageBufferClientMaxCallbackThreads(int) - Method in class io.prestosql.operator.ExchangeClientConfig
 
setPages(NestedLoopJoinPages) - Method in interface io.prestosql.operator.NestedLoopJoinBridge
 
setPages(NestedLoopJoinPages) - Method in class io.prestosql.operator.NestedLoopJoinPagesSupplier
 
setPagesIndexEagerCompactionEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setPageSource(Supplier<Optional<UpdatablePageSource>>) - Method in class io.prestosql.operator.DeleteOperator
 
setParseDecimalLiteralsAsDouble(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setPartitionedSplitCount(int) - Method in class io.prestosql.execution.NodeTaskMap.PartitionedSplitCountTracker
 
setPartitionSpilledLookupSourceHandle(int, SpilledLookupSourceHandle) - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
setPath(SqlPath) - Method in class io.prestosql.Session.SessionBuilder
 
setPath(String) - Method in class io.prestosql.sql.SqlEnvironmentConfig
 
SetPathTask - Class in io.prestosql.execution
 
SetPathTask() - Constructor for class io.prestosql.execution.SetPathTask
 
setPeakMemory(DataSize) - Method in class io.prestosql.Session.ResourceEstimateBuilder
 
setPercentile(double) - Method in interface io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileState
 
setPercentile(double) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.GroupedQuantileDigestAndPercentileState
 
setPercentile(double) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.SingleQuantileDigestAndPercentileState
 
setPercentile(double) - Method in interface io.prestosql.operator.aggregation.state.TDigestAndPercentileState
 
setPercentile(double) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.GroupedTDigestAndPercentileState
 
setPercentile(double) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.SingleTDigestAndPercentileState
 
setPercentiles(List<Double>) - Method in interface io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayState
 
setPercentiles(List<Double>) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.GroupedTDigestAndPercentileArrayState
 
setPercentiles(List<Double>) - Method in class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.SingleTDigestAndPercentileArrayState
 
setPerOperatorCpuTimerEnabled(boolean) - Method in class io.prestosql.execution.TaskManagerConfig
 
setPlugins(String) - Method in class io.prestosql.server.PluginManagerConfig
 
setPlugins(List<String>) - Method in class io.prestosql.server.PluginManagerConfig
 
setPosition(int) - Method in interface io.prestosql.operator.aggregation.state.BlockPositionState
 
setPredicatePushdownUseTableProperties(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setPreferPartialAggregation(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setPreloadedWarnings(int) - Method in class io.prestosql.testing.TestingWarningCollectorConfig
 
setPrincipalHostname(String) - Method in class io.prestosql.server.security.KerberosConfig
 
setProperties(Map<String, String>) - Method in class io.prestosql.server.testing.TestingPrestoServer.Builder
 
setPropertyMetadata(List<PropertyMetadata<?>>) - Method in class io.prestosql.testing.TestingConnectorSession.Builder
 
setPropertyValues(Map<String, Object>) - Method in class io.prestosql.testing.TestingConnectorSession.Builder
 
setPushAggregationThroughOuterJoin(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setPushPartialAggregationThoughJoin(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setPushTableWriteThroughUnion(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setQuantileDigest(QuantileDigest) - Method in interface io.prestosql.operator.aggregation.state.QuantileDigestState
 
setQuantileDigest(QuantileDigest) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.GroupedQuantileDigestState
 
setQuantileDigest(QuantileDigest) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.SingleQuantileDigestState
 
setQueryExecutionPolicy(String) - Method in class io.prestosql.execution.QueryManagerConfig
 
setQueryId(QueryId) - Method in class io.prestosql.Session.SessionBuilder
 
setQueryId(QueryId) - Method in class io.prestosql.testing.TestingTaskContext.Builder
 
setQueryManagerExecutorPoolSize(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setQueryMaxCpuTime(Duration) - Method in class io.prestosql.execution.QueryManagerConfig
 
setQueryMaxExecutionTime(Duration) - Method in class io.prestosql.execution.QueryManagerConfig
 
setQueryMaxMemory(DataSize) - Method in class io.prestosql.testing.TestingTaskContext.Builder
 
setQueryMaxRunTime(Duration) - Method in class io.prestosql.execution.QueryManagerConfig
 
setQueryMaxScanPhysicalBytes(DataSize) - Method in class io.prestosql.execution.QueryManagerConfig
 
setQueryMaxSpillPerNode(DataSize) - Method in class io.prestosql.spiller.NodeSpillConfig
 
setQueryMaxSpillSize(DataSize) - Method in class io.prestosql.testing.TestingTaskContext.Builder
 
setQueryResultsCompressionEnabled(boolean) - Method in class io.prestosql.server.ServerConfig
 
setRe2JDfaRetries(int) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setRe2JDfaStatesLimit(int) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setReady() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
setRedistributeWrites(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setReferencedTables(List<TableInfo>) - Method in class io.prestosql.execution.QueryStateMachine
 
setRefreshMaterializedView(Analysis.RefreshMaterializedViewAnalysis) - Method in class io.prestosql.sql.analyzer.Analysis
 
setRefreshPeriod(Duration) - Method in class io.prestosql.execution.scheduler.TopologyFileConfig
 
setRegexLibrary(RegexLibrary) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setRemoteTaskMaxCallbackThreads(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setRemoteTaskMaxErrorDuration(Duration) - Method in class io.prestosql.execution.QueryManagerConfig
 
setRemoteTaskMinErrorDuration(Duration) - Method in class io.prestosql.execution.QueryManagerConfig
Deprecated.
setRemoteUserAddress(String) - Method in class io.prestosql.Session.SessionBuilder
 
setRequired() - Method in class io.prestosql.server.security.CertificateAuthenticatorManager
 
setRequired() - Method in class io.prestosql.server.security.PasswordAuthenticatorManager
 
setRequiredAudience(String) - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
setRequiredIssuer(String) - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
setRequiredWorkers(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setRequiredWorkersMaxWait(Duration) - Method in class io.prestosql.execution.QueryManagerConfig
 
setReservedPoolDisabled(boolean) - Method in class io.prestosql.memory.NodeMemoryConfig
Deprecated.
setReservedPoolEnabled(boolean) - Method in class io.prestosql.memory.NodeMemoryConfig
Deprecated.
setResourceEstimates(ResourceEstimates) - Method in class io.prestosql.Session.SessionBuilder
 
setResourceOvercommit() - Method in class io.prestosql.memory.QueryContext
 
setRewriteFilteringSemiJoinToInnerJoin(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
SetRoleTask - Class in io.prestosql.execution
 
SetRoleTask() - Constructor for class io.prestosql.execution.SetRoleTask
 
setRoutines(List<RoutineInfo>) - Method in class io.prestosql.execution.QueryStateMachine
 
setRowIdField(Table, FieldReference) - Method in class io.prestosql.sql.analyzer.Analysis
 
setSampleRatio(SampledRelation, double) - Method in class io.prestosql.sql.analyzer.Analysis
 
setScaleWriters(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setScheduleSplitBatchSize(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setSchedulingPolicy(SchedulingPolicy) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setSchedulingWeight(int) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setSchema(String) - Method in class io.prestosql.Session.SessionBuilder
 
setSchemaAuthorization(Session, CatalogSchemaName, PrestoPrincipal) - Method in interface io.prestosql.metadata.Metadata
Set the specified schema's user/role.
setSchemaAuthorization(Session, CatalogSchemaName, PrestoPrincipal) - Method in class io.prestosql.metadata.MetadataManager
 
SetSchemaAuthorizationTask - Class in io.prestosql.execution
 
SetSchemaAuthorizationTask() - Constructor for class io.prestosql.execution.SetSchemaAuthorizationTask
 
setScope(Node, Scope) - Method in class io.prestosql.sql.analyzer.Analysis
 
setSecond(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanBooleanState
 
setSecond(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleBooleanState
 
setSecond(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.LongBooleanState
 
setSecond(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectBooleanState
 
setSecond(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanDoubleState
 
setSecond(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleDoubleState
 
setSecond(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.LongDoubleState
 
setSecond(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectDoubleState
 
setSecond(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanLongState
 
setSecond(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleLongState
 
setSecond(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.LongLongState
 
setSecond(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.ObjectLongState
 
setSecondBlock(Block) - Method in interface io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueState
 
setSecondNull(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.TwoNullableValueState
 
setSecondPosition(int) - Method in interface io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueState
 
setSelectAllResultFields(AllColumns, List<Field>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setSelectExpressions(Node, List<Analysis.SelectExpression>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setServiceName(String) - Method in class io.prestosql.server.security.KerberosConfig
 
setServiceThreadCount(int) - Method in class io.prestosql.execution.DynamicFilterConfig
 
SetSessionTask - Class in io.prestosql.execution
 
SetSessionTask() - Constructor for class io.prestosql.execution.SetSessionTask
 
setSessionTimeout(Duration) - Method in class io.prestosql.server.ui.FormWebUiConfig
 
setSetCatalog(String) - Method in class io.prestosql.execution.QueryStateMachine
 
setSetPath(String) - Method in class io.prestosql.execution.QueryStateMachine
 
setSetSchema(String) - Method in class io.prestosql.execution.QueryStateMachine
 
setSharedSecret(String) - Method in class io.prestosql.server.InternalCommunicationConfig
 
setSharedSecret(String) - Method in class io.prestosql.server.ui.FormWebUiConfig
 
setShareIndexLoading(boolean) - Method in class io.prestosql.execution.TaskManagerConfig
 
setSinkMaxBroadcastBufferSize(DataSize) - Method in class io.prestosql.execution.TaskManagerConfig
 
setSinkMaxBufferSize(DataSize) - Method in class io.prestosql.execution.TaskManagerConfig
 
setSkipMaterializedViewRefresh(boolean) - Method in class io.prestosql.sql.analyzer.Analysis
 
setSkipRedundantSort(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setSlice(Slice) - Method in interface io.prestosql.operator.aggregation.state.SliceState
 
setSmallBroadcastMaxDistinctValuesPerDriver(int) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setSmallBroadcastMaxSizePerDriver(DataSize) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setSmallBroadcastRangeRowLimitPerDriver(int) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setSmallPartitionedMaxDistinctValuesPerDriver(int) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setSmallPartitionedMaxSizePerDriver(DataSize) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setSmallPartitionedRangeRowLimitPerDriver(int) - Method in class io.prestosql.execution.DynamicFilterConfig
 
setSoftConcurrencyLimit(int) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setSoftCpuLimit(Duration) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setSoftMemoryLimitBytes(long) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setSource(String) - Method in class io.prestosql.Session.SessionBuilder
 
setSpatialJoinsEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setSpillCompressionEnabled(boolean) - Method in class io.prestosql.spiller.NodeSpillConfig
 
setSpillEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setSpillEncryptionEnabled(boolean) - Method in class io.prestosql.spiller.NodeSpillConfig
 
setSpillerSpillPaths(String) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setSpillerThreads(int) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setSpillMaxUsedSpaceThreshold(double) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setSpillOrderBy(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setSpillWindowOperator(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setSplitConcurrencyAdjustmentInterval(Duration) - Method in class io.prestosql.execution.TaskManagerConfig
 
setStageCountWarningThreshold(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setStart(Instant) - Method in class io.prestosql.Session.SessionBuilder
 
setStart(Instant) - Method in class io.prestosql.testing.TestingConnectorSession.Builder
 
setStartedTransactionId(TransactionId) - Method in class io.prestosql.execution.QueryStateMachine
 
setStateKey(String) - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
setStatisticsCpuTimerEnabled(boolean) - Method in class io.prestosql.execution.TaskManagerConfig
 
setStatisticsRange(StatisticRange) - Method in class io.prestosql.cost.SymbolStatsEstimate.Builder
 
setStatusRefreshMaxWait(Duration) - Method in class io.prestosql.execution.TaskManagerConfig
 
SetSupplier(Type) - Constructor for class io.prestosql.operator.SetBuilderOperator.SetSupplier
 
setSystemAccessControl(String, Map<String, String>) - Method in class io.prestosql.security.AccessControlManager
 
setSystemAccessControls(List<SystemAccessControl>) - Method in class io.prestosql.security.AccessControlManager
 
setSystemAccessControls(List<SystemAccessControl>) - Method in class io.prestosql.server.testing.TestingPrestoServer.Builder
 
setSystemProperties(Map<String, String>) - Method in class io.prestosql.Session.SessionBuilder
Sets system properties, discarding any system properties previously set.
setSystemProperty(String, String) - Method in class io.prestosql.Session.SessionBuilder
Sets a system property for the session.
setTableAuthorization(Session, CatalogSchemaTableName, PrestoPrincipal) - Method in interface io.prestosql.metadata.Metadata
Set the authorization (owner) of specified table's user/role
setTableAuthorization(Session, CatalogSchemaTableName, PrestoPrincipal) - Method in class io.prestosql.metadata.MetadataManager
 
SetTableAuthorizationTask - Class in io.prestosql.execution
 
SetTableAuthorizationTask() - Constructor for class io.prestosql.execution.SetTableAuthorizationTask
 
setTableComment(Session, TableHandle, Optional<String>) - Method in interface io.prestosql.metadata.Metadata
Comments to the specified table.
setTableComment(Session, TableHandle, Optional<String>) - Method in class io.prestosql.metadata.MetadataManager
 
setTaskConcurrency(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setTaskContext(TaskContext) - Method in class io.prestosql.operator.index.IndexLookupSourceFactory
 
setTaskContext(TaskContext) - Method in interface io.prestosql.operator.LookupSourceFactory
 
setTaskCpuTimerEnabled(boolean) - Method in class io.prestosql.execution.TaskManagerConfig
 
setTaskNotificationThreads(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setTaskStateMachine(TaskStateMachine) - Method in class io.prestosql.testing.TestingTaskContext.Builder
 
setTaskYieldThreads(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setTDigest(TDigest) - Method in interface io.prestosql.operator.aggregation.state.TDigestState
 
setTDigest(TDigest) - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory.GroupedTDigestState
 
setTDigest(TDigest) - Method in class io.prestosql.operator.aggregation.state.TDigestStateFactory.SingleTDigestState
 
setTimeZoneKey(TimeZoneKey) - Method in class io.prestosql.Session.SessionBuilder
 
setTimeZoneKey(TimeZoneKey) - Method in class io.prestosql.testing.TestingConnectorSession.Builder
 
setTokenUrl(String) - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
setTraceToken(Optional<String>) - Method in class io.prestosql.Session.SessionBuilder
 
setTransactionId(TransactionId) - Method in class io.prestosql.Session.SessionBuilder
 
setTrustStorePassword(String) - Method in class io.prestosql.server.InternalCommunicationConfig
 
setTrustStorePath(String) - Method in class io.prestosql.server.InternalCommunicationConfig
 
setType(TopologyAwareNodeSelectorConfig.TopologyType) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig
 
setTypedHeap(TypedHeap) - Method in interface io.prestosql.operator.aggregation.state.MinMaxNState
 
setTypedHeap(TypedHeap) - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.GroupedMinMaxNState
 
setTypedHeap(TypedHeap) - Method in class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.SingleMinMaxNState
 
setTypedKeyValueHeap(TypedKeyValueHeap) - Method in interface io.prestosql.operator.aggregation.minmaxby.MinMaxByNState
 
setTypedKeyValueHeap(TypedKeyValueHeap) - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.GroupedMinMaxByNState
 
setTypedKeyValueHeap(TypedKeyValueHeap) - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.SingleMinMaxByNState
 
setUnnest(Unnest, Analysis.UnnestAnalysis) - Method in class io.prestosql.sql.analyzer.Analysis
 
setUnwrapCasts(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setup(Binder) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorModule
 
setup(Binder) - Method in class io.prestosql.server.CoordinatorModule
 
setup(Binder) - Method in class io.prestosql.server.GracefulShutdownModule
 
setup(Binder) - Method in class io.prestosql.server.InternalCommunicationModule
 
setup(Binder) - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorSupportModule
 
setup(Binder) - Method in class io.prestosql.server.security.oauth2.OAuth2ServiceModule
 
setup(Binder) - Method in class io.prestosql.server.security.ServerSecurityModule
 
setup(Binder) - Method in class io.prestosql.server.ServerMainModule
 
setup(Binder) - Method in class io.prestosql.server.ui.OAuth2WebUiModule
 
setup(Binder) - Method in class io.prestosql.server.ui.WebUiAuthenticationModule
 
setup(Binder) - Method in class io.prestosql.server.ui.WebUiModule
 
setUpdateType(String) - Method in class io.prestosql.execution.QueryStateMachine
 
setUpdateType(String, QualifiedObjectName, Optional<Table>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setUseMarkDistinct(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setUsePreferredWritePartitioning(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setUserAgent(String) - Method in class io.prestosql.Session.SessionBuilder
 
setUserGroups(Map<String, Set<String>>) - Method in class io.prestosql.testing.TestingGroupProvider
 
setUserMappingFile(File) - Method in class io.prestosql.server.security.CertificateConfig
 
setUserMappingFile(File) - Method in class io.prestosql.server.security.InsecureAuthenticatorConfig
 
setUserMappingFile(File) - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
setUserMappingFile(File) - Method in class io.prestosql.server.security.KerberosConfig
 
setUserMappingFile(File) - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
setUserMappingFile(File) - Method in class io.prestosql.server.security.PasswordAuthenticatorConfig
 
setUserMappingPattern(String) - Method in class io.prestosql.server.security.CertificateConfig
 
setUserMappingPattern(String) - Method in class io.prestosql.server.security.InsecureAuthenticatorConfig
 
setUserMappingPattern(String) - Method in class io.prestosql.server.security.jwt.JwtAuthenticatorConfig
 
setUserMappingPattern(String) - Method in class io.prestosql.server.security.KerberosConfig
 
setUserMappingPattern(String) - Method in class io.prestosql.server.security.oauth2.OAuth2Config
 
setUserMappingPattern(String) - Method in class io.prestosql.server.security.PasswordAuthenticatorConfig
 
setUsername(String) - Method in class io.prestosql.server.ui.FixedUserWebUiConfig
 
setVariableArity(boolean) - Method in class io.prestosql.metadata.SignatureBuilder
 
setViewAuthorization(Session, CatalogSchemaTableName, PrestoPrincipal) - Method in interface io.prestosql.metadata.Metadata
Set the authorization (owner) of specified view's user/role
setViewAuthorization(Session, CatalogSchemaTableName, PrestoPrincipal) - Method in class io.prestosql.metadata.MetadataManager
 
SetViewAuthorizationTask - Class in io.prestosql.execution
 
SetViewAuthorizationTask() - Constructor for class io.prestosql.execution.SetViewAuthorizationTask
 
setWarmupInterval(Duration) - Method in class io.prestosql.failuredetector.FailureDetectorConfig
 
setWhere(Node, Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
setWindow(Window) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
setWindow(Optional<Window>) - Method in class io.prestosql.sql.planner.FunctionCallBuilder
 
setWindowFunctions(QuerySpecification, List<FunctionCall>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setWithDelay(long, ScheduledExecutorService) - Method in class io.prestosql.operator.DriverYieldSignal
 
setWriterCount(int) - Method in class io.prestosql.execution.TaskManagerConfig
 
setWriterMinSize(DataSize) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
sha1(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
sha256(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
sha512(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
shiftKeys(long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
Shifts left entries with the specified hash code, starting at the specified position, and empties the resulting free entry.
shiftKeys(long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Shifts left entries with the specified hash code, starting at the specified position, and empties the resulting free entry.
shortDecimalToBigint(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
shortDecimalToBoolean(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
shortDecimalToDouble(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
shortDecimalToGenericIntegerType(long, int, long, long) - Static method in class io.prestosql.type.DecimalSaturatedFloorCasts
 
shortDecimalToInteger(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
shortDecimalToJson(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
shortDecimalToLongDecimal(long, int, int, int, int) - Static method in class io.prestosql.type.DecimalSaturatedFloorCasts
 
shortDecimalToReal(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
shortDecimalToShortDecimal(long, int, int, int, int) - Static method in class io.prestosql.type.DecimalSaturatedFloorCasts
 
shortDecimalToSmallint(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
shortDecimalToTinyint(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
shortDecimalToVarchar(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
shortPrecision(long, long, Slice) - Static method in class io.prestosql.operator.scalar.timestamp.WithTimeZone
 
shortTime(long, ConnectorSession, Long) - Static method in class io.prestosql.operator.scalar.timetz.CurrentTime
 
shortTimestamp(long, ConnectorSession, Long) - Static method in class io.prestosql.operator.scalar.timestamptz.CurrentTimestamp
 
shortToLong(long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimestampCast
 
shortToLong(long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimestampCast
 
shortToLong(long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimestampWithTimeZoneCast
 
shortToLong(long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimeWithTimeZoneCast
 
shortToLong(long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToTimeWithTimeZoneCast
 
shortToLong(long, long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimestampWithTimeZoneCast
 
shortToLong(long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimeWithTimeZoneToTimestampCast
 
shortToLong(long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToTimestampWithTimeZoneCast
 
shortToLong(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimeWithTimeZoneCast
 
shortToShort(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimestampCast
 
shortToShort(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimeWithTimeZoneCast
 
shortToShort(long, long, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimestampCast
 
shortToShort(long, long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneToTimestampWithTimeZoneCast
 
shortToShort(long, long, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToTimeWithTimeZoneCast
 
shortToShort(long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimestampWithTimeZoneCast
 
shortToShort(long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampToTimeWithTimeZoneCast
 
shortToShort(long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimeWithTimeZoneToTimestampCast
 
shortToShort(long, ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneToTimestampWithTimeZoneCast
 
shouldWaitForMinWorkers() - Method in class io.prestosql.execution.DataDefinitionExecution
 
shouldWaitForMinWorkers() - Method in interface io.prestosql.execution.QueryExecution
 
shouldWaitForMinWorkers() - Method in class io.prestosql.execution.SqlQueryExecution
 
SHOW_COLUMNS - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
SHOW_CREATE_TABLE - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
ShowStatsRewrite - Class in io.prestosql.sql.rewrite
 
ShowStatsRewrite() - Constructor for class io.prestosql.sql.rewrite.ShowStatsRewrite
 
shuffle(Type, Block) - Method in class io.prestosql.operator.scalar.ArrayShuffleFunction
 
shutdown() - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
shutdown() - Method in class io.prestosql.dispatcher.DispatchExecutor
 
shutdown() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector
 
shutdown() - Method in class io.prestosql.server.CoordinatorModule.ExecutorCleanup
 
shutdown() - Method in class io.prestosql.server.security.KerberosAuthenticator
 
shutdown() - Method in class io.prestosql.server.ServerMainModule.ExecutorCleanup
 
ShutdownAction - Interface in io.prestosql.server
 
shutdownNow() - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
SHUTTING_DOWN - io.prestosql.metadata.NodeState
 
sign(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
sign(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
signature(Signature) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
Signature - Class in io.prestosql.metadata
 
Signature(String, TypeSignature, TypeSignature...) - Constructor for class io.prestosql.metadata.Signature
 
Signature(String, TypeSignature, List<TypeSignature>) - Constructor for class io.prestosql.metadata.Signature
 
Signature(String, List<TypeVariableConstraint>, List<LongVariableConstraint>, TypeSignature, List<TypeSignature>, boolean) - Constructor for class io.prestosql.metadata.Signature
 
SIGNATURE - Static variable in class io.prestosql.type.DecimalToDecimalCasts
 
SignatureBinder - Class in io.prestosql.metadata
Determines whether, and how, a callsite matches a generic function signature.
SignatureBinder.RelationshipType - Enum in io.prestosql.metadata
 
SignatureBuilder - Class in io.prestosql.metadata
 
SignatureBuilder() - Constructor for class io.prestosql.metadata.SignatureBuilder
 
signDecimalLong(Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Sign
 
signDecimalShort(long) - Static method in class io.prestosql.operator.scalar.MathFunctions.Sign
 
signFloat(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
signInteger(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
signSmallint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
signTinyint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
SimpleChannelComparator - Class in io.prestosql.operator
 
SimpleChannelComparator(int, int, BlockTypeOperators.BlockPositionComparison) - Constructor for class io.prestosql.operator.SimpleChannelComparator
 
SimpleFilterProjectSemiJoinStatsRule - Class in io.prestosql.cost
It is not yet proven whether this heuristic is any better or worse.
SimpleFilterProjectSemiJoinStatsRule(Metadata, StatsNormalizer, FilterStatsCalculator) - Constructor for class io.prestosql.cost.SimpleFilterProjectSemiJoinStatsRule
 
SimpleHttpResponseCallback<T> - Interface in io.prestosql.server.remotetask
 
SimpleHttpResponseHandler<T> - Class in io.prestosql.server.remotetask
 
SimpleHttpResponseHandler(SimpleHttpResponseCallback<T>, URI, RemoteTaskStats) - Constructor for class io.prestosql.server.remotetask.SimpleHttpResponseHandler
 
SimplePagesHashStrategy - Class in io.prestosql.operator
 
SimplePagesHashStrategy(List<Type>, List<Integer>, List<List<Block>>, List<Integer>, OptionalInt, Optional<Integer>, BlockTypeOperators) - Constructor for class io.prestosql.operator.SimplePagesHashStrategy
 
SimplePagesIndexComparator - Class in io.prestosql.operator
 
SimplePagesIndexComparator(List<Type>, List<Integer>, List<SortOrder>, TypeOperators) - Constructor for class io.prestosql.operator.SimplePagesIndexComparator
 
SimplePageWithPositionComparator - Class in io.prestosql.operator
 
SimplePageWithPositionComparator(List<Type>, List<Integer>, List<SortOrder>, TypeOperators) - Constructor for class io.prestosql.operator.SimplePageWithPositionComparator
 
SimplePlanRewriter<C> - Class in io.prestosql.sql.planner.plan
 
SimplePlanRewriter() - Constructor for class io.prestosql.sql.planner.plan.SimplePlanRewriter
 
SimplePlanRewriter.RewriteContext<C> - Class in io.prestosql.sql.planner.plan
 
SimplePlanVisitor<C> - Class in io.prestosql.sql.planner
 
SimplePlanVisitor() - Constructor for class io.prestosql.sql.planner.SimplePlanVisitor
 
SimpleStatsRule<T extends PlanNode> - Class in io.prestosql.cost
 
SimpleStatsRule(StatsNormalizer) - Constructor for class io.prestosql.cost.SimpleStatsRule
 
SimplifyCountOverConstant - Class in io.prestosql.sql.planner.iterative.rule
 
SimplifyCountOverConstant(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.SimplifyCountOverConstant
 
SimplifyExpressions - Class in io.prestosql.sql.planner.iterative.rule
 
SimplifyExpressions(Metadata, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.SimplifyExpressions
 
sin(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
SINGLE - io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties.StreamDistribution
 
SINGLE - io.prestosql.sql.planner.plan.AggregationNode.Step
 
SINGLE - io.prestosql.sql.planner.plan.TopNNode.Step
 
SINGLE - io.prestosql.sql.planner.SystemPartitioningHandle.SystemPartitionFunction
 
SINGLE_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
SingleArrayAggregationState - Class in io.prestosql.operator.aggregation.arrayagg
 
SingleArrayAggregationState(Type) - Constructor for class io.prestosql.operator.aggregation.arrayagg.SingleArrayAggregationState
 
SingleDistinctAggregationToGroupBy - Class in io.prestosql.sql.planner.iterative.rule
Implements distinct aggregations with similar inputs by transforming plans of the following shape:
SingleDistinctAggregationToGroupBy() - Constructor for class io.prestosql.sql.planner.iterative.rule.SingleDistinctAggregationToGroupBy
 
singleGroupingSet(List<Symbol>) - Static method in class io.prestosql.sql.planner.plan.AggregationNode
 
SingleHistogramState - Class in io.prestosql.operator.aggregation.histogram
 
SingleHistogramState(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, int) - Constructor for class io.prestosql.operator.aggregation.histogram.SingleHistogramState
 
SingleHyperLogLogState() - Constructor for class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.SingleHyperLogLogState
 
SingleLongApproximateMostFrequentState() - Constructor for class io.prestosql.operator.aggregation.LongApproximateMostFrequentStateFactory.SingleLongApproximateMostFrequentState
 
SingleLongApproximateMostFrequentState() - Constructor for class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory.SingleLongApproximateMostFrequentState
 
SingleLongDecimalWithOverflowAndLongState() - Constructor for class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.SingleLongDecimalWithOverflowAndLongState
 
SingleLongDecimalWithOverflowState() - Constructor for class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
SingleMinMaxByNState() - Constructor for class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.SingleMinMaxByNState
 
SingleMinMaxNState() - Constructor for class io.prestosql.operator.aggregation.state.MinMaxNStateFactory.SingleMinMaxNState
 
SingleMultimapAggregationState - Class in io.prestosql.operator.aggregation.multimapagg
 
SingleMultimapAggregationState(Type, Type) - Constructor for class io.prestosql.operator.aggregation.multimapagg.SingleMultimapAggregationState
 
SingleQuantileDigestAndPercentileState() - Constructor for class io.prestosql.operator.aggregation.state.QuantileDigestAndPercentileStateFactory.SingleQuantileDigestAndPercentileState
 
SingleQuantileDigestState() - Constructor for class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.SingleQuantileDigestState
 
SingleSetDigestState() - Constructor for class io.prestosql.type.setdigest.SetDigestStateFactory.SingleSetDigestState
 
SingleState() - Constructor for class io.prestosql.operator.aggregation.NumericHistogramStateFactory.SingleState
 
SingleState(Type, Type) - Constructor for class io.prestosql.operator.aggregation.state.KeyValuePairsStateFactory.SingleState
 
singleStatement() - Method in class io.prestosql.transaction.TransactionBuilder
 
singleStream() - Static method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
singleStreamPartition() - Static method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
SingleStreamSpiller - Interface in io.prestosql.spiller
 
SingleStreamSpillerFactory - Interface in io.prestosql.spiller
 
SingleTDigestAndPercentileArrayState() - Constructor for class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory.SingleTDigestAndPercentileArrayState
 
SingleTDigestAndPercentileState() - Constructor for class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory.SingleTDigestAndPercentileState
 
SingleTDigestState() - Constructor for class io.prestosql.operator.aggregation.state.TDigestStateFactory.SingleTDigestState
 
SingleTypedHistogram - Class in io.prestosql.operator.aggregation.histogram
 
SingleTypedHistogram(Block, Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, int) - Constructor for class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
SingleTypedHistogram(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, int) - Constructor for class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
size - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
Number of entries in the set (including the key zero, if present).
size - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Number of entries in the set (including the key zero, if present).
size() - Method in class io.prestosql.execution.buffer.BufferResult
 
size() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
size() - Method in class io.prestosql.execution.resourcegroups.IndexedPriorityQueue
 
size() - Method in class io.prestosql.operator.aggregation.TypedSet
 
size() - Method in class io.prestosql.operator.ArrayPositionLinks.FactoryBuilder
 
size() - Method in class io.prestosql.operator.ChannelSet.ChannelSetBuilder
 
size() - Method in class io.prestosql.operator.ChannelSet
 
size() - Method in interface io.prestosql.operator.PositionLinks.FactoryBuilder
 
size() - Method in class io.prestosql.operator.project.InputChannels
 
size() - Method in class io.prestosql.operator.project.SelectedPositions
 
size() - Method in class io.prestosql.operator.SortedPositionLinks.FactoryBuilder
 
size() - Method in class io.prestosql.operator.window.PagesWindowIndex
 
size() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
size() - Method in class io.prestosql.sql.planner.plan.Assignments
 
size() - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
size() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
 
size() - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
 
SIZE - Static variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.SingleLongDecimalWithOverflowAndLongState
 
SIZE - Static variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
sizeOf() - Method in class io.prestosql.operator.GroupedTopNRowNumberAccumulator
 
sizeOf() - Method in class io.prestosql.operator.IdRegistry
Does not include the sizes of the referenced objects themselves.
sizeOf() - Method in class io.prestosql.operator.RowReferencePageManager
 
sizeOf() - Method in class io.prestosql.util.HeapTraversal
 
sizeOf() - Method in class io.prestosql.util.Long2LongOpenBigHashMap
Returns the size of this hash map in bytes.
sizeOf() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
 
sizeOf() - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Returns the size of this hash map in bytes.
skewness(CentralMomentsState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.CentralMomentsAggregation
 
SKIP_REDUNDANT_SORT - Static variable in class io.prestosql.SystemSessionProperties
 
slice(Type, Block, long, long) - Static method in class io.prestosql.operator.scalar.ArraySliceFunction
 
SliceDeserializer() - Constructor for class io.prestosql.server.SliceSerialization.SliceDeserializer
 
sliceElementAt(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayElementAtFunction
 
SliceSerialization - Class in io.prestosql.server
 
SliceSerialization.SliceDeserializer - Class in io.prestosql.server
 
SliceSerialization.SliceSerializer - Class in io.prestosql.server
 
SliceSerializer() - Constructor for class io.prestosql.server.SliceSerialization.SliceSerializer
 
SliceState - Interface in io.prestosql.operator.aggregation.state
 
sliceSubscript(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
Slug - Class in io.prestosql.server.protocol
 
Slug.Context - Enum in io.prestosql.server.protocol
 
SMALLINT_TO_DECIMAL_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
SMALLINT_TO_DECIMAL_SATURATED_FLOOR_CAST - Static variable in class io.prestosql.type.DecimalSaturatedFloorCasts
 
SmallintOperators - Class in io.prestosql.type
 
smallintToLongDecimal(long, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
smallintToShortDecimal(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
sort() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
sort(PagesIndex, int, int) - Method in class io.prestosql.operator.PagesIndexOrdering
 
sort(BlockTypeOperators.BlockPositionComparison, Type, Block) - Method in class io.prestosql.operator.scalar.ArraySortFunction
 
sort(List<Type>, List<Page>, List<Integer>, List<SortOrder>, int) - Method in class io.prestosql.PagesIndexPageSorter
 
sort(List<Integer>, List<SortOrder>) - Method in class io.prestosql.operator.PagesIndex
 
sort(List<Integer>, List<SortOrder>, int, int) - Method in class io.prestosql.operator.PagesIndex
 
sortableIntToFloat(int) - Static method in class io.prestosql.operator.aggregation.FloatingPointBitsConverterUtil
Coverts a sortable int to float.
sortableLongToDouble(long) - Static method in class io.prestosql.operator.aggregation.FloatingPointBitsConverterUtil
Converts a sortable long to double.
sortBoolean(Type, Block, ArraySortComparatorFunction.ComparatorBooleanLambda) - Method in class io.prestosql.operator.scalar.ArraySortComparatorFunction
 
sortDouble(Type, Block, ArraySortComparatorFunction.ComparatorDoubleLambda) - Method in class io.prestosql.operator.scalar.ArraySortComparatorFunction
 
SortedPositionLinks - Class in io.prestosql.operator
Maintains position links in sorted order by build side expression.
SortedPositionLinks.FactoryBuilder - Class in io.prestosql.operator
 
SortExpressionContext - Class in io.prestosql.sql.planner
 
SortExpressionContext(Expression, List<Expression>) - Constructor for class io.prestosql.sql.planner.SortExpressionContext
 
SortExpressionExtractor - Class in io.prestosql.sql.planner
Extracts sort expression to be used for creating SortedPositionLinks from join filter expression.
sortItemToSortOrder(SortItem) - Static method in class io.prestosql.sql.planner.OrderingScheme
 
sortLong(Type, Block, ArraySortComparatorFunction.ComparatorLongLambda) - Method in class io.prestosql.operator.scalar.ArraySortComparatorFunction
 
SortNode - Class in io.prestosql.sql.planner.plan
 
SortNode(PlanNodeId, PlanNode, OrderingScheme, boolean) - Constructor for class io.prestosql.sql.planner.plan.SortNode
 
sortObject(Type, Block, ArraySortComparatorFunction.ComparatorObjectLambda) - Method in class io.prestosql.operator.scalar.ArraySortComparatorFunction
 
SortStatsRule - Class in io.prestosql.cost
 
SortStatsRule() - Constructor for class io.prestosql.cost.SortStatsRule
 
source() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
SOURCE_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
SOURCE_OUTER - io.prestosql.sql.planner.plan.IndexJoinNode.Type
 
SourceOperator - Interface in io.prestosql.operator
 
SourceOperatorFactory - Interface in io.prestosql.operator
 
sourceOutputLayout(int) - Method in class io.prestosql.sql.planner.plan.SetOperationNode
 
SourcePartitionedScheduler - Class in io.prestosql.execution.scheduler
 
sources() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
SourceScheduler - Interface in io.prestosql.execution.scheduler
 
sourceSymbolMap(int) - Method in class io.prestosql.sql.planner.plan.SetOperationNode
Returns the output to input symbol mapping for the given source channel
spaceTrimmedLength(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
SPATIAL_JOIN - Static variable in class io.prestosql.SystemSessionProperties
 
SPATIAL_PARTITIONING_TABLE_NAME - Static variable in class io.prestosql.SystemSessionProperties
 
SpatialIndexBuilderOperator - Class in io.prestosql.operator
 
SpatialIndexBuilderOperator.SpatialIndexBuilderOperatorFactory - Class in io.prestosql.operator
 
SpatialIndexBuilderOperator.SpatialPredicate - Interface in io.prestosql.operator
 
SpatialIndexBuilderOperatorFactory(int, PlanNodeId, List<Type>, List<Integer>, int, Optional<Integer>, Optional<Integer>, SpatialIndexBuilderOperator.SpatialPredicate, Optional<String>, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, int, PagesIndex.Factory) - Constructor for class io.prestosql.operator.SpatialIndexBuilderOperator.SpatialIndexBuilderOperatorFactory
 
spatialJoin() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
SpatialJoinNode - Class in io.prestosql.sql.planner.plan
 
SpatialJoinNode(PlanNodeId, SpatialJoinNode.Type, PlanNode, PlanNode, List<Symbol>, Expression, Optional<Symbol>, Optional<Symbol>, Optional<String>) - Constructor for class io.prestosql.sql.planner.plan.SpatialJoinNode
 
SpatialJoinNode.DistributionType - Enum in io.prestosql.sql.planner.plan
 
SpatialJoinNode.Type - Enum in io.prestosql.sql.planner.plan
 
SpatialJoinOperator - Class in io.prestosql.operator
 
SpatialJoinOperator(OperatorContext, SpatialJoinNode.Type, List<Type>, List<Integer>, int, Optional<Integer>, PagesSpatialIndexFactory, Runnable) - Constructor for class io.prestosql.operator.SpatialJoinOperator
 
SpatialJoinOperator.SpatialJoinOperatorFactory - Class in io.prestosql.operator
 
SpatialJoinOperatorFactory(int, PlanNodeId, SpatialJoinNode.Type, List<Type>, List<Integer>, int, Optional<Integer>, PagesSpatialIndexFactory) - Constructor for class io.prestosql.operator.SpatialJoinOperator.SpatialJoinOperatorFactory
 
SpatialJoinStatsRule - Class in io.prestosql.cost
 
SpatialJoinStatsRule(FilterStatsCalculator, StatsNormalizer) - Constructor for class io.prestosql.cost.SpatialJoinStatsRule
 
SpatialJoinUtils - Class in io.prestosql.util
 
SpecialForm - Class in io.prestosql.sql.relational
 
SpecialForm(SpecialForm.Form, Type, RowExpression...) - Constructor for class io.prestosql.sql.relational.SpecialForm
 
SpecialForm(SpecialForm.Form, Type, List<RowExpression>) - Constructor for class io.prestosql.sql.relational.SpecialForm
 
SpecialForm(SpecialForm.Form, Type, List<RowExpression>, List<ResolvedFunction>) - Constructor for class io.prestosql.sql.relational.SpecialForm
 
SpecialForm.Form - Enum in io.prestosql.sql.relational
 
specialize(FunctionBinding) - Method in class io.prestosql.metadata.LiteralFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.metadata.SqlAggregationFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.metadata.SqlScalarFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.CountColumn
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.DecimalSumAggregation
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.histogram.Histogram
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.MapAggregationFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.MapUnionAggregation
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ApplyFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ArrayConcatFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ArrayConstructor
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ArrayFlattenFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ArrayReduceFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ArrayToElementConcatFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ArrayToJsonCast
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ArrayTransformFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.CastFromUnknownOperator
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ConcatFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ConcatWsFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ElementToArrayConcatFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.GenericComparisonOperator
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.GenericDistinctFromOperator
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.GenericEqualOperator
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.GenericHashCodeOperator
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.GenericIndeterminateOperator
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.GenericLessThanOperator
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.GenericLessThanOrEqualOperator
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.GenericXxHash64Operator
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.IdentityCast
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.InvokeFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.JsonStringToArrayCast
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.JsonStringToMapCast
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.JsonStringToRowCast
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.JsonToArrayCast
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.JsonToMapCast
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.JsonToRowCast
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.MapConcatFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.MapFilterFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.MapToJsonCast
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.MapTransformKeysFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.MapTransformValuesFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.MapZipWithFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.Re2JCastToRegexpFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.RowToJsonCast
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ZipFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.scalar.ZipWithFunction
 
specialize(FunctionBinding) - Method in class io.prestosql.operator.window.SqlWindowFunction
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.metadata.SqlAggregationFunction
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.metadata.SqlScalarFunction
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxBy
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.aggregation.ParametricAggregation
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.AbstractGreatestLeast
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.ArrayJoin.ArrayJoinWithNullReplacement
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.ArrayJoin
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.ArrayToArrayCast
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.FormatFunction
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.MapConstructor
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.MapElementAtFunction
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.MapToMapCast
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.ParametricScalar
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.RowToRowCast
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.scalar.TryCastFunction
 
specialize(FunctionBinding, FunctionDependencies) - Method in class io.prestosql.operator.window.SqlWindowFunction
 
Specification(List<Symbol>, Optional<OrderingScheme>) - Constructor for class io.prestosql.sql.planner.plan.WindowNode.Specification
 
spill(Page) - Method in interface io.prestosql.spiller.SingleStreamSpiller
Initiate spilling of single page.
spill(Iterator<Page>) - Method in class io.prestosql.spiller.FileSingleStreamSpiller
 
spill(Iterator<Page>) - Method in class io.prestosql.spiller.GenericSpiller
 
spill(Iterator<Page>) - Method in interface io.prestosql.spiller.SingleStreamSpiller
Initiate spilling of pages stream.
spill(Iterator<Page>) - Method in interface io.prestosql.spiller.Spiller
Initiate spilling of pages stream.
SPILL_ENABLED - Static variable in class io.prestosql.SystemSessionProperties
 
SPILL_ORDER_BY - Static variable in class io.prestosql.SystemSessionProperties
 
SPILL_WINDOW_OPERATOR - Static variable in class io.prestosql.SystemSessionProperties
 
SpillableHashAggregationBuilder - Class in io.prestosql.operator.aggregation.builder
 
SpillableHashAggregationBuilder(List<AccumulatorFactory>, AggregationNode.Step, int, List<Type>, List<Integer>, Optional<Integer>, OperatorContext, DataSize, DataSize, SpillerFactory, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.aggregation.builder.SpillableHashAggregationBuilder
 
SpillCipher - Interface in io.prestosql.spiller
 
SpillContext - Interface in io.prestosql.operator
 
spillEpoch() - Method in interface io.prestosql.operator.LookupSourceProvider.LookupSourceLease
 
Spiller - Interface in io.prestosql.spiller
 
SPILLER_SPILL_PATH - Static variable in class io.prestosql.sql.analyzer.FeaturesConfig
 
SpillerFactory - Interface in io.prestosql.spiller
 
SpillerStats - Class in io.prestosql.spiller
 
SpillerStats() - Constructor for class io.prestosql.spiller.SpillerStats
 
SpillInfoSnapshot(long, IntPredicate) - Constructor for class io.prestosql.operator.LookupJoinOperator.SpillInfoSnapshot
 
SPILLING_INPUT - io.prestosql.operator.HashBuilderOperator.State
Memory revoking occurred during HashBuilderOperator.State.CONSUMING_INPUT.
SpillSpaceTracker - Class in io.prestosql.spiller
 
SpillSpaceTracker(DataSize) - Constructor for class io.prestosql.spiller.SpillSpaceTracker
 
split(Slice) - Method in class io.prestosql.type.Re2JRegexp
 
split(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
split(Slice, Slice, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
Split - Class in io.prestosql.metadata
 
Split(CatalogName, ConnectorSplit, Lifespan) - Constructor for class io.prestosql.metadata.Split
 
SPLIT_CONCURRENCY_ADJUSTMENT_INTERVAL - Static variable in class io.prestosql.SystemSessionProperties
 
SPLIT_QUEUES_FULL - io.prestosql.execution.scheduler.ScheduleResult.BlockedReason
 
SPLIT_RUN_QUANTA - Static variable in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
SplitBatch(List<Split>, boolean) - Constructor for class io.prestosql.split.SplitSource.SplitBatch
 
splitComplete(PrioritizedSplitRunner) - Method in class io.prestosql.execution.executor.TaskHandle
 
splitCompleted(SplitCompletedEvent) - Method in class io.prestosql.eventlistener.EventListenerManager
 
splitCompleted(SplitCompletedEvent) - Method in class io.prestosql.testing.TestingEventListenerManager
 
splitCompletedEvent(TaskId, DriverStats) - Method in class io.prestosql.event.SplitMonitor
 
SplitConcurrencyController - Class in io.prestosql.execution
 
SplitConcurrencyController(int, Duration) - Constructor for class io.prestosql.execution.SplitConcurrencyController
 
splitFailedEvent(TaskId, DriverStats, Throwable) - Method in class io.prestosql.event.SplitMonitor
 
splitFinished(long, double, int) - Method in class io.prestosql.execution.SplitConcurrencyController
 
SplitManager - Class in io.prestosql.split
 
SplitManager(QueryManagerConfig, Metadata) - Constructor for class io.prestosql.split.SplitManager
 
splitModule(HandleResolver) - Static method in class io.prestosql.metadata.HandleJsonModule
 
SplitMonitor - Class in io.prestosql.event
 
SplitMonitor(EventListenerManager, ObjectMapper) - Constructor for class io.prestosql.event.SplitMonitor
 
SplitOperatorInfo - Class in io.prestosql.operator
 
SplitOperatorInfo(CatalogName, Object) - Constructor for class io.prestosql.operator.SplitOperatorInfo
 
splitPage(Page, long) - Static method in class io.prestosql.execution.buffer.PageSplitterUtil
 
splitPart(Slice, Slice, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
SplitPlacementPolicy - Interface in io.prestosql.execution.scheduler
 
SplitPlacementResult - Class in io.prestosql.execution.scheduler
 
SplitPlacementResult(ListenableFuture<?>, Multimap<InternalNode, Split>) - Constructor for class io.prestosql.execution.scheduler.SplitPlacementResult
 
SplitRunner - Interface in io.prestosql.execution
 
splitsAdded(int) - Method in class io.prestosql.operator.PipelineContext
 
SplitSchedulerStats - Class in io.prestosql.execution.scheduler
 
SplitSchedulerStats() - Constructor for class io.prestosql.execution.scheduler.SplitSchedulerStats
 
SplitSource - Interface in io.prestosql.split
 
SplitSource.SplitBatch - Class in io.prestosql.split
 
splitToMap(Type, Slice, Slice, Slice) - Method in class io.prestosql.operator.scalar.SplitToMapFunction
 
SplitToMapFunction - Class in io.prestosql.operator.scalar
 
SplitToMapFunction(Type) - Constructor for class io.prestosql.operator.scalar.SplitToMapFunction
 
splitToMultimap(Type, Slice, Slice, Slice) - Method in class io.prestosql.operator.scalar.SplitToMultimapFunction
 
SplitToMultimapFunction - Class in io.prestosql.operator.scalar
 
SplitToMultimapFunction(Type) - Constructor for class io.prestosql.operator.scalar.SplitToMultimapFunction
 
spookyHashV2_32(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
spookyHashV2_64(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
SqlAggregationFunction - Class in io.prestosql.metadata
 
SqlAggregationFunction(FunctionMetadata, boolean, boolean) - Constructor for class io.prestosql.metadata.SqlAggregationFunction
 
sqlDateOf(int, int, int) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlDateOf(LocalDate) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
SqlEnvironmentConfig - Class in io.prestosql.sql
 
SqlEnvironmentConfig() - Constructor for class io.prestosql.sql.SqlEnvironmentConfig
 
sqlFormat(List<BiFunction<ConnectorSession, Block, Object>>, ConnectorSession, Slice, Block) - Static method in class io.prestosql.operator.scalar.FormatFunction
 
SqlFormatterUtil - Class in io.prestosql.sql
 
SqlFunction - Interface in io.prestosql.metadata
 
SqlIntervalDayTime - Class in io.prestosql.type
 
SqlIntervalDayTime(int, int, int, int, int) - Constructor for class io.prestosql.type.SqlIntervalDayTime
 
SqlIntervalDayTime(long) - Constructor for class io.prestosql.type.SqlIntervalDayTime
 
SqlIntervalYearMonth - Class in io.prestosql.type
 
SqlIntervalYearMonth(int) - Constructor for class io.prestosql.type.SqlIntervalYearMonth
 
SqlIntervalYearMonth(int, int) - Constructor for class io.prestosql.type.SqlIntervalYearMonth
 
SqlOperator - Class in io.prestosql.metadata
 
SqlOperator(OperatorType, List<TypeVariableConstraint>, List<LongVariableConstraint>, TypeSignature, List<TypeSignature>, boolean) - Constructor for class io.prestosql.metadata.SqlOperator
 
SqlPath - Class in io.prestosql.sql
 
SqlPath(Optional<String>) - Constructor for class io.prestosql.sql.SqlPath
 
SqlPathElement - Class in io.prestosql.sql
 
SqlPathElement(Optional<Identifier>, Identifier) - Constructor for class io.prestosql.sql.SqlPathElement
 
SqlQueryExecution - Class in io.prestosql.execution
 
SqlQueryExecution.SqlQueryExecutionFactory - Class in io.prestosql.execution
 
SqlQueryManager - Class in io.prestosql.execution
 
SqlQueryManager(ClusterMemoryManager, QueryManagerConfig) - Constructor for class io.prestosql.execution.SqlQueryManager
 
SqlQueryScheduler - Class in io.prestosql.execution.scheduler
 
SqlScalarFunction - Class in io.prestosql.metadata
 
SqlScalarFunction(FunctionMetadata) - Constructor for class io.prestosql.metadata.SqlScalarFunction
 
SqlStageExecution - Class in io.prestosql.execution
 
SqlTask - Class in io.prestosql.execution
 
SqlTaskExecution - Class in io.prestosql.execution
 
SqlTaskExecutionFactory - Class in io.prestosql.execution
 
SqlTaskExecutionFactory(Executor, TaskExecutor, LocalExecutionPlanner, SplitMonitor, TaskManagerConfig) - Constructor for class io.prestosql.execution.SqlTaskExecutionFactory
 
SqlTaskIoStats - Class in io.prestosql.execution
 
SqlTaskIoStats() - Constructor for class io.prestosql.execution.SqlTaskIoStats
 
SqlTaskIoStats(CounterStat, CounterStat, CounterStat, CounterStat) - Constructor for class io.prestosql.execution.SqlTaskIoStats
 
SqlTaskManager - Class in io.prestosql.execution
 
SqlTaskManager(LocalExecutionPlanner, LocationFactory, TaskExecutor, SplitMonitor, NodeInfo, LocalMemoryManager, TaskManagementExecutor, TaskManagerConfig, NodeMemoryConfig, LocalSpillManager, NodeSpillConfig, GcMonitor) - Constructor for class io.prestosql.execution.SqlTaskManager
 
sqlTimeOf(int, int, int, int) - Static method in class io.prestosql.testing.DateTimeTestingUtils
sqlTimeOf(int, int, int, int, int) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimeOf(int, LocalTime) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimeOf(LocalTime) - Static method in class io.prestosql.testing.DateTimeTestingUtils
sqlTimestampOf(int, int, int, int, int, int, int, int) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimestampOf(int, long) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimestampOf(int, LocalDateTime) - Static method in class io.prestosql.testing.DateTimeTestingUtils
Constructs standard (non-legacy) TIMESTAMP value corresponding to argument
sqlTimestampOf(int, DateTime) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimestampOf(long) - Static method in class io.prestosql.testing.DateTimeTestingUtils
sqlTimestampOf(DateTime) - Static method in class io.prestosql.testing.DateTimeTestingUtils
sqlTimestampWithTimeZoneOf(int, int, int, int, int, int, int, int, TimeZoneKey) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimeWithTimeZoneOf(int, int, int, int, int, int) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
SqlToRowExpressionTranslator - Class in io.prestosql.sql.relational
 
SqlTypeBytecodeExpression - Class in io.prestosql.sql.gen
 
sqlVarbinary(int...) - Static method in class io.prestosql.testing.SqlVarbinaryTestingUtil
 
sqlVarbinary(String) - Static method in class io.prestosql.testing.SqlVarbinaryTestingUtil
 
sqlVarbinaryFromHex(String) - Static method in class io.prestosql.testing.SqlVarbinaryTestingUtil
 
sqlVarbinaryFromIso(String) - Static method in class io.prestosql.testing.SqlVarbinaryTestingUtil
 
SqlVarbinaryTestingUtil - Class in io.prestosql.testing
 
SqlWindowFunction - Class in io.prestosql.operator.window
 
SqlWindowFunction(WindowFunctionSupplier, boolean) - Constructor for class io.prestosql.operator.window.SqlWindowFunction
 
sqrt(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
ST_CONTAINS - Static variable in class io.prestosql.util.SpatialJoinUtils
 
ST_DISTANCE - Static variable in class io.prestosql.util.SpatialJoinUtils
 
ST_INTERSECTS - Static variable in class io.prestosql.util.SpatialJoinUtils
 
ST_WITHIN - Static variable in class io.prestosql.util.SpatialJoinUtils
 
StackLine(String, int, String, String) - Constructor for class io.prestosql.server.ThreadResource.StackLine
 
stageCannotScheduleMoreTasks(StageId, int) - Method in class io.prestosql.server.DynamicFilterService
 
StageExecutionDescriptor - Class in io.prestosql.operator
 
StageExecutionDescriptor.StageExecutionStrategy - Enum in io.prestosql.operator
 
StageExecutionPlan - Class in io.prestosql.sql.planner
 
StageExecutionPlan(PlanFragment, Map<PlanNodeId, SplitSource>, List<StageExecutionPlan>, Map<PlanNodeId, TableInfo>) - Constructor for class io.prestosql.sql.planner.StageExecutionPlan
 
StageId - Class in io.prestosql.execution
 
StageId(QueryId, int) - Constructor for class io.prestosql.execution.StageId
 
StageId(String, int) - Constructor for class io.prestosql.execution.StageId
 
StageInfo - Class in io.prestosql.execution
 
StageInfo(StageId, StageState, PlanFragment, List<Type>, StageStats, List<TaskInfo>, List<StageInfo>, Map<PlanNodeId, TableInfo>, ExecutionFailureInfo) - Constructor for class io.prestosql.execution.StageInfo
 
StageScheduler - Interface in io.prestosql.execution.scheduler
 
StageState - Enum in io.prestosql.execution
 
StageStateMachine - Class in io.prestosql.execution
 
StageStateMachine(StageId, Session, PlanFragment, Map<PlanNodeId, TableInfo>, ExecutorService, SplitSchedulerStats) - Constructor for class io.prestosql.execution.StageStateMachine
 
StageStats - Class in io.prestosql.execution
 
StageStats(DateTime, Distribution.DistributionSnapshot, int, int, int, int, int, int, int, int, double, DataSize, DataSize, DataSize, DataSize, DataSize, Duration, Duration, Duration, boolean, Set<BlockedReason>, DataSize, long, Duration, DataSize, long, DataSize, long, DataSize, long, DataSize, DataSize, long, DataSize, StageGcStatistics, List<OperatorStats>) - Constructor for class io.prestosql.execution.StageStats
 
StandardFunctionResolution - Class in io.prestosql.sql.relational
 
StandardFunctionResolution(Metadata) - Constructor for class io.prestosql.sql.relational.StandardFunctionResolution
 
StandardJoinFilterFunction - Class in io.prestosql.operator
 
StandardJoinFilterFunction(InternalJoinFilterFunction, LongArrayList, List<Page>) - Constructor for class io.prestosql.operator.StandardJoinFilterFunction
 
start - Variable in class io.prestosql.util.LongBigArrayFIFOQueue
The start position in LongBigArrayFIFOQueue.array.
start() - Method in class io.prestosql.dispatcher.DispatchManager
 
start() - Method in class io.prestosql.execution.ClusterSizeMonitor
 
start() - Method in class io.prestosql.execution.DataDefinitionExecution
 
start() - Method in class io.prestosql.execution.executor.TaskExecutor
 
start() - Method in class io.prestosql.execution.MemoryRevokingScheduler
 
start() - Method in interface io.prestosql.execution.QueryExecution
 
start() - Method in class io.prestosql.execution.QueryTracker
 
start() - Method in interface io.prestosql.execution.RemoteTask
 
start() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
start() - Method in class io.prestosql.execution.scheduler.SqlQueryScheduler
 
start() - Method in class io.prestosql.execution.SqlQueryExecution
 
start() - Method in class io.prestosql.execution.SqlQueryManager
 
start() - Method in class io.prestosql.execution.SqlTaskManager
 
start() - Method in class io.prestosql.failuredetector.HeartbeatFailureDetector
 
start() - Method in class io.prestosql.operator.PipelineContext
 
start() - Method in class io.prestosql.operator.TaskContext
 
start() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
start() - Method in class io.prestosql.server.remotetask.TaskInfoFetcher
 
start() - Method in class io.prestosql.server.security.jwt.JwkService
 
start() - Method in class io.prestosql.sql.gen.ExpressionProfiler
 
start() - Method in class io.prestosql.util.FinalizerService
 
start(int, int, Page) - Method in class io.prestosql.operator.ArrayPositionLinks
 
start(int, int, Page) - Method in interface io.prestosql.operator.PositionLinks
Initialize iteration over position links.
start(int, int, Page) - Method in class io.prestosql.operator.SortedPositionLinks
 
start(String) - Method in class io.prestosql.server.Server
 
START - io.prestosql.operator.WindowOperator.FrameBoundKey.Type
 
startChallenge(URI) - Method in class io.prestosql.server.security.oauth2.OAuth2Service
 
STARTING - io.prestosql.execution.QueryState
Query execution is being started.
STARTING_VERSION - Static variable in class io.prestosql.execution.TaskStatus
Version of task status that can be used to create an initial local task that is always older or equal than any remote task.
startLifespan(Lifespan, ConnectorPartitionHandle) - Method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
 
startLifespan(Lifespan, ConnectorPartitionHandle) - Method in interface io.prestosql.execution.scheduler.SourceScheduler
 
startMemoryRevoke() - Method in interface io.prestosql.operator.aggregation.builder.HashAggregationBuilder
 
startMemoryRevoke() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
startMemoryRevoke() - Method in class io.prestosql.operator.aggregation.builder.SpillableHashAggregationBuilder
 
startMemoryRevoke() - Method in class io.prestosql.operator.HashAggregationOperator
 
startMemoryRevoke() - Method in class io.prestosql.operator.HashBuilderOperator
 
startMemoryRevoke() - Method in interface io.prestosql.operator.Operator
After calling this method operator should revoke all reserved revocable memory.
startMemoryRevoke() - Method in class io.prestosql.operator.OrderByOperator
 
startMemoryRevoke() - Method in class io.prestosql.operator.WindowOperator
 
startMemoryRevoke() - Method in class io.prestosql.operator.WorkProcessorPipelineSourceOperator
 
startPollingNodeStates() - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
startProcessTimer() - Method in class io.prestosql.operator.DriverContext
 
startRequest() - Method in class io.prestosql.server.remotetask.Backoff
 
startsWith(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
StartTransactionTask - Class in io.prestosql.execution
 
StartTransactionTask() - Constructor for class io.prestosql.execution.StartTransactionTask
 
startupComplete() - Method in class io.prestosql.server.ServerInfoResource
 
startWaitingForResources() - Method in class io.prestosql.dispatcher.FailedDispatchQuery
 
startWaitingForResources() - Method in class io.prestosql.dispatcher.LocalDispatchQuery
 
startWaitingForResources() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
State(MapType) - Constructor for class io.prestosql.operator.scalar.MapConstructor.State
 
STATE - io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata.ParameterType
 
stateChanged(T) - Method in interface io.prestosql.execution.StateMachine.StateChangeListener
 
StateCompiler - Class in io.prestosql.operator.aggregation.state
 
StateMachine<T> - Class in io.prestosql.execution
Simple state machine which holds a single state.
StateMachine(String, Executor, T) - Constructor for class io.prestosql.execution.StateMachine
Creates a state machine with the specified initial state and no terminal states.
StateMachine(String, Executor, T, Iterable<T>) - Constructor for class io.prestosql.execution.StateMachine
Creates a state machine with the specified initial state and terminal states.
StateMachine.StateChangeListener<T> - Interface in io.prestosql.execution
 
StatementHttpExecutionMBean - Class in io.prestosql.server
 
StatementHttpExecutionMBean(ExecutorService, ScheduledExecutorService) - Constructor for class io.prestosql.server.StatementHttpExecutionMBean
 
StatementRewrite - Class in io.prestosql.sql.rewrite
 
StatementUtils - Class in io.prestosql.util
 
StaticCatalogStore - Class in io.prestosql.metadata
 
StaticCatalogStore(ConnectorManager, StaticCatalogStoreConfig) - Constructor for class io.prestosql.metadata.StaticCatalogStore
 
StaticCatalogStore(ConnectorManager, File, List<String>) - Constructor for class io.prestosql.metadata.StaticCatalogStore
 
StaticCatalogStoreConfig - Class in io.prestosql.metadata
 
StaticCatalogStoreConfig() - Constructor for class io.prestosql.metadata.StaticCatalogStoreConfig
 
StaticLookupSourceProvider - Class in io.prestosql.operator
 
StaticLookupSourceProvider(LookupSource) - Constructor for class io.prestosql.operator.StaticLookupSourceProvider
 
StaticResourceAccessTypeLoader(Map<AnnotatedElement, ResourceSecurity.AccessType>) - Constructor for class io.prestosql.server.security.ResourceSecurityBinder.StaticResourceAccessTypeLoader
 
StaticSystemTablesProvider - Class in io.prestosql.connector.system
 
StaticSystemTablesProvider(Set<SystemTable>) - Constructor for class io.prestosql.connector.system.StaticSystemTablesProvider
 
StatisticAggregations - Class in io.prestosql.sql.planner.plan
 
StatisticAggregations(Map<Symbol, AggregationNode.Aggregation>, List<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.StatisticAggregations
 
StatisticAggregations.Parts - Class in io.prestosql.sql.planner.plan
 
StatisticAggregationsDescriptor<T> - Class in io.prestosql.sql.planner.plan
 
StatisticAggregationsDescriptor(Map<String, T>, Map<TableStatisticType, T>, Map<ColumnStatisticMetadata, T>) - Constructor for class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
StatisticAggregationsDescriptor.Builder<T> - Class in io.prestosql.sql.planner.plan
 
StatisticAggregationsDescriptor.ColumnStatisticMetadataKeyDeserializer - Class in io.prestosql.sql.planner.plan
 
StatisticAggregationsDescriptor.ColumnStatisticMetadataKeySerializer - Class in io.prestosql.sql.planner.plan
 
statisticRange() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
StatisticRange - Class in io.prestosql.cost
 
StatisticRange(double, double, double) - Constructor for class io.prestosql.cost.StatisticRange
 
STATISTICS_CPU_TIMER_ENABLED - Static variable in class io.prestosql.SystemSessionProperties
 
StatisticsAggregationPlanner - Class in io.prestosql.sql.planner
 
StatisticsAggregationPlanner(SymbolAllocator, Metadata) - Constructor for class io.prestosql.sql.planner.StatisticsAggregationPlanner
 
StatisticsAggregationPlanner.ColumnStatisticsAggregation - Class in io.prestosql.sql.planner
 
StatisticsAggregationPlanner.TableStatisticAggregation - Class in io.prestosql.sql.planner
 
StatisticsWriterNode - Class in io.prestosql.sql.planner.plan
 
StatisticsWriterNode(PlanNodeId, PlanNode, StatisticsWriterNode.WriteStatisticsTarget, Symbol, boolean, StatisticAggregationsDescriptor<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
StatisticsWriterNode.WriteStatisticsHandle - Class in io.prestosql.sql.planner.plan
 
StatisticsWriterNode.WriteStatisticsReference - Class in io.prestosql.sql.planner.plan
 
StatisticsWriterNode.WriteStatisticsTarget - Class in io.prestosql.sql.planner.plan
 
StatisticsWriterOperator - Class in io.prestosql.operator
 
StatisticsWriterOperator(OperatorContext, StatisticsWriterOperator.StatisticsWriter, StatisticAggregationsDescriptor<Integer>, boolean) - Constructor for class io.prestosql.operator.StatisticsWriterOperator
 
StatisticsWriterOperator.StatisticsWriter - Interface in io.prestosql.operator
 
StatisticsWriterOperator.StatisticsWriterOperatorFactory - Class in io.prestosql.operator
 
StatisticsWriterOperatorFactory(int, PlanNodeId, StatisticsWriterOperator.StatisticsWriter, boolean, StatisticAggregationsDescriptor<Integer>) - Constructor for class io.prestosql.operator.StatisticsWriterOperator.StatisticsWriterOperatorFactory
 
Stats(URI) - Constructor for class io.prestosql.failuredetector.HeartbeatFailureDetector.Stats
 
STATS_START_CHANNEL - Static variable in class io.prestosql.operator.TableWriterOperator
 
StatsAndCosts - Class in io.prestosql.cost
 
StatsAndCosts(Map<PlanNodeId, PlanNodeStatsEstimate>, Map<PlanNodeId, PlanCostEstimate>) - Constructor for class io.prestosql.cost.StatsAndCosts
 
StatsCalculator - Interface in io.prestosql.cost
 
StatsCalculatorModule - Class in io.prestosql.cost
 
StatsCalculatorModule() - Constructor for class io.prestosql.cost.StatsCalculatorModule
 
StatsNormalizer - Class in io.prestosql.cost
Makes stats consistent
StatsNormalizer() - Constructor for class io.prestosql.cost.StatsNormalizer
 
StatsProvider - Interface in io.prestosql.cost
 
StatsRecordingPlanOptimizer - Class in io.prestosql.sql.planner.optimizations
 
StatsRecordingPlanOptimizer(OptimizerStatsRecorder, PlanOptimizer) - Constructor for class io.prestosql.sql.planner.optimizations.StatsRecordingPlanOptimizer
 
statusPing() - Method in class io.prestosql.server.StatusResource
 
StatusResource - Class in io.prestosql.server
 
StatusResource(NodeVersion, NodeInfo, ServerConfig, LocalMemoryManager) - Constructor for class io.prestosql.server.StatusResource
 
statusRoundTripMillis(long) - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
stddev(VarianceState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.VarianceAggregation
 
stddevPop(VarianceState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.VarianceAggregation
 
step() - Static method in class io.prestosql.sql.planner.plan.Patterns.Aggregation
 
step() - Static method in class io.prestosql.sql.planner.plan.Patterns.TopN
 
stop() - Method in class io.prestosql.connector.ConnectorManager
 
stop() - Method in class io.prestosql.dispatcher.DispatchManager
 
stop() - Method in class io.prestosql.dispatcher.QueuedStatementResource
 
stop() - Method in class io.prestosql.execution.ClusterSizeMonitor
 
stop() - Method in class io.prestosql.execution.executor.TaskExecutor
 
stop() - Method in class io.prestosql.execution.MemoryRevokingScheduler
 
stop() - Method in class io.prestosql.execution.QueryTracker
 
stop() - Method in class io.prestosql.execution.SqlQueryManager
 
stop() - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
stop() - Method in class io.prestosql.operator.ExchangeClientFactory
 
stop() - Method in class io.prestosql.server.DynamicFilterService
 
stop() - Method in class io.prestosql.server.HttpRemoteTaskFactory
 
stop() - Method in class io.prestosql.server.protocol.ExecutingStatementResource
 
stop() - Method in class io.prestosql.server.security.jwt.JwkService
 
stop(int) - Method in class io.prestosql.sql.gen.ExpressionProfiler
 
storeCost(int, PlanCostEstimate) - Method in class io.prestosql.sql.planner.iterative.Memo
 
storeStats(int, PlanNodeStatsEstimate) - Method in class io.prestosql.sql.planner.iterative.Memo
 
strategy - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
The hash strategy of this custom map.
strategy() - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Returns the hashing strategy.
streamBackdoorDeriveProperties(PlanNode, List<ActualProperties>, Metadata, TypeOperators, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.PropertyDerivations
 
streamIndexDataForSingleKey(UpdateRequest) - Method in class io.prestosql.operator.index.IndexLoader
 
StreamingAggregationOperator - Class in io.prestosql.operator
 
StreamingIndexedData - Class in io.prestosql.operator.index
 
StreamingIndexedData(List<Type>, List<BlockTypeOperators.BlockPositionEqual>, Page, PageBuffer, Driver) - Constructor for class io.prestosql.operator.index.StreamingIndexedData
 
streamPartitionedOn(List<Symbol>) - Static method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
StreamPreferredProperties - Class in io.prestosql.sql.planner.optimizations
 
StreamPropertyDerivations - Class in io.prestosql.sql.planner.optimizations
 
StreamPropertyDerivations.StreamProperties - Class in io.prestosql.sql.planner.optimizations
 
StreamPropertyDerivations.StreamProperties.StreamDistribution - Enum in io.prestosql.sql.planner.optimizations
 
StringApproximateMostFrequentStateFactory - Class in io.prestosql.operator.aggregation
 
StringApproximateMostFrequentStateFactory() - Constructor for class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateFactory
 
StringApproximateMostFrequentStateFactory.GroupedLongApproximateMostFrequentState - Class in io.prestosql.operator.aggregation
 
StringApproximateMostFrequentStateFactory.SingleLongApproximateMostFrequentState - Class in io.prestosql.operator.aggregation
 
StringApproximateMostFrequentStateSerializer - Class in io.prestosql.operator.aggregation
 
StringApproximateMostFrequentStateSerializer() - Constructor for class io.prestosql.operator.aggregation.StringApproximateMostFrequentStateSerializer
 
StringFunctions - Class in io.prestosql.operator.scalar
Current implementation is based on code points from Unicode and does ignore grapheme cluster boundaries.
stringPosition(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
stringPosition(Slice, Slice, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
stripLeadingConstants(List<? extends LocalProperty<T>>) - Static method in class io.prestosql.sql.planner.optimizations.LocalProperties
 
SubExpressionExtractor - Class in io.prestosql.sql.planner
Extracts and returns the set of all expression subtrees within an Expression, including Expression itself
subExpressions(Iterable<RowExpression>) - Static method in class io.prestosql.sql.relational.Expressions
 
subGroups() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
subLocation(int, int) - Method in class io.prestosql.execution.scheduler.NetworkLocation
 
submit(ManagedQueryExecution, SelectionContext<C>, Executor) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
submit(ManagedQueryExecution, SelectionContext<C>, Executor) - Method in interface io.prestosql.execution.resourcegroups.ResourceGroupManager
 
submit(ManagedQueryExecution, SelectionContext<Void>, Executor) - Method in class io.prestosql.execution.resourcegroups.NoOpResourceGroupManager
 
submit(Runnable) - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
submit(Runnable, T) - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
submit(Callable<T>) - Method in class io.prestosql.dispatcher.DecoratingListeningExecutorService
 
SUBNET - io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig.TopologyType
 
SubnetBasedTopology - Class in io.prestosql.execution.scheduler
 
SubnetBasedTopology(SubnetTopologyConfig) - Constructor for class io.prestosql.execution.scheduler.SubnetBasedTopology
 
SubnetBasedTopology(List<Integer>, SubnetBasedTopology.AddressProtocol) - Constructor for class io.prestosql.execution.scheduler.SubnetBasedTopology
 
SubnetBasedTopology.AddressProtocol - Enum in io.prestosql.execution.scheduler
 
SubnetTopologyConfig - Class in io.prestosql.execution.scheduler
 
SubnetTopologyConfig() - Constructor for class io.prestosql.execution.scheduler.SubnetTopologyConfig
 
SubPlan - Class in io.prestosql.sql.planner
 
SubPlan(PlanFragment, List<SubPlan>) - Constructor for class io.prestosql.sql.planner.SubPlan
 
subquery() - Static method in class io.prestosql.sql.planner.plan.Patterns.CorrelatedJoin
 
subRange(int, int) - Method in class io.prestosql.operator.project.SelectedPositions
 
subscript(MapSubscriptOperator.MissingKeyExceptionFactory, Type, Type, ConnectorSession, Block, boolean) - Static method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
subscript(MapSubscriptOperator.MissingKeyExceptionFactory, Type, Type, ConnectorSession, Block, double) - Static method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
subscript(MapSubscriptOperator.MissingKeyExceptionFactory, Type, Type, ConnectorSession, Block, long) - Static method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
subscript(MapSubscriptOperator.MissingKeyExceptionFactory, Type, Type, ConnectorSession, Block, Object) - Static method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
substr(Slice, long) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
substr(Slice, long, long) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
substring(Slice, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
substring(Slice, long, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
subtract(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
subtract(long, long) - Static method in class io.prestosql.operator.scalar.time.TimeOperators
 
subtract(long, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampMinusIntervalDayToSecond
 
subtract(long, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampMinusIntervalYearToMonth
 
subtract(long, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampMinusTimestamp
 
subtract(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampMinusIntervalYearToMonth
 
subtract(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampMinusTimestamp
 
subtract(long, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.TimeMinusIntervalDayToSecond
 
subtract(long, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.TimeMinusTime
 
subtract(long, long) - Static method in class io.prestosql.type.BigintOperators
 
subtract(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
subtract(long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
subtract(long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
subtract(long, long) - Static method in class io.prestosql.type.RealOperators
 
subtract(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
subtract(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
subtract(long, long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampMinusIntervalDayToSecond
 
subtract(ConnectorSession, LongTimestamp, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampMinusIntervalYearToMonth
 
subtract(LongTimestamp, long) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampMinusIntervalDayToSecond
 
subtract(LongTimestamp, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampMinusTimestamp
 
subtract(LongTimestampWithTimeZone, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampMinusIntervalDayToSecond
 
subtract(LongTimestampWithTimeZone, long) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampMinusIntervalYearToMonth
 
subtract(LongTimestampWithTimeZone, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampMinusTimestamp
 
subtract(LongTimeWithTimeZone, long) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.TimeMinusIntervalDayToSecond
 
subtract(LongTimeWithTimeZone, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.TimeMinusTime
 
subtractLongLongLong(Slice, Slice, int, boolean) - Static method in class io.prestosql.type.DecimalOperators
 
subtractLongShortLong(Slice, long, int, boolean) - Static method in class io.prestosql.type.DecimalOperators
 
subtractShortLongLong(long, Slice, int, boolean) - Static method in class io.prestosql.type.DecimalOperators
 
subtractShortShortLong(long, long, int, boolean) - Static method in class io.prestosql.type.DecimalOperators
 
subtractShortShortShort(long, long, long, long) - Static method in class io.prestosql.type.DecimalOperators
 
subtractSubsetStats(PlanNodeStatsEstimate, PlanNodeStatsEstimate) - Static method in class io.prestosql.cost.PlanNodeStatsEstimateMath
Subtracts subset stats from supersets stats.
success() - Method in class io.prestosql.server.remotetask.Backoff
 
success(TaskInfo) - Method in class io.prestosql.server.remotetask.TaskInfoFetcher
 
success(T) - Method in interface io.prestosql.server.remotetask.SimpleHttpResponseCallback
 
SugarFreeChecker - Class in io.prestosql.sql.planner.sanity
Verifies the plan does not contain any "syntactic sugar" from the AST.
SugarFreeChecker() - Constructor for class io.prestosql.sql.planner.sanity.SugarFreeChecker
 
sum(LongDoubleState, double) - Static method in class io.prestosql.operator.aggregation.DoubleSumAggregation
 
sum(LongLongState, long) - Static method in class io.prestosql.operator.aggregation.LongSumAggregation
 
sum(NullableDoubleState, long) - Static method in class io.prestosql.operator.aggregation.RealSumAggregation
 
sum(NullableLongState, long) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondSumAggregation
 
sum(NullableLongState, long) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthSumAggregation
 
SumDataSizeForStats - Class in io.prestosql.operator.aggregation
 
summarize() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
summarize() - Method in class io.prestosql.execution.TaskInfo
 
summarize() - Method in class io.prestosql.operator.OperatorStats
 
summarize() - Method in class io.prestosql.operator.PipelineStats
 
summarize() - Method in class io.prestosql.operator.TaskStats
 
summarizeFinal() - Method in class io.prestosql.operator.TaskStats
 
SuperTableJdbcTable - Class in io.prestosql.connector.system.jdbc
 
SuperTableJdbcTable() - Constructor for class io.prestosql.connector.system.jdbc.SuperTableJdbcTable
 
SuperTypeJdbcTable - Class in io.prestosql.connector.system.jdbc
 
SuperTypeJdbcTable() - Constructor for class io.prestosql.connector.system.jdbc.SuperTypeJdbcTable
 
supplier(Signature, InternalAggregationFunction) - Static method in class io.prestosql.operator.window.AggregateWindowFunction
 
supportClientTransaction() - Method in class io.prestosql.server.HttpRequestSessionContext
 
supportClientTransaction() - Method in interface io.prestosql.server.SessionContext
 
supportsMetadataDelete(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
 
supportsMetadataDelete(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
supportsMissingColumnsOnInsert(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
 
supportsMissingColumnsOnInsert(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
swap(int, int) - Method in class io.prestosql.operator.PagesIndex
 
SwapAdjacentWindowsBySpecifications(int) - Constructor for class io.prestosql.sql.planner.iterative.rule.GatherAndMergeWindows.SwapAdjacentWindowsBySpecifications
 
SWITCH - io.prestosql.sql.relational.SpecialForm.Form
 
SwitchCodeGenerator - Class in io.prestosql.sql.gen
 
SwitchCodeGenerator(SpecialForm) - Constructor for class io.prestosql.sql.gen.SwitchCodeGenerator
 
Symbol - Class in io.prestosql.sql.planner
 
Symbol(String) - Constructor for class io.prestosql.sql.planner.Symbol
 
SymbolAllocator - Class in io.prestosql.sql.planner
 
SymbolAllocator() - Constructor for class io.prestosql.sql.planner.SymbolAllocator
 
SymbolAllocator(Map<Symbol, Type>) - Constructor for class io.prestosql.sql.planner.SymbolAllocator
 
symbolMapper(Map<Symbol, Symbol>) - Static method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
SymbolMapper - Class in io.prestosql.sql.planner.optimizations
 
SymbolMapper.Builder - Class in io.prestosql.sql.planner.optimizations
 
symbolReallocator(Map<Symbol, Symbol>, SymbolAllocator) - Static method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
SymbolResolver - Interface in io.prestosql.sql.planner
 
SymbolsExtractor - Class in io.prestosql.sql.planner
 
SymbolStatsEstimate - Class in io.prestosql.cost
 
SymbolStatsEstimate(double, double, double, double, double) - Constructor for class io.prestosql.cost.SymbolStatsEstimate
 
SymbolStatsEstimate.Builder - Class in io.prestosql.cost
 
SyntheticAddress - Class in io.prestosql.operator
Methods for creating and decoding synthetic addresses.
SYSTEM - io.prestosql.sql.planner.plan.SampleNode.Type
 
SystemColumnHandle - Class in io.prestosql.connector.system
 
SystemColumnHandle(String) - Constructor for class io.prestosql.connector.system.SystemColumnHandle
 
SystemConnector - Class in io.prestosql.connector.system
 
SystemConnector(InternalNodeManager, SystemTablesProvider, Function<TransactionId, ConnectorTransactionHandle>) - Constructor for class io.prestosql.connector.system.SystemConnector
 
SystemConnector(InternalNodeManager, Set<SystemTable>, Function<TransactionId, ConnectorTransactionHandle>) - Constructor for class io.prestosql.connector.system.SystemConnector
 
SystemConnectorModule - Class in io.prestosql.connector.system
 
SystemConnectorModule() - Constructor for class io.prestosql.connector.system.SystemConnectorModule
 
SystemHandleResolver - Class in io.prestosql.connector.system
 
SystemHandleResolver() - Constructor for class io.prestosql.connector.system.SystemHandleResolver
 
SystemPageSourceProvider - Class in io.prestosql.connector.system
 
SystemPageSourceProvider(SystemTablesProvider) - Constructor for class io.prestosql.connector.system.SystemPageSourceProvider
 
SystemPartitioningHandle - Class in io.prestosql.sql.planner
 
SystemPartitioningHandle(SystemPartitioningHandle.SystemPartitioning, SystemPartitioningHandle.SystemPartitionFunction) - Constructor for class io.prestosql.sql.planner.SystemPartitioningHandle
 
SystemPartitioningHandle.SystemPartitionFunction - Enum in io.prestosql.sql.planner
 
SystemSessionProperties - Class in io.prestosql
 
SystemSessionProperties() - Constructor for class io.prestosql.SystemSessionProperties
 
SystemSessionProperties(QueryManagerConfig, TaskManagerConfig, MemoryManagerConfig, FeaturesConfig, NodeMemoryConfig, DynamicFilterConfig) - Constructor for class io.prestosql.SystemSessionProperties
 
SystemSplit - Class in io.prestosql.connector.system
 
SystemSplit(HostAddress, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.connector.system.SystemSplit
 
SystemSplit(List<HostAddress>, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.connector.system.SystemSplit
 
SystemSplitManager - Class in io.prestosql.connector.system
 
SystemSplitManager(InternalNodeManager, SystemTablesProvider) - Constructor for class io.prestosql.connector.system.SystemSplitManager
 
SystemTableHandle - Class in io.prestosql.connector.system
 
SystemTableHandle(String, String, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.connector.system.SystemTableHandle
 
SystemTablesMetadata - Class in io.prestosql.connector.system
 
SystemTablesMetadata(SystemTablesProvider) - Constructor for class io.prestosql.connector.system.SystemTablesMetadata
 
SystemTablesProvider - Interface in io.prestosql.connector.system
 
SystemTransactionHandle - Class in io.prestosql.connector.system
 
SystemTransactionHandle(TransactionId, ConnectorTransactionHandle) - Constructor for class io.prestosql.connector.system.SystemTransactionHandle
 

T

TABLE_PRIVILEGES - io.prestosql.connector.informationschema.InformationSchemaTable
 
TableColumnInfo(CatalogSchemaTableName, Set<IoPlanPrinter.ColumnConstraint>, IoPlanPrinter.EstimatedStatsAndCost) - Constructor for class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan.TableColumnInfo
 
TableCommentSystemTable - Class in io.prestosql.connector.system
 
TableCommentSystemTable(Metadata, AccessControl) - Constructor for class io.prestosql.connector.system.TableCommentSystemTable
 
TableDeleteNode - Class in io.prestosql.sql.planner.plan
 
TableDeleteNode(PlanNodeId, TableHandle, Symbol) - Constructor for class io.prestosql.sql.planner.plan.TableDeleteNode
 
TableDeleteOperator - Class in io.prestosql.operator
 
TableDeleteOperator(OperatorContext, Metadata, Session, TableHandle) - Constructor for class io.prestosql.operator.TableDeleteOperator
 
TableDeleteOperator.TableDeleteOperatorFactory - Class in io.prestosql.operator
 
TableDeleteOperatorFactory(int, PlanNodeId, Metadata, Session, TableHandle) - Constructor for class io.prestosql.operator.TableDeleteOperator.TableDeleteOperatorFactory
 
TableDeleteOptimizer - Class in io.prestosql.sql.planner.optimizations
Converts delete followed immediately by table scan to a special table-only delete node
TableDeleteOptimizer(Metadata) - Constructor for class io.prestosql.sql.planner.optimizations.TableDeleteOptimizer
 
tableExists(Metadata, Session, String) - Static method in class io.prestosql.metadata.MetadataUtil
 
tableExists(Session, String) - Method in class io.prestosql.testing.LocalQueryRunner
 
tableExists(Session, String) - Method in interface io.prestosql.testing.QueryRunner
 
tableFinish() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
TableFinishInfo - Class in io.prestosql.operator
 
TableFinishInfo(JsonNode, boolean, Duration, Duration) - Constructor for class io.prestosql.operator.TableFinishInfo
 
TableFinishInfo(Optional<ConnectorOutputMetadata>, Duration, Duration) - Constructor for class io.prestosql.operator.TableFinishInfo
 
TableFinishNode - Class in io.prestosql.sql.planner.plan
 
TableFinishNode(PlanNodeId, PlanNode, TableWriterNode.WriterTarget, Symbol, Optional<StatisticAggregations>, Optional<StatisticAggregationsDescriptor<Symbol>>) - Constructor for class io.prestosql.sql.planner.plan.TableFinishNode
 
TableFinishOperator - Class in io.prestosql.operator
 
TableFinishOperator(OperatorContext, TableFinishOperator.TableFinisher, Operator, StatisticAggregationsDescriptor<Integer>, boolean) - Constructor for class io.prestosql.operator.TableFinishOperator
 
TableFinishOperator.TableFinisher - Interface in io.prestosql.operator
 
TableFinishOperator.TableFinishOperatorFactory - Class in io.prestosql.operator
 
TableFinishOperatorFactory(int, PlanNodeId, TableFinishOperator.TableFinisher, OperatorFactory, StatisticAggregationsDescriptor<Integer>, Session) - Constructor for class io.prestosql.operator.TableFinishOperator.TableFinishOperatorFactory
 
TableHandle - Class in io.prestosql.metadata
 
TableHandle(CatalogName, ConnectorTableHandle, ConnectorTransactionHandle, Optional<ConnectorTableLayoutHandle>) - Constructor for class io.prestosql.metadata.TableHandle
 
tableHandleModule(HandleResolver) - Static method in class io.prestosql.metadata.HandleJsonModule
 
TableInfo - Class in io.prestosql.execution
 
TableInfo(QualifiedObjectName, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.execution.TableInfo
 
TableInfoSupplier - Class in io.prestosql.sql.planner.planprinter
 
TableInfoSupplier(Metadata, Session) - Constructor for class io.prestosql.sql.planner.planprinter.TableInfoSupplier
 
TableJdbcTable - Class in io.prestosql.connector.system.jdbc
 
TableJdbcTable(Metadata, AccessControl) - Constructor for class io.prestosql.connector.system.jdbc.TableJdbcTable
 
tableLayoutHandleModule(HandleResolver) - Static method in class io.prestosql.metadata.HandleJsonModule
 
TableLayoutResult - Class in io.prestosql.metadata
Deprecated.
TableLayoutResult(TableHandle, TableProperties, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.metadata.TableLayoutResult
Deprecated.
 
TableMetadata - Class in io.prestosql.metadata
 
TableMetadata(CatalogName, ConnectorTableMetadata) - Constructor for class io.prestosql.metadata.TableMetadata
 
tableMetadataBuilder(SchemaTableName) - Static method in class io.prestosql.metadata.MetadataUtil.TableMetadataBuilder
 
TablePartitioning(PartitioningHandle, List<ColumnHandle>) - Constructor for class io.prestosql.metadata.TableProperties.TablePartitioning
 
tablePrefix(String, Optional<String>, Optional<String>) - Static method in class io.prestosql.connector.system.jdbc.FilterUtil
 
TableProperties - Class in io.prestosql.metadata
 
TableProperties(CatalogName, ConnectorTransactionHandle, ConnectorTableProperties) - Constructor for class io.prestosql.metadata.TableProperties
 
TableProperties.TablePartitioning - Class in io.prestosql.metadata
 
TablePropertiesSystemTable - Class in io.prestosql.connector.system
 
TablePropertiesSystemTable(TransactionManager, Metadata) - Constructor for class io.prestosql.connector.system.TablePropertiesSystemTable
 
TablePropertyManager - Class in io.prestosql.metadata
 
TablePropertyManager() - Constructor for class io.prestosql.metadata.TablePropertyManager
 
TABLES - io.prestosql.connector.informationschema.InformationSchemaTable
 
tableScan() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
TableScanNode - Class in io.prestosql.sql.planner.plan
 
TableScanNode(PlanNodeId, TableHandle, List<Symbol>, Map<Symbol, ColumnHandle>, boolean) - Constructor for class io.prestosql.sql.planner.plan.TableScanNode
 
TableScanNode(PlanNodeId, TableHandle, List<Symbol>, Map<Symbol, ColumnHandle>, TupleDomain<ColumnHandle>, boolean) - Constructor for class io.prestosql.sql.planner.plan.TableScanNode
 
TableScanOperator - Class in io.prestosql.operator
 
TableScanOperator(OperatorContext, PlanNodeId, PageSourceProvider, TableHandle, Iterable<ColumnHandle>, DynamicFilter) - Constructor for class io.prestosql.operator.TableScanOperator
 
TableScanOperator.TableScanOperatorFactory - Class in io.prestosql.operator
 
TableScanOperatorFactory(int, PlanNodeId, PageSourceProvider, TableHandle, Iterable<ColumnHandle>, DynamicFilter) - Constructor for class io.prestosql.operator.TableScanOperator.TableScanOperatorFactory
 
TableScanStatsRule - Class in io.prestosql.cost
 
TableScanStatsRule(Metadata, StatsNormalizer) - Constructor for class io.prestosql.cost.TableScanStatsRule
 
TableScanValidator - Class in io.prestosql.sql.planner.sanity
 
TableScanValidator() - Constructor for class io.prestosql.sql.planner.sanity.TableScanValidator
 
TableScanWorkProcessorOperator - Class in io.prestosql.operator
 
TableScanWorkProcessorOperator(Session, MemoryTrackingContext, WorkProcessor<Split>, PageSourceProvider, TableHandle, Iterable<ColumnHandle>, DynamicFilter) - Constructor for class io.prestosql.operator.TableScanWorkProcessorOperator
 
TableTypeJdbcTable - Class in io.prestosql.connector.system.jdbc
 
TableTypeJdbcTable() - Constructor for class io.prestosql.connector.system.jdbc.TableTypeJdbcTable
 
TableWriterInfo(long, Duration, Duration, Duration) - Constructor for class io.prestosql.operator.TableWriterOperator.TableWriterInfo
 
tableWriterNode() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
TableWriterNode - Class in io.prestosql.sql.planner.plan
 
TableWriterNode(PlanNodeId, PlanNode, TableWriterNode.WriterTarget, Symbol, Symbol, List<Symbol>, List<String>, Set<Symbol>, Optional<PartitioningScheme>, Optional<StatisticAggregations>, Optional<StatisticAggregationsDescriptor<Symbol>>) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode
 
TableWriterNode.CreateReference - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.CreateTarget - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.DeleteTarget - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.InsertReference - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.InsertTarget - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.RefreshMaterializedViewReference - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.RefreshMaterializedViewTarget - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.WriterTarget - Class in io.prestosql.sql.planner.plan
 
TableWriterOperator - Class in io.prestosql.operator
 
TableWriterOperator(OperatorContext, ConnectorPageSink, List<Integer>, List<String>, Operator, List<Type>, boolean) - Constructor for class io.prestosql.operator.TableWriterOperator
 
TableWriterOperator.TableWriterInfo - Class in io.prestosql.operator
 
TableWriterOperator.TableWriterOperatorFactory - Class in io.prestosql.operator
 
TableWriterOperatorFactory(int, PlanNodeId, PageSinkManager, TableWriterNode.WriterTarget, List<Integer>, List<String>, Session, OperatorFactory, List<Type>) - Constructor for class io.prestosql.operator.TableWriterOperator.TableWriterOperatorFactory
 
take() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
tan(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
tanh(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
TASK_CONCURRENCY - Static variable in class io.prestosql.SystemSessionProperties
 
TASK_SHARE_INDEX_LOADING - Static variable in class io.prestosql.SystemSessionProperties
 
TASK_TABLE - Static variable in class io.prestosql.connector.system.TaskSystemTable
 
TASK_TABLE_NAME - Static variable in class io.prestosql.connector.system.TaskSystemTable
 
TASK_WRITER_COUNT - Static variable in class io.prestosql.SystemSessionProperties
 
TaskContext - Class in io.prestosql.operator
 
TaskCountEstimator - Class in io.prestosql.cost
 
TaskCountEstimator(NodeSchedulerConfig, InternalNodeManager) - Constructor for class io.prestosql.cost.TaskCountEstimator
 
TaskCountEstimator(IntSupplier) - Constructor for class io.prestosql.cost.TaskCountEstimator
 
TaskExecutor - Class in io.prestosql.execution.executor
 
TaskExecutor(int, int, int, int, Ticker) - Constructor for class io.prestosql.execution.executor.TaskExecutor
 
TaskExecutor(int, int, int, int, MultilevelSplitQueue, Ticker) - Constructor for class io.prestosql.execution.executor.TaskExecutor
 
TaskExecutor(int, int, int, int, EmbedVersion, MultilevelSplitQueue, Ticker) - Constructor for class io.prestosql.execution.executor.TaskExecutor
 
TaskExecutor(TaskManagerConfig, EmbedVersion, MultilevelSplitQueue) - Constructor for class io.prestosql.execution.executor.TaskExecutor
 
TaskExecutorResource - Class in io.prestosql.server
 
TaskExecutorResource(TaskExecutor) - Constructor for class io.prestosql.server.TaskExecutorResource
 
TaskHandle - Class in io.prestosql.execution.executor
 
TaskHandle(TaskId, MultilevelSplitQueue, DoubleSupplier, int, Duration, OptionalInt) - Constructor for class io.prestosql.execution.executor.TaskHandle
 
TaskId - Class in io.prestosql.execution
 
TaskId(StageId, int) - Constructor for class io.prestosql.execution.TaskId
 
TaskId(String) - Constructor for class io.prestosql.execution.TaskId
 
TaskId(String, int, int) - Constructor for class io.prestosql.execution.TaskId
 
TaskInfo - Class in io.prestosql.execution
 
TaskInfo(TaskStatus, DateTime, OutputBufferInfo, Set<PlanNodeId>, TaskStats, boolean) - Constructor for class io.prestosql.execution.TaskInfo
 
TaskInfoFetcher - Class in io.prestosql.server.remotetask
 
TaskInfoFetcher(Consumer<Throwable>, TaskInfo, HttpClient, Duration, JsonCodec<TaskInfo>, Duration, boolean, Executor, ScheduledExecutorService, ScheduledExecutorService, RemoteTaskStats) - Constructor for class io.prestosql.server.remotetask.TaskInfoFetcher
 
TaskManagementExecutor - Class in io.prestosql.execution
Holder of ScheduledExecutorService used for task management.
TaskManagementExecutor() - Constructor for class io.prestosql.execution.TaskManagementExecutor
 
TaskManager - Interface in io.prestosql.execution
 
TaskManagerConfig - Class in io.prestosql.execution
 
TaskManagerConfig() - Constructor for class io.prestosql.execution.TaskManagerConfig
 
TaskOutputFactory(OutputBuffer) - Constructor for class io.prestosql.operator.TaskOutputOperator.TaskOutputFactory
 
TaskOutputOperator - Class in io.prestosql.operator
 
TaskOutputOperator(OperatorContext, OutputBuffer, Function<Page, Page>, PagesSerdeFactory) - Constructor for class io.prestosql.operator.TaskOutputOperator
 
TaskOutputOperator.TaskOutputFactory - Class in io.prestosql.operator
 
TaskOutputOperator.TaskOutputOperatorFactory - Class in io.prestosql.operator
 
TaskOutputOperatorFactory(int, PlanNodeId, OutputBuffer, Function<Page, Page>, PagesSerdeFactory) - Constructor for class io.prestosql.operator.TaskOutputOperator.TaskOutputOperatorFactory
 
TaskResource - Class in io.prestosql.server
Manages tasks on this worker node
TaskResource(TaskManager, SessionPropertyManager, BoundedExecutor, ScheduledExecutorService) - Constructor for class io.prestosql.server.TaskResource
 
TaskSource - Class in io.prestosql.execution
 
TaskSource(PlanNodeId, Set<ScheduledSplit>, boolean) - Constructor for class io.prestosql.execution.TaskSource
 
TaskSource(PlanNodeId, Set<ScheduledSplit>, Set<Lifespan>, boolean) - Constructor for class io.prestosql.execution.TaskSource
 
TaskState - Enum in io.prestosql.execution
 
TaskStateMachine - Class in io.prestosql.execution
 
TaskStateMachine(TaskId, Executor) - Constructor for class io.prestosql.execution.TaskStateMachine
 
TaskStats - Class in io.prestosql.operator
 
TaskStats(DateTime, DateTime) - Constructor for class io.prestosql.operator.TaskStats
 
TaskStats(DateTime, DateTime, DateTime, DateTime, DateTime, Duration, Duration, int, int, int, int, int, int, int, double, DataSize, DataSize, DataSize, Duration, Duration, Duration, boolean, Set<BlockedReason>, DataSize, long, Duration, DataSize, long, DataSize, long, DataSize, long, DataSize, long, DataSize, int, Duration, List<PipelineStats>) - Constructor for class io.prestosql.operator.TaskStats
 
TaskStatus - Class in io.prestosql.execution
 
TaskStatus(TaskId, String, long, TaskState, URI, String, Set<Lifespan>, List<ExecutionFailureInfo>, int, int, boolean, DataSize, DataSize, DataSize, DataSize, long, Duration, long) - Constructor for class io.prestosql.execution.TaskStatus
 
TaskSystemTable - Class in io.prestosql.connector.system
 
TaskSystemTable(TaskManager, NodeInfo) - Constructor for class io.prestosql.connector.system.TaskSystemTable
 
TaskUpdateRequest - Class in io.prestosql.server
 
TaskUpdateRequest(SessionRepresentation, Map<String, String>, Optional<PlanFragment>, List<TaskSource>, OutputBuffers, OptionalInt) - Constructor for class io.prestosql.server.TaskUpdateRequest
 
taskWide() - Static method in class io.prestosql.execution.Lifespan
 
TDIGEST - Static variable in class io.prestosql.type.TDigestType
 
TDigestAggregationFunction - Class in io.prestosql.operator.aggregation
 
TDigestAndPercentileArrayState - Interface in io.prestosql.operator.aggregation.state
 
TDigestAndPercentileArrayStateFactory - Class in io.prestosql.operator.aggregation.state
 
TDigestAndPercentileArrayStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateFactory
 
TDigestAndPercentileArrayStateFactory.GroupedTDigestAndPercentileArrayState - Class in io.prestosql.operator.aggregation.state
 
TDigestAndPercentileArrayStateFactory.SingleTDigestAndPercentileArrayState - Class in io.prestosql.operator.aggregation.state
 
TDigestAndPercentileArrayStateSerializer - Class in io.prestosql.operator.aggregation.state
 
TDigestAndPercentileArrayStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.TDigestAndPercentileArrayStateSerializer
 
TDigestAndPercentileState - Interface in io.prestosql.operator.aggregation.state
 
TDigestAndPercentileStateFactory - Class in io.prestosql.operator.aggregation.state
 
TDigestAndPercentileStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateFactory
 
TDigestAndPercentileStateFactory.GroupedTDigestAndPercentileState - Class in io.prestosql.operator.aggregation.state
 
TDigestAndPercentileStateFactory.SingleTDigestAndPercentileState - Class in io.prestosql.operator.aggregation.state
 
TDigestAndPercentileStateSerializer - Class in io.prestosql.operator.aggregation.state
 
TDigestAndPercentileStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.TDigestAndPercentileStateSerializer
 
TDigestFunctions - Class in io.prestosql.operator.scalar
 
TDigestOperators - Class in io.prestosql.type
 
TDigestState - Interface in io.prestosql.operator.aggregation.state
 
TDigestStateFactory - Class in io.prestosql.operator.aggregation.state
 
TDigestStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.TDigestStateFactory
 
TDigestStateFactory.GroupedTDigestState - Class in io.prestosql.operator.aggregation.state
 
TDigestStateFactory.SingleTDigestState - Class in io.prestosql.operator.aggregation.state
 
TDigestStateSerializer - Class in io.prestosql.operator.aggregation.state
 
TDigestStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.TDigestStateSerializer
 
TDigestType - Class in io.prestosql.type
 
TERMINAL_BUFFER_STATES - Static variable in enum io.prestosql.execution.buffer.BufferState
 
TERMINAL_QUERY_STATES - Static variable in enum io.prestosql.execution.QueryState
 
TERMINAL_STAGE_STATES - Static variable in enum io.prestosql.execution.StageState
 
TERMINAL_TASK_STATES - Static variable in enum io.prestosql.execution.TaskState
 
TEST_TABLE_HANDLE - Static variable in class io.prestosql.testing.TestingHandles
 
TESTING_CATALOG - Static variable in class io.prestosql.testing.TestingSession
 
TestingAccessControlManager - Class in io.prestosql.testing
 
TestingAccessControlManager(TransactionManager, EventListenerManager) - Constructor for class io.prestosql.testing.TestingAccessControlManager
 
TestingAccessControlManager.TestingPrivilege - Class in io.prestosql.testing
 
TestingAccessControlManager.TestingPrivilegeType - Enum in io.prestosql.testing
 
TestingColumnHandle(String) - Constructor for class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
TestingColumnHandle(String, int, Type) - Constructor for class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
TestingColumnHandle(String, OptionalInt, Optional<Type>) - Constructor for class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
TestingConnectorContext - Class in io.prestosql.testing
 
TestingConnectorContext() - Constructor for class io.prestosql.testing.TestingConnectorContext
 
TestingConnectorSession - Class in io.prestosql.testing
 
TestingConnectorSession.Builder - Class in io.prestosql.testing
 
TestingEventListenerManager - Class in io.prestosql.testing
 
TestingEventListenerManager(EventListenerConfig) - Constructor for class io.prestosql.testing.TestingEventListenerManager
 
TestingFactory(boolean) - Constructor for class io.prestosql.operator.PagesIndex.TestingFactory
 
TestingGroupProvider - Class in io.prestosql.testing
 
TestingGroupProvider() - Constructor for class io.prestosql.testing.TestingGroupProvider
 
TestingHandle - Enum in io.prestosql.testing
 
TestingHandleResolver - Class in io.prestosql.testing
 
TestingHandleResolver() - Constructor for class io.prestosql.testing.TestingHandleResolver
 
TestingHandles - Class in io.prestosql.testing
 
TestingMetadata - Class in io.prestosql.testing
 
TestingMetadata() - Constructor for class io.prestosql.testing.TestingMetadata
 
TestingMetadata.TestingColumnHandle - Class in io.prestosql.testing
 
TestingMetadata.TestingTableHandle - Class in io.prestosql.testing
 
TestingNodeManager - Class in io.prestosql.testing
 
TestingNodeManager() - Constructor for class io.prestosql.testing.TestingNodeManager
 
TestingNodeManager(Node) - Constructor for class io.prestosql.testing.TestingNodeManager
 
TestingNodeManager(Node, Collection<Node>) - Constructor for class io.prestosql.testing.TestingNodeManager
 
TestingNodeManager(String) - Constructor for class io.prestosql.testing.TestingNodeManager
 
TestingNodeManager(String, Node, Collection<Node>) - Constructor for class io.prestosql.testing.TestingNodeManager
 
TestingNodeManager(List<Node>) - Constructor for class io.prestosql.testing.TestingNodeManager
 
TestingPageSinkProvider - Class in io.prestosql.testing
 
TestingPageSinkProvider() - Constructor for class io.prestosql.testing.TestingPageSinkProvider
 
TestingPrestoServer - Class in io.prestosql.server.testing
 
TestingPrestoServer.Builder - Class in io.prestosql.server.testing
 
TestingPrestoServer.TestShutdownAction - Class in io.prestosql.server.testing
 
TestingSession - Class in io.prestosql.testing
 
TestingSplit - Class in io.prestosql.testing
 
TestingSplit(boolean, List<HostAddress>) - Constructor for class io.prestosql.testing.TestingSplit
 
TestingSplitManager - Class in io.prestosql.testing
 
TestingSplitManager(List<ConnectorSplit>) - Constructor for class io.prestosql.testing.TestingSplitManager
 
TestingTableHandle() - Constructor for class io.prestosql.testing.TestingMetadata.TestingTableHandle
 
TestingTableHandle(SchemaTableName) - Constructor for class io.prestosql.testing.TestingMetadata.TestingTableHandle
 
TestingTaskContext - Class in io.prestosql.testing
 
TestingTaskContext.Builder - Class in io.prestosql.testing
 
TestingTransactionHandle - Class in io.prestosql.testing
 
TestingTransactionHandle(UUID) - Constructor for class io.prestosql.testing.TestingTransactionHandle
 
testingVersionEmbedder() - Static method in class io.prestosql.version.EmbedVersion
 
TestingWarningCollector - Class in io.prestosql.testing
 
TestingWarningCollector(WarningCollectorConfig, TestingWarningCollectorConfig) - Constructor for class io.prestosql.testing.TestingWarningCollector
 
TestingWarningCollectorConfig - Class in io.prestosql.testing
 
TestingWarningCollectorConfig() - Constructor for class io.prestosql.testing.TestingWarningCollectorConfig
 
TestingWarningCollectorFactory - Class in io.prestosql.testing
 
TestingWarningCollectorFactory(WarningCollectorConfig, TestingWarningCollectorConfig) - Constructor for class io.prestosql.testing.TestingWarningCollectorFactory
 
TestingWarningCollectorModule - Class in io.prestosql.testing
 
TestingWarningCollectorModule() - Constructor for class io.prestosql.testing.TestingWarningCollectorModule
 
testMask(Block, int) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
testSessionBuilder() - Static method in class io.prestosql.testing.TestingSession
 
testSessionBuilder(SessionPropertyManager) - Static method in class io.prestosql.testing.TestingSession
 
TestShutdownAction() - Constructor for class io.prestosql.server.testing.TestingPrestoServer.TestShutdownAction
 
textDistributedPlan(StageInfo, Metadata, Session, boolean) - Static method in class io.prestosql.sql.planner.planprinter.PlanPrinter
 
textDistributedPlan(StageInfo, ValuePrinter, boolean) - Static method in class io.prestosql.sql.planner.planprinter.PlanPrinter
 
textDistributedPlan(SubPlan, Metadata, Session, boolean) - Static method in class io.prestosql.sql.planner.planprinter.PlanPrinter
 
textIoPlan(Plan, Metadata, TypeOperators, Session) - Static method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter
 
textLogicalPlan(PlanNode, TypeProvider, Metadata, StatsAndCosts, Session, int, boolean) - Static method in class io.prestosql.sql.planner.planprinter.PlanPrinter
 
TextRenderer - Class in io.prestosql.sql.planner.planprinter
 
TextRenderer(boolean, int) - Constructor for class io.prestosql.sql.planner.planprinter.TextRenderer
 
ThreadResource - Class in io.prestosql.server
 
ThreadResource() - Constructor for class io.prestosql.server.ThreadResource
 
ThreadResource.Info - Class in io.prestosql.server
 
ThreadResource.StackLine - Class in io.prestosql.server
 
ThrowableMapper - Class in io.prestosql.server
 
ThrowableMapper(ServerConfig) - Constructor for class io.prestosql.server.ThrowableMapper
 
TIME_PATTERN - Static variable in class io.prestosql.type.DateTimes
 
TimeFunctions - Class in io.prestosql.operator.scalar.time
 
timeHasTimeZone(String) - Static method in class io.prestosql.type.DateTimes
 
timeMinusIntervalDayToSecond(long, long) - Static method in class io.prestosql.operator.scalar.time.TimeOperators
 
TimeMinusIntervalDayToSecond() - Constructor for class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.TimeMinusIntervalDayToSecond
 
TimeMinusTime() - Constructor for class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.TimeMinusTime
 
TimeOperators - Class in io.prestosql.operator.scalar.time
 
timePlusIntervalDayToSecond(long, long) - Static method in class io.prestosql.operator.scalar.time.TimeOperators
 
TimePlusIntervalDayToSecond() - Constructor for class io.prestosql.operator.scalar.timetz.TimeWithTimeZoneOperators.TimePlusIntervalDayToSecond
 
timestampHasTimeZone(String) - Static method in class io.prestosql.type.DateTimes
 
TimestampMinusIntervalDayToSecond() - Constructor for class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampMinusIntervalDayToSecond
 
TimestampMinusIntervalDayToSecond() - Constructor for class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampMinusIntervalDayToSecond
 
TimestampMinusIntervalYearToMonth() - Constructor for class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampMinusIntervalYearToMonth
 
TimestampMinusIntervalYearToMonth() - Constructor for class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampMinusIntervalYearToMonth
 
TimestampMinusTimestamp() - Constructor for class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampMinusTimestamp
 
TimestampMinusTimestamp() - Constructor for class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampMinusTimestamp
 
TimestampOperators - Class in io.prestosql.operator.scalar.timestamp
 
TimestampOperators.IntervalDayToSecondPlusTimestamp - Class in io.prestosql.operator.scalar.timestamp
 
TimestampOperators.IntervalYearToMonthPlusTimestamp - Class in io.prestosql.operator.scalar.timestamp
 
TimestampOperators.TimestampMinusIntervalDayToSecond - Class in io.prestosql.operator.scalar.timestamp
 
TimestampOperators.TimestampMinusIntervalYearToMonth - Class in io.prestosql.operator.scalar.timestamp
 
TimestampOperators.TimestampMinusTimestamp - Class in io.prestosql.operator.scalar.timestamp
 
TimestampOperators.TimestampPlusIntervalDayToSecond - Class in io.prestosql.operator.scalar.timestamp
 
TimestampOperators.TimestampPlusIntervalYearToMonth - Class in io.prestosql.operator.scalar.timestamp
 
TimestampPlusIntervalDayToSecond() - Constructor for class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampPlusIntervalDayToSecond
 
TimestampPlusIntervalDayToSecond() - Constructor for class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampPlusIntervalDayToSecond
 
TimestampPlusIntervalYearToMonth() - Constructor for class io.prestosql.operator.scalar.timestamp.TimestampOperators.TimestampPlusIntervalYearToMonth
 
TimestampPlusIntervalYearToMonth() - Constructor for class io.prestosql.operator.scalar.timestamptz.TimestampWithTimeZoneOperators.TimestampPlusIntervalYearToMonth
 
TimestampToDateCast - Class in io.prestosql.operator.scalar.timestamp
 
TimestampToJsonCast - Class in io.prestosql.operator.scalar.timestamp
 
TimestampToTimeCast - Class in io.prestosql.operator.scalar.timestamp
 
TimestampToTimestampCast - Class in io.prestosql.operator.scalar.timestamp
 
TimestampToTimestampWithTimeZoneCast - Class in io.prestosql.operator.scalar.timestamp
 
TimestampToTimeWithTimeZoneCast - Class in io.prestosql.operator.scalar.timestamp
 
TimestampToVarcharCast - Class in io.prestosql.operator.scalar.timestamp
 
TimestampWithTimeZoneOperators - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneOperators.IntervalDayToSecondPlusTimestamp - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneOperators.IntervalYearToMonthPlusTimestamp - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneOperators.TimestampMinusIntervalDayToSecond - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneOperators.TimestampMinusIntervalYearToMonth - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneOperators.TimestampMinusTimestamp - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneOperators.TimestampPlusIntervalDayToSecond - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneOperators.TimestampPlusIntervalYearToMonth - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneToDateCast - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneToTimeCast - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneToTimestampCast - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneToTimestampWithTimeZoneCast - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneToTimeWithTimeZoneCast - Class in io.prestosql.operator.scalar.timestamptz
 
TimestampWithTimeZoneToVarcharCast - Class in io.prestosql.operator.scalar.timestamptz
 
TimeToTimestampCast - Class in io.prestosql.operator.scalar.time
 
TimeToTimestampWithTimeZoneCast - Class in io.prestosql.operator.scalar.time
 
TimeToTimeWithTimeZoneCast - Class in io.prestosql.operator.scalar.time
 
TimeWithTimeZoneOperators - Class in io.prestosql.operator.scalar.timetz
 
TimeWithTimeZoneOperators.IntervalDayToSecondPlusTime - Class in io.prestosql.operator.scalar.timetz
 
TimeWithTimeZoneOperators.TimeMinusIntervalDayToSecond - Class in io.prestosql.operator.scalar.timetz
 
TimeWithTimeZoneOperators.TimeMinusTime - Class in io.prestosql.operator.scalar.timetz
 
TimeWithTimeZoneOperators.TimePlusIntervalDayToSecond - Class in io.prestosql.operator.scalar.timetz
 
TimeWithTimeZoneToTimeCast - Class in io.prestosql.operator.scalar.timetz
 
TimeWithTimeZoneToTimestampCast - Class in io.prestosql.operator.scalar.timestamp
 
TimeWithTimeZoneToTimestampWithTimeZoneCast - Class in io.prestosql.operator.scalar.timetz
 
TimeWithTimeZoneToTimeWithTimeZoneCast - Class in io.prestosql.operator.scalar.timetz
 
TimeWithTimeZoneToVarcharCast - Class in io.prestosql.operator.scalar.timetz
 
TimeZoneHour - Class in io.prestosql.operator.scalar.timestamptz
 
TimeZoneHour - Class in io.prestosql.operator.scalar.timetz
 
TimeZoneMinute - Class in io.prestosql.operator.scalar.timestamptz
 
TimeZoneMinute - Class in io.prestosql.operator.scalar.timetz
 
TINYINT_TO_DECIMAL_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
TINYINT_TO_DECIMAL_SATURATED_FLOOR_CAST - Static variable in class io.prestosql.type.DecimalSaturatedFloorCasts
 
TinyintOperators - Class in io.prestosql.type
 
tinyintToLongDecimal(long, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
tinyintToShortDecimal(long, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
toArray(ArrayType, JsonUtil.BlockBuilderAppender, ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.JsonToArrayCast
 
toBase(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
toBase64(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
toBase64Url(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
toBasicStageStats(StageState) - Method in class io.prestosql.execution.StageStats
 
toBigEndian32(long) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
toBigEndian64(long) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
toConnectorSession() - Method in class io.prestosql.Session
 
toConnectorSession(CatalogName) - Method in class io.prestosql.Session
 
toConnectorSession(String) - Method in class io.prestosql.Session
 
toDataProvider() - Static method in class io.prestosql.testing.DataProviders
 
toDoubleExact(long) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
toEpochMicros(long, int) - Static method in class io.prestosql.type.DateTimes
 
toException() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
toExpression() - Method in class io.prestosql.sql.planner.plan.JoinNode.EquiJoinClause
 
toExpression(Object, Type) - Method in class io.prestosql.sql.planner.LiteralEncoder
 
toExpressions(List<?>, List<? extends Type>) - Method in class io.prestosql.sql.planner.LiteralEncoder
 
toFailure(Throwable) - Static method in class io.prestosql.util.Failures
 
toFailureInfo() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
toFailures(Collection<? extends Throwable>) - Static method in class io.prestosql.util.Failures
 
toFastutilHashSet(Set<?>, Type, MethodHandle, MethodHandle) - Static method in class io.prestosql.util.FastutilSetHelper
 
toFunctionBinding(FunctionId, BoundSignature, Signature) - Static method in class io.prestosql.metadata.MetadataManager
 
toFunctionId(Signature) - Static method in class io.prestosql.metadata.FunctionId
 
toHex(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
toIEEE754Binary32(long) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
toIEEE754Binary64(double) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
toIso8601(long, long) - Static method in class io.prestosql.operator.scalar.timestamp.ToIso8601
 
toIso8601(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.ToIso8601
 
toIso8601(long, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ToIso8601
 
toIso8601(long, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ToIso8601
 
ToIso8601 - Class in io.prestosql.operator.scalar.timestamp
 
ToIso8601 - Class in io.prestosql.operator.scalar.timestamptz
 
toISO8601FromDate(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
toJoinNodeType() - Method in enum io.prestosql.sql.planner.plan.CorrelatedJoinNode.Type
 
toJson(JsonUtil.JsonGeneratorWriter, Block) - Static method in class io.prestosql.operator.scalar.ArrayToJsonCast
 
toJson(JsonUtil.ObjectKeyProvider, JsonUtil.JsonGeneratorWriter, Block) - Static method in class io.prestosql.operator.scalar.MapToJsonCast
 
toJson(List<JsonUtil.JsonGeneratorWriter>, Block) - Static method in class io.prestosql.operator.scalar.RowToJsonCast
 
toLocalDateTime(TimestampType, Block, int) - Static method in class io.prestosql.type.DateTimes
 
toMap(MapType, JsonUtil.BlockBuilderAppender, ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.JsonToMapCast
 
toMilliseconds(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
toPage() - Method in class io.prestosql.testing.MaterializedResult
 
toPlanCost() - Method in class io.prestosql.cost.LocalCostEstimate
Deprecated.
This class represents individual cost of a part of a plan (usually of a single PlanNode). Use CostProvider instead.
topN() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
TopN() - Constructor for class io.prestosql.sql.planner.plan.Patterns.TopN
 
TopNNode - Class in io.prestosql.sql.planner.plan
 
TopNNode(PlanNodeId, PlanNode, long, OrderingScheme, TopNNode.Step) - Constructor for class io.prestosql.sql.planner.plan.TopNNode
 
TopNNode.Step - Enum in io.prestosql.sql.planner.plan
 
TopNOperator - Class in io.prestosql.operator
Returns the top N rows from the source sorted according to the specified ordering in the keyChannelIndex channel.
TopNProcessor - Class in io.prestosql.operator
Returns the top N rows from the source sorted according to the specified ordering in the keyChannelIndex channel.
TopNProcessor(AggregatedMemoryContext, List<Type>, int, List<Integer>, List<SortOrder>, TypeOperators) - Constructor for class io.prestosql.operator.TopNProcessor
 
topNRowNumber() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
TopNRowNumberNode - Class in io.prestosql.sql.planner.plan
 
TopNRowNumberNode(PlanNodeId, PlanNode, WindowNode.Specification, Symbol, int, boolean, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.TopNRowNumberNode
 
TopNRowNumberOperator - Class in io.prestosql.operator
 
TopNRowNumberOperator(OperatorContext, List<? extends Type>, List<Integer>, List<Integer>, List<Type>, List<Integer>, List<SortOrder>, int, boolean, Optional<Integer>, int, JoinCompiler, TypeOperators, BlockTypeOperators) - Constructor for class io.prestosql.operator.TopNRowNumberOperator
 
TopNRowNumberOperator.TopNRowNumberOperatorFactory - Class in io.prestosql.operator
 
TopNRowNumberOperatorFactory(int, PlanNodeId, List<? extends Type>, List<Integer>, List<Integer>, List<? extends Type>, List<Integer>, List<SortOrder>, int, boolean, Optional<Integer>, int, JoinCompiler, TypeOperators, BlockTypeOperators) - Constructor for class io.prestosql.operator.TopNRowNumberOperator.TopNRowNumberOperatorFactory
 
TopNStatsRule - Class in io.prestosql.cost
 
TopNStatsRule(StatsNormalizer) - Constructor for class io.prestosql.cost.TopNStatsRule
 
TOPOLOGY - io.prestosql.execution.scheduler.NodeSchedulerConfig.NodeSchedulerPolicy
 
TopologyAwareNodeSelector - Class in io.prestosql.execution.scheduler
 
TopologyAwareNodeSelector(InternalNodeManager, NodeTaskMap, boolean, Supplier<NodeMap>, int, int, int, List<CounterStat>, NetworkTopology) - Constructor for class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
TopologyAwareNodeSelectorConfig - Class in io.prestosql.execution.scheduler
 
TopologyAwareNodeSelectorConfig() - Constructor for class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig
 
TopologyAwareNodeSelectorConfig.TopologyType - Enum in io.prestosql.execution.scheduler
 
TopologyAwareNodeSelectorFactory - Class in io.prestosql.execution.scheduler
 
TopologyAwareNodeSelectorFactory(NetworkTopology, InternalNodeManager, NodeSchedulerConfig, NodeTaskMap, TopologyAwareNodeSelectorConfig) - Constructor for class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorFactory
 
TopologyAwareNodeSelectorModule - Class in io.prestosql.execution.scheduler
 
TopologyAwareNodeSelectorModule() - Constructor for class io.prestosql.execution.scheduler.TopologyAwareNodeSelectorModule
 
TopologyFileConfig - Class in io.prestosql.execution.scheduler
 
TopologyFileConfig() - Constructor for class io.prestosql.execution.scheduler.TopologyFileConfig
 
toPredicate(TupleDomain<Symbol>) - Method in class io.prestosql.sql.planner.DomainTranslator
 
toQualifiedName() - Method in class io.prestosql.metadata.ResolvedFunction
 
toResponse(Throwable) - Method in class io.prestosql.server.ThrowableMapper
 
toRow(RowType, JsonUtil.BlockBuilderAppender, ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.JsonToRowCast
 
toSecurityContext() - Method in class io.prestosql.Session
 
toSession(SessionPropertyManager) - Method in class io.prestosql.SessionRepresentation
 
toSession(SessionPropertyManager, Map<String, String>) - Method in class io.prestosql.SessionRepresentation
 
toSessionRepresentation() - Method in class io.prestosql.Session
 
toSignature() - Method in class io.prestosql.metadata.BoundSignature
 
toSortItems() - Method in class io.prestosql.sql.planner.OrderingScheme
 
toSqlType(Type) - Static method in class io.prestosql.sql.analyzer.TypeSignatureTranslator
 
toStackTraceElement(String) - Static method in class io.prestosql.execution.ExecutionFailureInfo
 
toString() - Method in class io.prestosql.connector.CatalogName
 
toString() - Method in class io.prestosql.connector.informationschema.InformationSchemaColumnHandle
 
toString() - Method in class io.prestosql.connector.informationschema.InformationSchemaTableHandle
 
toString() - Method in class io.prestosql.connector.informationschema.InformationSchemaTransactionHandle
 
toString() - Method in class io.prestosql.connector.system.GlobalSystemTransactionHandle
 
toString() - Method in class io.prestosql.connector.system.SystemColumnHandle
 
toString() - Method in class io.prestosql.connector.system.SystemSplit
 
toString() - Method in class io.prestosql.connector.system.SystemTableHandle
 
toString() - Method in class io.prestosql.connector.system.SystemTransactionHandle
 
toString() - Method in class io.prestosql.cost.LocalCostEstimate
 
toString() - Method in class io.prestosql.cost.PlanCostEstimate
 
toString() - Method in class io.prestosql.cost.PlanNodeStatsEstimate
 
toString() - Method in class io.prestosql.cost.StatisticRange
 
toString() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
toString() - Method in class io.prestosql.execution.buffer.BufferInfo
 
toString() - Method in class io.prestosql.execution.buffer.BufferResult
 
toString() - Method in class io.prestosql.execution.buffer.OutputBufferInfo
 
toString() - Method in class io.prestosql.execution.buffer.OutputBuffers.OutputBufferId
 
toString() - Method in class io.prestosql.execution.buffer.OutputBuffers
 
toString() - Method in class io.prestosql.execution.buffer.PageBufferInfo
 
toString() - Method in class io.prestosql.execution.buffer.PageCodecMarker.MarkerSet
 
toString() - Method in class io.prestosql.execution.buffer.SerializedPage
 
toString() - Method in class io.prestosql.execution.Column
 
toString() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
toString() - Method in class io.prestosql.execution.executor.Priority
 
toString() - Method in class io.prestosql.execution.executor.TaskExecutor
 
toString() - Method in class io.prestosql.execution.executor.TaskHandle
 
toString() - Method in exception io.prestosql.execution.Failure
 
toString() - Method in class io.prestosql.execution.Input
 
toString() - Method in class io.prestosql.execution.Lifespan
 
toString() - Method in class io.prestosql.execution.NodeTaskMap.PartitionedSplitCountTracker
 
toString() - Method in class io.prestosql.execution.QueryInfo
 
toString() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
toString() - Method in class io.prestosql.execution.ScheduledSplit
 
toString() - Method in class io.prestosql.execution.scheduler.NetworkLocation
 
toString() - Method in class io.prestosql.execution.scheduler.ScheduleResult
 
toString() - Method in class io.prestosql.execution.SqlStageExecution
 
toString() - Method in class io.prestosql.execution.SqlTask
 
toString() - Method in class io.prestosql.execution.SqlTaskExecution
 
toString() - Method in class io.prestosql.execution.StageId
 
toString() - Method in class io.prestosql.execution.StageInfo
 
toString() - Method in class io.prestosql.execution.StageStateMachine
 
toString() - Method in class io.prestosql.execution.StateMachine
 
toString() - Method in class io.prestosql.execution.TaskId
 
toString() - Method in class io.prestosql.execution.TaskInfo
 
toString() - Method in class io.prestosql.execution.TaskSource
 
toString() - Method in class io.prestosql.execution.TaskStateMachine
 
toString() - Method in class io.prestosql.execution.TaskStatus
 
toString() - Method in class io.prestosql.FullConnectorSession
 
toString() - Method in class io.prestosql.memory.ClusterMemoryPool
 
toString() - Method in class io.prestosql.memory.LowMemoryKiller.QueryMemoryInfo
 
toString() - Method in class io.prestosql.memory.MemoryInfo
 
toString() - Method in class io.prestosql.memory.MemoryPool
 
toString() - Method in class io.prestosql.memory.MemoryPoolAssignment
 
toString() - Method in class io.prestosql.memory.MemoryPoolAssignmentsRequest
 
toString() - Method in class io.prestosql.memory.VersionedMemoryPoolId
 
toString() - Method in class io.prestosql.metadata.AggregationFunctionMetadata
 
toString() - Method in class io.prestosql.metadata.AnalyzeTableHandle
 
toString() - Method in class io.prestosql.metadata.BoundSignature
 
toString() - Method in class io.prestosql.metadata.Catalog
 
toString() - Method in class io.prestosql.metadata.CatalogMetadata
 
toString() - Method in class io.prestosql.metadata.FunctionArgumentDefinition
 
toString() - Method in class io.prestosql.metadata.FunctionDependencies.FunctionKey
 
toString() - Method in class io.prestosql.metadata.FunctionDependencies.OperatorKey
 
toString() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.CastDependency
 
toString() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.FunctionDependency
 
toString() - Method in class io.prestosql.metadata.FunctionDependencyDeclaration.OperatorDependency
 
toString() - Method in class io.prestosql.metadata.FunctionId
 
toString() - Method in class io.prestosql.metadata.FunctionMetadata
 
toString() - Method in class io.prestosql.metadata.IndexHandle
 
toString() - Method in class io.prestosql.metadata.InsertTableHandle
 
toString() - Method in class io.prestosql.metadata.InternalNode
 
toString() - Method in class io.prestosql.metadata.LongVariableConstraint
 
toString() - Method in class io.prestosql.metadata.NewTableLayout
 
toString() - Method in class io.prestosql.metadata.OutputTableHandle
 
toString() - Method in class io.prestosql.metadata.QualifiedObjectName
 
toString() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
toString() - Method in class io.prestosql.metadata.ResolvedFunction
 
toString() - Method in class io.prestosql.metadata.Signature
 
toString() - Method in class io.prestosql.metadata.Split
 
toString() - Method in class io.prestosql.metadata.TableHandle
 
toString() - Method in class io.prestosql.metadata.TypeVariableConstraint
 
toString() - Method in class io.prestosql.operator.DriverYieldSignal
 
toString() - Method in class io.prestosql.operator.ExchangeClientStatus
 
toString() - Method in class io.prestosql.operator.GroupByIdBlock
 
toString() - Method in class io.prestosql.operator.HttpPageBufferClient.PagesResponse
 
toString() - Method in class io.prestosql.operator.HttpPageBufferClient
 
toString() - Method in class io.prestosql.operator.InterpretedHashGenerator
 
toString() - Method in class io.prestosql.operator.JoinOperatorInfo
 
toString() - Method in class io.prestosql.operator.LookupJoinPageBuilder
 
toString() - Method in class io.prestosql.operator.NestedLoopJoinPagesBuilder
 
toString() - Method in class io.prestosql.operator.OperatorContext
 
toString() - Method in class io.prestosql.operator.PageBufferClientStatus
 
toString() - Method in class io.prestosql.operator.PagesIndex
 
toString() - Method in class io.prestosql.operator.PartitionedOutputOperator.PartitionedOutputInfo
 
toString() - Method in class io.prestosql.operator.PrecomputedHashGenerator
 
toString() - Method in class io.prestosql.operator.project.CursorProcessorOutput
 
toString() - Method in class io.prestosql.operator.project.GeneratedPageProjection
 
toString() - Method in class io.prestosql.operator.project.InputChannels
 
toString() - Method in class io.prestosql.operator.scalar.JsonPath
 
toString() - Method in class io.prestosql.operator.scalar.JsonPathTokenizer
 
toString() - Method in class io.prestosql.operator.TableWriterOperator.TableWriterInfo
 
toString() - Method in class io.prestosql.operator.window.FrameInfo
 
toString() - Method in class io.prestosql.operator.window.PagesWindowIndex
 
toString() - Method in class io.prestosql.security.SecurityContext
 
toString() - Method in class io.prestosql.server.BasicQueryInfo
 
toString() - Method in class io.prestosql.server.protocol.QueryResultRows
 
toString() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
toString() - Method in class io.prestosql.server.security.InternalPrincipal
 
toString() - Method in class io.prestosql.server.TaskUpdateRequest
 
toString() - Method in class io.prestosql.Session
 
toString() - Method in class io.prestosql.spiller.AesSpillCipher
 
toString() - Method in class io.prestosql.spiller.SpillSpaceTracker
 
toString() - Method in class io.prestosql.split.ConnectorAwareSplitSource
 
toString() - Method in class io.prestosql.split.RemoteSplit
 
toString() - Method in class io.prestosql.sql.analyzer.Analysis.AccessControlInfo
 
toString() - Method in class io.prestosql.sql.analyzer.CanonicalizationAware
 
toString() - Method in class io.prestosql.sql.analyzer.Field
 
toString() - Method in class io.prestosql.sql.analyzer.FieldId
 
toString() - Method in class io.prestosql.sql.analyzer.RelationId
 
toString() - Method in class io.prestosql.sql.analyzer.RelationType
 
toString() - Method in class io.prestosql.sql.analyzer.Scope
 
toString() - Method in class io.prestosql.sql.analyzer.TypeSignatureProvider
 
toString() - Method in class io.prestosql.sql.DynamicFilters.Descriptor
 
toString() - Method in class io.prestosql.sql.gen.Binding
 
toString() - Method in class io.prestosql.sql.gen.CallSiteBinder
 
toString() - Method in class io.prestosql.sql.planner.LocalDynamicFilterConsumer
 
toString() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
toString() - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
toString() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
toString() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
toString() - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
toString() - Method in class io.prestosql.sql.planner.OrderingScheme
 
toString() - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
toString() - Method in class io.prestosql.sql.planner.Partitioning
 
toString() - Method in class io.prestosql.sql.planner.PartitioningHandle
 
toString() - Method in class io.prestosql.sql.planner.PartitioningScheme
 
toString() - Method in class io.prestosql.sql.planner.plan.DynamicFilterId
 
toString() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode.EquiJoinClause
 
toString() - Method in class io.prestosql.sql.planner.plan.JoinNode.EquiJoinClause
 
toString() - Method in class io.prestosql.sql.planner.plan.PlanFragmentId
 
toString() - Method in class io.prestosql.sql.planner.plan.PlanNodeId
 
toString() - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
toString() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode.WriteStatisticsHandle
 
toString() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode.WriteStatisticsReference
 
toString() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode.WriteStatisticsTarget
 
toString() - Method in class io.prestosql.sql.planner.plan.TableScanNode
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateReference
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateTarget
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.DeleteTarget
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertReference
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertTarget
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewReference
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.RefreshMaterializedViewTarget
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.WriterTarget
 
toString() - Method in class io.prestosql.sql.planner.PlanFragment
 
toString() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.ColumnConstraint
 
toString() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.EstimatedStatsAndCost
 
toString() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedDomain
 
toString() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedMarker
 
toString() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.FormattedRange
 
toString() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan.TableColumnInfo
 
toString() - Method in class io.prestosql.sql.planner.planprinter.IoPlanPrinter.IoPlan
 
toString() - Method in class io.prestosql.sql.planner.ScopeAware
 
toString() - Method in class io.prestosql.sql.planner.SortExpressionContext
 
toString() - Method in class io.prestosql.sql.planner.StageExecutionPlan
 
toString() - Method in class io.prestosql.sql.planner.Symbol
 
toString() - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
toString() - Method in class io.prestosql.sql.relational.CallExpression
 
toString() - Method in class io.prestosql.sql.relational.ConstantExpression
 
toString() - Method in class io.prestosql.sql.relational.InputReferenceExpression
 
toString() - Method in class io.prestosql.sql.relational.LambdaDefinitionExpression
 
toString() - Method in class io.prestosql.sql.relational.RowExpression
 
toString() - Method in class io.prestosql.sql.relational.SpecialForm
 
toString() - Method in class io.prestosql.sql.relational.VariableReferenceExpression
 
toString() - Method in class io.prestosql.sql.SqlPath
 
toString() - Method in class io.prestosql.sql.SqlPathElement
 
toString() - Method in class io.prestosql.testing.MaterializedResult
 
toString() - Method in class io.prestosql.testing.MaterializedRow
 
toString() - Method in class io.prestosql.testing.TestingAccessControlManager.TestingPrivilege
 
toString() - Method in class io.prestosql.testing.TestingConnectorSession
 
toString() - Method in class io.prestosql.testing.TestingTransactionHandle
 
toString() - Method in class io.prestosql.transaction.TransactionId
 
toString() - Method in class io.prestosql.type.JoniRegexp
 
toString() - Method in class io.prestosql.type.Re2JRegexp
 
toString() - Method in class io.prestosql.type.SqlIntervalDayTime
 
toString() - Method in class io.prestosql.type.SqlIntervalYearMonth
 
toStringValue() - Method in enum io.prestosql.connector.informationschema.InformationSchemaTable
 
toSummaryString(byte) - Static method in enum io.prestosql.execution.buffer.PageCodecMarker
 
toSymbolReference() - Method in class io.prestosql.sql.planner.Symbol
 
toSystemColumnHandles(ConnectorTableMetadata) - Static method in class io.prestosql.connector.system.SystemColumnHandle
 
toSystemSecurityContext() - Method in class io.prestosql.security.SecurityContext
 
TOTAL_RESERVATION - io.prestosql.memory.MemoryManagerConfig.LowMemoryKillerPolicy
 
TOTAL_RESERVATION_ON_BLOCKED_NODES - io.prestosql.memory.MemoryManagerConfig.LowMemoryKillerPolicy
 
TotalReservationLowMemoryKiller - Class in io.prestosql.memory
 
TotalReservationLowMemoryKiller() - Constructor for class io.prestosql.memory.TotalReservationLowMemoryKiller
 
TotalReservationOnBlockedNodesLowMemoryKiller - Class in io.prestosql.memory
 
TotalReservationOnBlockedNodesLowMemoryKiller() - Constructor for class io.prestosql.memory.TotalReservationOnBlockedNodesLowMemoryKiller
 
totalSpilledBytes - Variable in class io.prestosql.spiller.SpillerStats
 
toTestTypes() - Method in class io.prestosql.testing.MaterializedResult
Converts this MaterializedResult to a new one, representing the data using the same type domain as returned by TestingPrestoClient.
toTypes(List<? extends Type>, AggregationNode.Step, List<AccumulatorFactory>, Optional<Integer>) - Static method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
toTypeSignature(DataType) - Static method in class io.prestosql.sql.analyzer.TypeSignatureTranslator
 
toUnixTime(long) - Static method in class io.prestosql.operator.scalar.timestamp.ToUnixTime
 
toUnixTime(long, long) - Static method in class io.prestosql.operator.scalar.timestamptz.ToUnixTime
 
toUnixTime(LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.ToUnixTime
 
toUnixTime(LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.ToUnixTime
 
ToUnixTime - Class in io.prestosql.operator.scalar.timestamp
 
ToUnixTime - Class in io.prestosql.operator.scalar.timestamptz
 
toUtf8(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
toWhenHasSplitQueueSpaceFuture(List<RemoteTask>, int) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
toWhenHasSplitQueueSpaceFuture(Set<InternalNode>, List<RemoteTask>, int) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
toZonedDateTime(TimestampWithTimeZoneType, Block, int) - Static method in class io.prestosql.type.DateTimes
 
trace(PlanNode, Set<Symbol>) - Static method in class io.prestosql.sql.planner.optimizations.IndexJoinOptimizer.IndexKeyTracer
 
TrackingLookupSourceSupplier - Interface in io.prestosql.operator
 
trackQueryStats(DispatchQuery) - Method in class io.prestosql.execution.QueryManagerStats
 
trackQueryStats(QueryExecution) - Method in class io.prestosql.execution.QueryManagerStats
 
transaction(TransactionManager, AccessControl) - Static method in class io.prestosql.transaction.TransactionBuilder
 
TransactionBuilder - Class in io.prestosql.transaction
 
transactionExists(TransactionId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
transactionExists(TransactionId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
transactionExists(TransactionId) - Method in interface io.prestosql.transaction.TransactionManager
 
transactionHandleModule(HandleResolver) - Static method in class io.prestosql.metadata.HandleJsonModule
 
TransactionId - Class in io.prestosql.transaction
 
TransactionInfo - Class in io.prestosql.transaction
 
TransactionInfo(TransactionId, IsolationLevel, boolean, boolean, DateTime, Duration, List<CatalogName>, Optional<CatalogName>) - Constructor for class io.prestosql.transaction.TransactionInfo
 
TransactionManager - Interface in io.prestosql.transaction
 
TransactionManagerConfig - Class in io.prestosql.transaction
 
TransactionManagerConfig() - Constructor for class io.prestosql.transaction.TransactionManagerConfig
 
TRANSACTIONS_TABLE_NAME - Static variable in class io.prestosql.connector.system.TransactionsSystemTable
 
TransactionsSystemTable - Class in io.prestosql.connector.system
 
TransactionsSystemTable(Metadata, TransactionManager) - Constructor for class io.prestosql.connector.system.TransactionsSystemTable
 
transform(WorkProcessor.Transformation<T, R>) - Method in interface io.prestosql.operator.WorkProcessor
TransformCorrelatedDistinctAggregationWithoutProjection - Class in io.prestosql.sql.planner.iterative.rule
This rule decorrelates a correlated subquery of LEFT correlated join with distinct operator (grouped aggregation with no aggregation assignments) It is similar to TransformCorrelatedDistinctAggregationWithProjection rule, but does not support projection over aggregation in the subquery
TransformCorrelatedDistinctAggregationWithoutProjection(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedDistinctAggregationWithoutProjection
 
TransformCorrelatedDistinctAggregationWithProjection - Class in io.prestosql.sql.planner.iterative.rule
This rule decorrelates a correlated subquery of LEFT correlated join with distinct operator (grouped aggregation with no aggregation assignments)
TransformCorrelatedDistinctAggregationWithProjection(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedDistinctAggregationWithProjection
 
TransformCorrelatedGlobalAggregationWithoutProjection - Class in io.prestosql.sql.planner.iterative.rule
This rule decorrelates a correlated subquery with: - single global aggregation, or - global aggregation over distinct operator (grouped aggregation with no aggregation assignments) It is similar to TransformCorrelatedGlobalAggregationWithProjection rule, but does not support projection over aggregation in the subquery
TransformCorrelatedGlobalAggregationWithoutProjection(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGlobalAggregationWithoutProjection
 
TransformCorrelatedGlobalAggregationWithProjection - Class in io.prestosql.sql.planner.iterative.rule
This rule decorrelates a correlated subquery of LEFT or INNER correlated join with: - single global aggregation, or - global aggregation over distinct operator (grouped aggregation with no aggregation assignments)
TransformCorrelatedGlobalAggregationWithProjection(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGlobalAggregationWithProjection
 
TransformCorrelatedGroupedAggregationWithoutProjection - Class in io.prestosql.sql.planner.iterative.rule
This rule decorrelates a correlated subquery of INNER correlated join with: - single grouped aggregation, or - grouped aggregation over distinct operator (grouped aggregation with no aggregation assignments) It is similar to TransformCorrelatedGroupedAggregationWithProjection rule, but does not support projection over aggregation in the subquery
TransformCorrelatedGroupedAggregationWithoutProjection(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGroupedAggregationWithoutProjection
 
TransformCorrelatedGroupedAggregationWithProjection - Class in io.prestosql.sql.planner.iterative.rule
This rule decorrelates a correlated subquery of INNER correlated join with: - single grouped aggregation, or - grouped aggregation over distinct operator (grouped aggregation with no aggregation assignments)
TransformCorrelatedGroupedAggregationWithProjection(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedGroupedAggregationWithProjection
 
TransformCorrelatedInPredicateToJoin - Class in io.prestosql.sql.planner.iterative.rule
Replaces correlated ApplyNode with InPredicate expression with SemiJoin
TransformCorrelatedInPredicateToJoin(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin
 
TransformCorrelatedJoinToJoin - Class in io.prestosql.sql.planner.iterative.rule
Tries to decorrelate subquery and rewrite it using normal join.
TransformCorrelatedJoinToJoin(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedJoinToJoin
 
TransformCorrelatedScalarSubquery - Class in io.prestosql.sql.planner.iterative.rule
Scalar filter scan query is something like:
TransformCorrelatedScalarSubquery(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedScalarSubquery
 
TransformCorrelatedSingleRowSubqueryToProject - Class in io.prestosql.sql.planner.iterative.rule
This optimizer can rewrite correlated single row subquery to projection in a way described here: From:
TransformCorrelatedSingleRowSubqueryToProject() - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedSingleRowSubqueryToProject
 
TransformExistsApplyToCorrelatedJoin - Class in io.prestosql.sql.planner.iterative.rule
EXISTS is modeled as (if correlated predicates are equality comparisons):
TransformExistsApplyToCorrelatedJoin(Metadata) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformExistsApplyToCorrelatedJoin
 
TransformFilteringSemiJoinToInnerJoin - Class in io.prestosql.sql.planner.iterative.rule
Rewrite filtering semi-join to inner join.
TransformFilteringSemiJoinToInnerJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformFilteringSemiJoinToInnerJoin
 
transformProcessor(Function<WorkProcessor<T>, WorkProcessor<R>>) - Method in interface io.prestosql.operator.WorkProcessor
 
TransformQuantifiedComparisonApplyToCorrelatedJoin - Class in io.prestosql.sql.planner.optimizations
 
TransformQuantifiedComparisonApplyToCorrelatedJoin(Metadata) - Constructor for class io.prestosql.sql.planner.optimizations.TransformQuantifiedComparisonApplyToCorrelatedJoin
 
TransformUncorrelatedInPredicateSubqueryToSemiJoin - Class in io.prestosql.sql.planner.iterative.rule
This optimizers looks for InPredicate expressions in ApplyNodes and replaces the nodes with SemiJoin nodes.
TransformUncorrelatedInPredicateSubqueryToSemiJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedInPredicateSubqueryToSemiJoin
 
TransformUncorrelatedSubqueryToJoin - Class in io.prestosql.sql.planner.iterative.rule
 
TransformUncorrelatedSubqueryToJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedSubqueryToJoin
 
TransformWork<I,​O> - Class in io.prestosql.operator
 
TransformWork(Work<I>, Function<I, O>) - Constructor for class io.prestosql.operator.TransformWork
 
transitionToAborted() - Method in class io.prestosql.execution.StageStateMachine
 
transitionToCanceled() - Method in class io.prestosql.execution.QueryStateMachine
 
transitionToCanceled() - Method in class io.prestosql.execution.StageStateMachine
 
transitionToDispatching() - Method in class io.prestosql.execution.QueryStateMachine
 
transitionToFailed(Throwable) - Method in class io.prestosql.execution.QueryStateMachine
 
transitionToFailed(Throwable) - Method in class io.prestosql.execution.StageStateMachine
 
transitionToFinished() - Method in class io.prestosql.execution.StageStateMachine
 
transitionToFinishing() - Method in class io.prestosql.execution.QueryStateMachine
 
transitionToFlushing() - Method in class io.prestosql.execution.StageStateMachine
 
transitionToFlushing() - Method in class io.prestosql.execution.TaskStateMachine
 
transitionToPlanning() - Method in class io.prestosql.execution.QueryStateMachine
 
transitionToRunning() - Method in class io.prestosql.execution.QueryStateMachine
 
transitionToRunning() - Method in class io.prestosql.execution.StageStateMachine
 
transitionToScheduled() - Method in class io.prestosql.execution.StageStateMachine
 
transitionToScheduling() - Method in class io.prestosql.execution.StageStateMachine
 
transitionToSchedulingSplits() - Method in class io.prestosql.execution.SqlStageExecution
 
transitionToSchedulingSplits() - Method in class io.prestosql.execution.StageStateMachine
 
transitionToStarting() - Method in class io.prestosql.execution.QueryStateMachine
 
transitionToWaitingForResources() - Method in class io.prestosql.execution.QueryStateMachine
 
translate(Slice, Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
translate(Session, Expression, TypeAnalyzer, TypeProvider) - Static method in class io.prestosql.sql.planner.ConnectorExpressionTranslator
 
translate(ConnectorExpression, Map<String, Symbol>, LiteralEncoder) - Static method in class io.prestosql.sql.planner.ConnectorExpressionTranslator
 
translate(Partitioning.Translator) - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
translate(Partitioning.Translator) - Method in class io.prestosql.sql.planner.Partitioning
 
translate(Expression, Map<NodeRef<Expression>, Type>, Map<Symbol, Integer>, Metadata, Session, boolean) - Static method in class io.prestosql.sql.relational.SqlToRowExpressionTranslator
 
translate(Function<Symbol, Symbol>) - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
translate(Function<Symbol, Symbol>) - Method in class io.prestosql.sql.planner.Partitioning
 
translate(Function<Symbol, Optional<Symbol>>) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
translate(Function<Symbol, Optional<Symbol>>) - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
translate(Function<Symbol, Optional<Symbol>>) - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
translate(Function<Symbol, Optional<Symbol>>, Function<Expression, Optional<Symbol>>) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
translate(List<? extends LocalProperty<X>>, Function<X, Optional<Y>>) - Static method in class io.prestosql.sql.planner.optimizations.LocalProperties
Translates the properties as much as possible, and truncates at the first non-translatable property
translateOutputLayout(List<Symbol>) - Method in class io.prestosql.sql.planner.PartitioningScheme
 
TranslationResult(PlanNode, List<Symbol>) - Constructor for class io.prestosql.sql.planner.iterative.rule.SetOperationNodeTranslator.TranslationResult
 
TranslationResult(PlanNode, List<Symbol>, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.iterative.rule.SetOperationNodeTranslator.TranslationResult
 
Translator(Function<Symbol, Optional<Symbol>>, Function<Symbol, Optional<NullableValue>>, Function<Expression, Optional<Symbol>>) - Constructor for class io.prestosql.sql.planner.Partitioning.Translator
 
TraversingQueryContextVisitor<C,​R> - Class in io.prestosql.memory
 
TraversingQueryContextVisitor() - Constructor for class io.prestosql.memory.TraversingQueryContextVisitor
 
triggerProcessQueuedQueries() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
trim() - Method in class io.prestosql.util.Long2LongOpenBigHashMap
Rehashes the map, making the table as small as possible.
trim() - Method in class io.prestosql.util.LongBigArrayFIFOQueue
Trims the queue to the smallest possible size.
trim() - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Rehashes the map, making the table as small as possible.
trim(long) - Method in class io.prestosql.util.Long2LongOpenBigHashMap
Rehashes this map if the table is too large.
trim(long) - Method in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
Rehashes this map if the table is too large.
trim(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
trim(Slice, int[]) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
TriStateBooleanState - Interface in io.prestosql.operator.aggregation.state
 
TriStateBooleanStateSerializer - Class in io.prestosql.operator.aggregation.state
 
TriStateBooleanStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.TriStateBooleanStateSerializer
 
TRUE_VALUE - Static variable in interface io.prestosql.operator.aggregation.state.TriStateBooleanState
 
trueFalse() - Static method in class io.prestosql.testing.DataProviders
 
truncate(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
truncate(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
truncate(Slice, long) - Static method in class io.prestosql.operator.scalar.time.TimeFunctions
 
truncate(Slice, long) - Static method in class io.prestosql.operator.scalar.timestamp.DateTrunc
 
truncate(Slice, long) - Static method in class io.prestosql.operator.scalar.timestamptz.DateTrunc
 
truncate(Slice, long) - Static method in class io.prestosql.operator.scalar.timetz.DateTrunc
 
truncate(Slice, LongTimestamp) - Static method in class io.prestosql.operator.scalar.timestamp.DateTrunc
 
truncate(Slice, LongTimestampWithTimeZone) - Static method in class io.prestosql.operator.scalar.timestamptz.DateTrunc
 
truncate(Slice, LongTimeWithTimeZone) - Static method in class io.prestosql.operator.scalar.timetz.DateTrunc
 
Truncate() - Constructor for class io.prestosql.operator.scalar.MathFunctions.Truncate
 
truncateDate(ConnectorSession, Slice, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
truncateIfNecessaryForErrorMessage(Slice) - Static method in class io.prestosql.util.JsonUtil
 
truncateLong(long, long, Slice, long) - Static method in class io.prestosql.operator.scalar.MathFunctions.TruncateN
 
truncateLong(long, Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Truncate
 
truncateLongShort(long, Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Truncate
 
truncateShort(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions.Truncate
 
truncateShort(long, long, long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions.TruncateN
 
TRY_CAST - Static variable in class io.prestosql.operator.scalar.TryCastFunction
 
tryAddPage(Page) - Method in class io.prestosql.operator.index.IndexSnapshotBuilder
 
tryBoolean(TryFunction.TryBooleanLambda) - Static method in class io.prestosql.operator.scalar.TryFunction
 
TryCastFunction - Class in io.prestosql.operator.scalar
 
TryCastFunction() - Constructor for class io.prestosql.operator.scalar.TryCastFunction
 
tryDecodeEcKey(String, Map<String, String>) - Static method in class io.prestosql.server.security.jwt.JwkDecoder
 
tryDecodeJwkKey(Map<String, String>) - Static method in class io.prestosql.server.security.jwt.JwkDecoder
 
tryDecodeRsaKey(String, Map<String, String>) - Static method in class io.prestosql.server.security.jwt.JwkDecoder
 
tryDouble(TryFunction.TryDoubleLambda) - Static method in class io.prestosql.operator.scalar.TryFunction
 
TryFunction - Class in io.prestosql.operator.scalar
 
TryFunction.TryBooleanLambda - Interface in io.prestosql.operator.scalar
 
TryFunction.TryDoubleLambda - Interface in io.prestosql.operator.scalar
 
TryFunction.TryLongLambda - Interface in io.prestosql.operator.scalar
 
TryFunction.TryObjectLambda - Interface in io.prestosql.operator.scalar
 
tryGetPathToRoot(ResourceGroupId) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
tryGetPathToRoot(ResourceGroupId) - Method in class io.prestosql.execution.resourcegroups.NoOpResourceGroupManager
 
tryGetPathToRoot(ResourceGroupId) - Method in interface io.prestosql.execution.resourcegroups.ResourceGroupManager
 
tryGetQuery(QueryId) - Method in class io.prestosql.execution.QueryTracker
 
tryGetResourceGroupInfo(ResourceGroupId) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
tryGetResourceGroupInfo(ResourceGroupId) - Method in class io.prestosql.execution.resourcegroups.NoOpResourceGroupManager
 
tryGetResourceGroupInfo(ResourceGroupId) - Method in interface io.prestosql.execution.resourcegroups.ResourceGroupManager
 
tryGetScope(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
tryGetSingleVarcharValue(TupleDomain<T>, T) - Static method in class io.prestosql.connector.system.jdbc.FilterUtil
 
tryLong(TryFunction.TryLongLambda) - Static method in class io.prestosql.operator.scalar.TryFunction
 
tryObject(TryFunction.TryObjectLambda) - Static method in class io.prestosql.operator.scalar.TryFunction
 
tryReserve(QueryId, String, long) - Method in class io.prestosql.memory.MemoryPool
Try to reserve the given number of bytes.
tryResolveField(Expression) - Method in class io.prestosql.sql.analyzer.Scope
 
tryResolveField(Expression, QualifiedName) - Method in class io.prestosql.sql.analyzer.Scope
 
trySet(T) - Method in class io.prestosql.execution.StateMachine
Tries to change the state.
trySetActive(TransactionId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
trySetActive(TransactionId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
trySetActive(TransactionId) - Method in interface io.prestosql.transaction.TransactionManager
 
trySetInactive(TransactionId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
trySetInactive(TransactionId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
trySetInactive(TransactionId) - Method in interface io.prestosql.transaction.TransactionManager
 
TuplePageFilter - Class in io.prestosql.operator.index
Filters out rows that do not match the values from the specified tuple
TuplePageFilter(Page, List<BlockTypeOperators.BlockPositionEqual>, List<Integer>) - Constructor for class io.prestosql.operator.index.TuplePageFilter
 
TwoNullableValueState - Interface in io.prestosql.operator.aggregation.minmaxby
 
TwoNullableValueStateMapping - Class in io.prestosql.operator.aggregation.minmaxby
 
type() - Static method in class io.prestosql.sql.planner.plan.Patterns.CorrelatedJoin
 
type() - Static method in class io.prestosql.sql.planner.plan.Patterns.Join
 
TYPE_OPERATORS - Static variable in class io.prestosql.operator.PagesIndex.TestingFactory
 
TypeAnalyzer - Class in io.prestosql.sql.planner
This class is to facilitate obtaining the type of an expression and its subexpressions during planning (i.e., when interacting with IR expression).
TypeAnalyzer(SqlParser, Metadata) - Constructor for class io.prestosql.sql.planner.TypeAnalyzer
 
TypeCoercion - Class in io.prestosql.type
 
TypeCoercion(Function<TypeSignature, Type>) - Constructor for class io.prestosql.type.TypeCoercion
 
TypeCoercion.TypeCompatibility - Class in io.prestosql.type
 
typeConvert(Join.Type) - Static method in enum io.prestosql.sql.planner.plan.CorrelatedJoinNode.Type
 
typeConvert(Join.Type) - Static method in enum io.prestosql.sql.planner.plan.JoinNode.Type
 
TypeDeserializer - Class in io.prestosql.type
 
TypeDeserializer(Metadata) - Constructor for class io.prestosql.type.TypeDeserializer
 
TypeDeserializer(Function<TypeId, Type>) - Constructor for class io.prestosql.type.TypeDeserializer
 
TypedHeap - Class in io.prestosql.operator.aggregation
 
TypedHeap(BlockTypeOperators.BlockPositionComparison, Type, int) - Constructor for class io.prestosql.operator.aggregation.TypedHeap
 
TypedHistogram - Interface in io.prestosql.operator.aggregation.histogram
 
TypedKeyValueHeap - Class in io.prestosql.operator.aggregation
 
TypedKeyValueHeap(BlockTypeOperators.BlockPositionComparison, Type, Type, int) - Constructor for class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
TypedSet - Class in io.prestosql.operator.aggregation
 
TypedSet(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionIsDistinctFrom, BlockTypeOperators.BlockPositionHashCode, BlockBuilder, int, String, boolean) - Constructor for class io.prestosql.operator.aggregation.TypedSet
 
TypedSymbol(Symbol, String) - Constructor for class io.prestosql.sql.planner.planprinter.NodeRepresentation.TypedSymbol
 
typeForMagicLiteral(Type) - Static method in class io.prestosql.metadata.LiteralFunction
 
TypeImplementationDependency - Class in io.prestosql.operator.annotations
 
TypeImplementationDependency(String) - Constructor for class io.prestosql.operator.annotations.TypeImplementationDependency
 
typeof(Type, Boolean) - Static method in class io.prestosql.operator.scalar.TypeOfFunction
 
typeof(Type, Double) - Static method in class io.prestosql.operator.scalar.TypeOfFunction
 
typeof(Type, Long) - Static method in class io.prestosql.operator.scalar.TypeOfFunction
 
typeof(Type, Object) - Static method in class io.prestosql.operator.scalar.TypeOfFunction
 
TypeOfFunction - Class in io.prestosql.operator.scalar
 
TypeOperatorsCache - Class in io.prestosql.type
 
TypeOperatorsCache() - Constructor for class io.prestosql.type.TypeOperatorsCache
 
TypeProvider - Class in io.prestosql.sql.planner
 
TYPES - Static variable in class io.prestosql.operator.DeleteOperator
 
TYPES - Static variable in class io.prestosql.operator.StatisticsWriterOperator
 
TYPES - Static variable in class io.prestosql.operator.TableDeleteOperator
 
TYPES - Static variable in class io.prestosql.operator.TableFinishOperator
 
TypeSignatureDeserializer - Class in io.prestosql.type
 
TypeSignatureDeserializer() - Constructor for class io.prestosql.type.TypeSignatureDeserializer
 
TypeSignatureKeyDeserializer - Class in io.prestosql.type
 
TypeSignatureKeyDeserializer() - Constructor for class io.prestosql.type.TypeSignatureKeyDeserializer
 
TypeSignatureProvider - Class in io.prestosql.sql.analyzer
 
TypeSignatureProvider(TypeSignature) - Constructor for class io.prestosql.sql.analyzer.TypeSignatureProvider
 
TypeSignatureProvider(Function<List<Type>, TypeSignature>) - Constructor for class io.prestosql.sql.analyzer.TypeSignatureProvider
 
TypeSignatureTranslator - Class in io.prestosql.sql.analyzer
 
TypesJdbcTable - Class in io.prestosql.connector.system.jdbc
 
TypesJdbcTable(Metadata) - Constructor for class io.prestosql.connector.system.jdbc.TypesJdbcTable
 
TypeUtils - Class in io.prestosql.type
 
TypeValidator - Class in io.prestosql.sql.planner.sanity
Ensures that all the expressions and FunctionCalls matches their output symbols
TypeValidator() - Constructor for class io.prestosql.sql.planner.sanity.TypeValidator
 
typeVariable(String) - Static method in class io.prestosql.metadata.Signature
 
TypeVariableConstraint - Class in io.prestosql.metadata
 
TypeVariableConstraint(String, boolean, boolean, String, Set<TypeSignature>, Set<TypeSignature>) - Constructor for class io.prestosql.metadata.TypeVariableConstraint
 
typeVariableConstraints(TypeVariableConstraint...) - Method in class io.prestosql.metadata.SignatureBuilder
 
typeVariableConstraints(List<TypeVariableConstraint>) - Method in class io.prestosql.metadata.SignatureBuilder
 

U

UdtJdbcTable - Class in io.prestosql.connector.system.jdbc
 
UdtJdbcTable() - Constructor for class io.prestosql.connector.system.jdbc.UdtJdbcTable
 
UI_LOCATION - Static variable in class io.prestosql.server.ui.FormWebUiAuthenticationFilter
 
UiQueryResource - Class in io.prestosql.server.ui
 
UiQueryResource(DispatchManager, AccessControl, GroupProvider) - Constructor for class io.prestosql.server.ui.UiQueryResource
 
UnaliasSymbolReferences - Class in io.prestosql.sql.planner.optimizations
Re-maps symbol references that are just aliases of each other (e.g., due to projections like $0 := $1)
UnaliasSymbolReferences(Metadata) - Constructor for class io.prestosql.sql.planner.optimizations.UnaliasSymbolReferences
 
UnaryFunctionInterface - Interface in io.prestosql.sql.gen.lambda
 
unblockStageDynamicFilters(QueryId, PlanFragment) - Method in class io.prestosql.server.DynamicFilterService
Join build source tasks might become blocked waiting for join stage to collect build data.
unboxPrimitive(Class<?>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
unboxPrimitiveIfNecessary(Scope, Class<?>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
UndeclaredDependencyException - Exception in io.prestosql.metadata
 
UndeclaredDependencyException(String) - Constructor for exception io.prestosql.metadata.UndeclaredDependencyException
 
unescapeLiteralLikePattern(Slice, Optional<Slice>) - Static method in class io.prestosql.type.LikeFunctions
 
UNGROUPED_EXECUTION - io.prestosql.operator.PipelineExecutionStrategy
 
UNGROUPED_EXECUTION - io.prestosql.operator.StageExecutionDescriptor.StageExecutionStrategy
 
ungroupedExecution() - Static method in class io.prestosql.operator.StageExecutionDescriptor
 
UNIFORM - io.prestosql.execution.scheduler.NodeSchedulerConfig.NodeSchedulerPolicy
 
UniformNodeSelector - Class in io.prestosql.execution.scheduler
 
UniformNodeSelector(InternalNodeManager, NodeTaskMap, boolean, Supplier<NodeMap>, int, int, int, boolean) - Constructor for class io.prestosql.execution.scheduler.UniformNodeSelector
 
UniformNodeSelectorFactory - Class in io.prestosql.execution.scheduler
 
UniformNodeSelectorFactory(InternalNodeManager, NodeSchedulerConfig, NodeTaskMap) - Constructor for class io.prestosql.execution.scheduler.UniformNodeSelectorFactory
 
UniformNodeSelectorModule - Class in io.prestosql.execution.scheduler
 
UniformNodeSelectorModule() - Constructor for class io.prestosql.execution.scheduler.UniformNodeSelectorModule
 
union() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
union(Type, BlockTypeOperators.BlockPositionEqual, BlockTypeOperators.BlockPositionHashCode, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayUnionFunction
 
UnionNode - Class in io.prestosql.sql.planner.plan
 
UnionNode(PlanNodeId, List<PlanNode>, ListMultimap<Symbol, Symbol>, List<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.UnionNode
 
UnionStatsRule - Class in io.prestosql.cost
 
UnionStatsRule(StatsNormalizer) - Constructor for class io.prestosql.cost.UnionStatsRule
 
unknown() - Static method in class io.prestosql.cost.LocalCostEstimate
 
unknown() - Static method in class io.prestosql.cost.PlanCostEstimate
 
unknown() - Static method in class io.prestosql.cost.PlanNodeStatsEstimate
 
unknown() - Static method in class io.prestosql.cost.SymbolStatsEstimate
 
UNKNOWN - io.prestosql.failuredetector.FailureDetector.State
 
UNKNOWN - io.prestosql.sql.planner.SystemPartitioningHandle.SystemPartitionFunction
 
UNKNOWN - Static variable in class io.prestosql.type.UnknownType
 
UnknownType - Class in io.prestosql.type
 
UNLOADED_INDEX_KEY - Static variable in interface io.prestosql.operator.index.IndexedData
 
UnloadedIndexKeyRecordCursor(List<Type>, List<UnloadedIndexKeyRecordSet.PageAndPositions>) - Constructor for class io.prestosql.operator.index.UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor
 
UnloadedIndexKeyRecordSet - Class in io.prestosql.operator.index
 
UnloadedIndexKeyRecordSet(Session, IndexSnapshot, Set<Integer>, List<Type>, List<UpdateRequest>, JoinCompiler, BlockTypeOperators) - Constructor for class io.prestosql.operator.index.UnloadedIndexKeyRecordSet
 
UnloadedIndexKeyRecordSet.UnloadedIndexKeyRecordCursor - Class in io.prestosql.operator.index
 
unmangleOperator(String) - Static method in class io.prestosql.metadata.Signature
 
unnest() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
UnnestAnalysis(Map<NodeRef<Expression>, List<Field>>, Optional<Field>) - Constructor for class io.prestosql.sql.analyzer.Analysis.UnnestAnalysis
 
UnnestNode - Class in io.prestosql.sql.planner.plan
 
UnnestNode(PlanNodeId, PlanNode, List<Symbol>, List<UnnestNode.Mapping>, Optional<Symbol>, JoinNode.Type, Optional<Expression>) - Constructor for class io.prestosql.sql.planner.plan.UnnestNode
 
UnnestNode.Mapping - Class in io.prestosql.sql.planner.plan
 
UnnestOperator - Class in io.prestosql.operator.unnest
 
UnnestOperator(OperatorContext, List<Integer>, List<Type>, List<Integer>, List<Type>, boolean, boolean) - Constructor for class io.prestosql.operator.unnest.UnnestOperator
 
UnnestOperator.UnnestOperatorFactory - Class in io.prestosql.operator.unnest
 
UnnestOperatorFactory(int, PlanNodeId, List<Integer>, List<Type>, List<Integer>, List<Type>, boolean, boolean) - Constructor for class io.prestosql.operator.unnest.UnnestOperator.UnnestOperatorFactory
 
unordered(boolean) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
unpackChronology(long) - Static method in class io.prestosql.util.DateTimeZoneIndex
 
unpackDateTimeZone(long) - Static method in class io.prestosql.util.DateTimeZoneIndex
 
unregisterTableForColumnMasking(QualifiedObjectName, String, String) - Method in class io.prestosql.sql.analyzer.Analysis
 
unregisterTableForRowFiltering(QualifiedObjectName, String) - Method in class io.prestosql.sql.analyzer.Analysis
 
unregisterTableForView() - Method in class io.prestosql.sql.analyzer.Analysis
 
UNRESPONSIVE - io.prestosql.failuredetector.FailureDetector.State
 
unscaledDecimal - Variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
unscaledDecimals - Variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
unset(byte) - Method in enum io.prestosql.execution.buffer.PageCodecMarker
 
unsupportedPartitioningSpillerFactory() - Static method in interface io.prestosql.spiller.PartitioningSpillerFactory
 
unsupportedSingleStreamSpillerFactory() - Static method in interface io.prestosql.spiller.SingleStreamSpillerFactory
 
UNWRAP_CASTS - Static variable in class io.prestosql.SystemSessionProperties
 
UnwrapCastInComparison - Class in io.prestosql.sql.planner.iterative.rule
Given s of type S, a constant expression t of type T, and when an implicit cast exists between S->T, converts expression of the form:
UnwrapCastInComparison(Metadata, TypeOperators, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.UnwrapCastInComparison
 
unwrapCasts(Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, Expression) - Static method in class io.prestosql.sql.planner.iterative.rule.UnwrapCastInComparison
 
update() - Method in interface io.prestosql.operator.UpdateMemory
Update memory reservation.
update(long, double, int) - Method in class io.prestosql.execution.SplitConcurrencyController
 
update(TaskSource) - Method in class io.prestosql.execution.TaskSource
 
update(List<MemoryInfo>, int) - Method in class io.prestosql.memory.ClusterMemoryPool
 
updateBytes(long) - Method in interface io.prestosql.operator.SpillContext
 
updateBytes(long) - Method in class io.prestosql.spiller.LocalSpillContext
 
updateCentralMomentsState(CentralMomentsState, double) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
updateCorrelationState(CorrelationState, double, double) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
updateCovarianceState(CovarianceState, double, double) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
updateDomains(Map<DynamicFilterId, Domain>) - Method in class io.prestosql.execution.DynamicFiltersCollector
 
updateDomains(Map<DynamicFilterId, Domain>) - Method in class io.prestosql.operator.TaskContext
 
updateFailure() - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
updateGroupsAndProcessQueuedQueries() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
updateLevelPriority() - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
Updates the (potentially stale) priority value cached in this object.
updateLookupSourcePositions(long) - Method in class io.prestosql.operator.JoinStatisticsCounter
 
updateMemory() - Method in interface io.prestosql.operator.aggregation.builder.HashAggregationBuilder
 
updateMemory() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
updateMemory() - Method in class io.prestosql.operator.aggregation.builder.SpillableHashAggregationBuilder
 
UpdateMemory - Interface in io.prestosql.operator
 
updateMemoryPoolAssignments(MemoryPoolAssignmentsRequest) - Method in class io.prestosql.execution.SqlTaskManager
 
updateMemoryPoolAssignments(MemoryPoolAssignmentsRequest) - Method in interface io.prestosql.execution.TaskManager
 
updateMemoryReservation() - Method in class io.prestosql.operator.ChannelSet.ChannelSetBuilder
 
updateMemoryUsage(long) - Method in class io.prestosql.operator.exchange.LocalExchangeMemoryManager
 
updateMemoryUsage(long, long, long) - Method in class io.prestosql.execution.StageStateMachine
 
updateMemoryUsage(long, long, long, long, long, long) - Method in class io.prestosql.execution.QueryStateMachine
 
updateOutputLocations(Set<URI>, boolean) - Method in class io.prestosql.execution.QueryStateMachine.QueryOutputManager
 
updateOutputLocations(Set<URI>, boolean) - Method in class io.prestosql.execution.QueryStateMachine
 
updatePriority(Priority, long, long) - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
Presto 'charges' the quanta run time to the task and the level it belongs to in an effort to maintain the target thread utilization ratios between levels and to maintain fairness within a level.
updateQueryInfo(Optional<StageInfo>) - Method in class io.prestosql.execution.QueryStateMachine
 
updateRegressionState(RegressionState, double, double) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
updateResourceUsageAndGetDelta() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
updateRoundTripMillis(long) - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
updateSource(TaskSource) - Method in class io.prestosql.operator.Driver
 
updateState(NodeState) - Method in class io.prestosql.server.ServerInfoResource
 
updateSuccess() - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
updateTask(Session, TaskId, Optional<PlanFragment>, List<TaskSource>, OutputBuffers, OptionalInt) - Method in class io.prestosql.execution.SqlTaskManager
 
updateTask(Session, TaskId, Optional<PlanFragment>, List<TaskSource>, OutputBuffers, OptionalInt) - Method in interface io.prestosql.execution.TaskManager
Updates the task plan, sources and output buffers.
updateTask(Session, Optional<PlanFragment>, List<TaskSource>, OutputBuffers, OptionalInt) - Method in class io.prestosql.execution.SqlTask
 
updateVarianceState(VarianceState, double) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
updateWithPlanBytes(long) - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
upper(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
urlDecode(Slice) - Static method in class io.prestosql.operator.scalar.UrlFunctions
 
urlEncode(Slice) - Static method in class io.prestosql.operator.scalar.UrlFunctions
 
urlExtractFragment(Slice) - Static method in class io.prestosql.operator.scalar.UrlFunctions
 
urlExtractHost(Slice) - Static method in class io.prestosql.operator.scalar.UrlFunctions
 
urlExtractParameter(Slice, Slice) - Static method in class io.prestosql.operator.scalar.UrlFunctions
 
urlExtractPath(Slice) - Static method in class io.prestosql.operator.scalar.UrlFunctions
 
urlExtractPort(Slice) - Static method in class io.prestosql.operator.scalar.UrlFunctions
 
urlExtractProtocol(Slice) - Static method in class io.prestosql.operator.scalar.UrlFunctions
 
urlExtractQuery(Slice) - Static method in class io.prestosql.operator.scalar.UrlFunctions
 
UrlFunctions - Class in io.prestosql.operator.scalar
 
USE_MARK_DISTINCT - Static variable in class io.prestosql.SystemSessionProperties
 
USE_PREFERRED_WRITE_PARTITIONING - Static variable in class io.prestosql.SystemSessionProperties
 
UsedByGeneratedCode - Annotation Type in io.prestosql.annotation
Annotates a program element that is (only) used by generated code.
useDefaultAuthenticator() - Method in class io.prestosql.server.security.CertificateAuthenticatorManager
 
useMarkDistinct(Session) - Static method in class io.prestosql.SystemSessionProperties
 
USER_NAME - io.prestosql.server.security.KerberosNameType
 
UserMapping - Class in io.prestosql.server.security
 
UserMapping.Rule - Class in io.prestosql.server.security
 
UserMapping.UserMappingRules - Class in io.prestosql.server.security
 
UserMappingException - Exception in io.prestosql.server.security
 
UserMappingException(String) - Constructor for exception io.prestosql.server.security.UserMappingException
 
UserMappingRules(List<UserMapping.Rule>) - Constructor for class io.prestosql.server.security.UserMapping.UserMappingRules
 
userState - Variable in class io.prestosql.sql.gen.VarArgsToArrayAdapterGenerator.VarArgsToArrayAdapterState
User state created by provided user state factory
usesLegacyTableLayouts() - Method in class io.prestosql.connector.informationschema.InformationSchemaMetadata
 
usesLegacyTableLayouts() - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
usesLegacyTableLayouts() - Method in class io.prestosql.testing.TestingMetadata
 
usesLegacyTableLayouts(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Deprecated.
usesLegacyTableLayouts(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
UseTask - Class in io.prestosql.execution
 
UseTask() - Constructor for class io.prestosql.execution.UseTask
 
utilizationSupplier - Variable in class io.prestosql.execution.executor.TaskHandle
 
uuid() - Static method in class io.prestosql.type.UuidOperators
 
UUID - Static variable in class io.prestosql.type.UuidType
 
UuidOperators - Class in io.prestosql.type
 
UuidType - Class in io.prestosql.type
UUIDs are encoded in big-endian representation (the bytes are stored in the same order as they appear when a UUID is printed in hexadecimal).

V

validate(PlanNode) - Static method in class io.prestosql.sql.planner.sanity.ValidateDependenciesChecker
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.AllFunctionsResolved
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.DynamicFiltersChecker
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.NoDuplicatePlanNodeIdsChecker
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.NoIdentifierLeftChecker
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.NoSubqueryExpressionLeftChecker
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in interface io.prestosql.sql.planner.sanity.PlanSanityChecker.Checker
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.SugarFreeChecker
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.TableScanValidator
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.TypeValidator
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.ValidateAggregationsWithDefaultValues
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.ValidateDependenciesChecker
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.ValidateStreamingAggregations
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.VerifyNoFilteredAggregations
 
validate(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.VerifyOnlyOneOutputNode
 
ValidateAggregationsWithDefaultValues - Class in io.prestosql.sql.planner.sanity
When an aggregation has an empty grouping set then a default value needs to be returned in the output (e.g: 0 for COUNT(*)).
ValidateAggregationsWithDefaultValues(boolean) - Constructor for class io.prestosql.sql.planner.sanity.ValidateAggregationsWithDefaultValues
 
validateCatalogSessionProperty(CatalogName, String, String, String) - Method in class io.prestosql.metadata.SessionPropertyManager
 
ValidateDependenciesChecker - Class in io.prestosql.sql.planner.sanity
Ensures that all dependencies (i.e., symbols in expressions) for a plan node are provided by its source nodes
ValidateDependenciesChecker() - Constructor for class io.prestosql.sql.planner.sanity.ValidateDependenciesChecker
 
validateFinalPlan(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.PlanSanityChecker
 
validateImplementationDependencyAnnotation(AnnotatedElement, Annotation, Set<String>, Collection<String>) - Static method in interface io.prestosql.operator.annotations.ImplementationDependency
 
validateIntermediatePlan(PlanNode, Session, Metadata, TypeOperators, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.PlanSanityChecker
 
validateOperator(OperatorType, TypeSignature, List<TypeSignature>) - Static method in class io.prestosql.operator.scalar.annotations.OperatorValidator
 
validateScan(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
 
validateScan(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
validateSignaturesCompatibility(Optional<Signature>, Signature) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
ValidateStreamingAggregations - Class in io.prestosql.sql.planner.sanity
Verifies that input of streaming aggregations is grouped on the grouping keys
ValidateStreamingAggregations() - Constructor for class io.prestosql.sql.planner.sanity.ValidateStreamingAggregations
 
validateSystemSessionProperty(String, String) - Method in class io.prestosql.metadata.SessionPropertyManager
 
value - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
The array of values.
value - Variable in class io.prestosql.util.LongLong2LongOpenCustomBigHashMap
The array of values.
value() - Method in annotation type io.prestosql.operator.aggregation.state.InitialBooleanValue
 
value() - Method in annotation type io.prestosql.operator.aggregation.state.InitialDoubleValue
 
value() - Method in annotation type io.prestosql.operator.aggregation.state.InitialLongValue
 
value() - Method in annotation type io.prestosql.server.security.ResourceSecurity
 
value() - Method in annotation type io.prestosql.type.Constraints
 
valueAtQuantile(TDigest, double) - Static method in class io.prestosql.operator.scalar.TDigestFunctions
 
valueAtQuantileBigint(Slice, double) - Static method in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
valueAtQuantileDouble(Slice, double) - Static method in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
valueAtQuantileReal(Slice, double) - Static method in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
valueOf(int) - Static method in enum io.prestosql.operator.scalar.ColorFunctions.SystemColor
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.connector.informationschema.InformationSchemaTable
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.execution.buffer.BufferState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.execution.buffer.OutputBuffers.BufferType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.execution.buffer.PageCodecMarker
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.execution.QueryState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.execution.scheduler.NodeSchedulerConfig.NodeSchedulerPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.execution.scheduler.ScheduleResult.BlockedReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.execution.scheduler.SubnetBasedTopology.AddressProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig.TopologyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class io.prestosql.execution.StageId
 
valueOf(String) - Static method in enum io.prestosql.execution.StageState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class io.prestosql.execution.TaskId
 
valueOf(String) - Static method in enum io.prestosql.execution.TaskState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.failuredetector.FailureDetector.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.memory.MemoryManagerConfig.LowMemoryKillerPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.metadata.FunctionKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.metadata.NodeState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class io.prestosql.metadata.QualifiedObjectName
 
valueOf(String) - Static method in enum io.prestosql.metadata.RemoteTransactionHandle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.metadata.SignatureBinder.RelationshipType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata.ParameterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.BlockedReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.HashBuilderOperator.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.LookupJoinOperators.JoinType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.PipelineExecutionStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.scalar.ColorFunctions.SystemColor
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.StageExecutionDescriptor.StageExecutionStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.WindowOperator.FrameBoundKey.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.WorkProcessor.ProcessState.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.server.protocol.Slug.Context
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.server.security.KerberosNameType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.server.security.ResourceSecurity.AccessType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.analyzer.CorrelationSupport
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.analyzer.FeaturesConfig.DataIntegrityVerification
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.analyzer.FeaturesConfig.JoinReorderingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.analyzer.RegexLibrary
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.LogicalPlanner.Stage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties.StreamDistribution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.AggregationNode.Step
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.CorrelatedJoinNode.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.ExchangeNode.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.ExchangeNode.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.IndexJoinNode.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.JoinNode.DistributionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.JoinNode.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.SampleNode.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.SemiJoinNode.DistributionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.SpatialJoinNode.DistributionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.SpatialJoinNode.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.plan.TopNNode.Step
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.planner.SystemPartitioningHandle.SystemPartitionFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.sql.relational.SpecialForm.Form
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.testing.TestingHandle
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class io.prestosql.transaction.TransactionId
 
valueOf(String) - Static method in enum io.prestosql.util.HeapTraversal.Child
Returns the enum constant of this type with the specified name.
valueOf(List<String>) - Static method in class io.prestosql.execution.StageId
 
ValuePrinter - Class in io.prestosql.sql.planner.planprinter
 
ValuePrinter(Metadata, Session) - Constructor for class io.prestosql.sql.planner.planprinter.ValuePrinter
 
values - Variable in class io.prestosql.util.Long2LongOpenBigHashMap
Cached collection of values.
values() - Static method in enum io.prestosql.connector.informationschema.InformationSchemaTable
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.execution.buffer.BufferState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.execution.buffer.OutputBuffers.BufferType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.execution.buffer.PageCodecMarker
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.execution.QueryState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.execution.scheduler.NodeSchedulerConfig.NodeSchedulerPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.execution.scheduler.ScheduleResult.BlockedReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.execution.scheduler.SubnetBasedTopology.AddressProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.execution.scheduler.TopologyAwareNodeSelectorConfig.TopologyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.execution.StageState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.execution.TaskState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.failuredetector.FailureDetector.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.memory.MemoryManagerConfig.LowMemoryKillerPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.metadata.FunctionKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.metadata.NodeState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.metadata.RemoteTransactionHandle
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.metadata.SignatureBinder.RelationshipType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata.ParameterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.operator.BlockedReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.operator.HashBuilderOperator.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.operator.LookupJoinOperators.JoinType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.operator.PipelineExecutionStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.operator.scalar.ColorFunctions.SystemColor
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.operator.StageExecutionDescriptor.StageExecutionStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.operator.WindowOperator.FrameBoundKey.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.operator.WorkProcessor.ProcessState.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.server.protocol.Slug.Context
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.server.security.KerberosNameType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.server.security.ResourceSecurity.AccessType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.analyzer.CorrelationSupport
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.analyzer.FeaturesConfig.DataIntegrityVerification
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.analyzer.FeaturesConfig.JoinDistributionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.analyzer.FeaturesConfig.JoinReorderingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.analyzer.RegexLibrary
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.LogicalPlanner.Stage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties.StreamDistribution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.AggregationNode.Step
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.CorrelatedJoinNode.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.ExchangeNode.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.ExchangeNode.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.IndexJoinNode.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.JoinNode.DistributionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.JoinNode.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
values() - Static method in enum io.prestosql.sql.planner.plan.SampleNode.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.SemiJoinNode.DistributionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.SpatialJoinNode.DistributionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.SpatialJoinNode.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.plan.TopNNode.Step
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.planner.SystemPartitioningHandle.SystemPartitionFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.sql.relational.SpecialForm.Form
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.testing.TestingHandle
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.util.HeapTraversal.Child
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class io.prestosql.util.Long2LongOpenBigHashMap
 
Values() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Values
 
valuesAtPercentiles(TDigest, List<Double>) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileArrayAggregations
 
valuesAtQuantiles(TDigest, Block) - Static method in class io.prestosql.operator.scalar.TDigestFunctions
 
valuesAtQuantilesBigint(Slice, Block) - Static method in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
valuesAtQuantilesDouble(Slice, Block) - Static method in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
valuesAtQuantilesReal(Slice, Block) - Static method in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
valuesExpressionRewrite() - Method in class io.prestosql.sql.planner.iterative.rule.ExpressionRewriteRuleSet
 
ValuesNode - Class in io.prestosql.sql.planner.plan
 
ValuesNode(PlanNodeId, int) - Constructor for class io.prestosql.sql.planner.plan.ValuesNode
Constructor of ValuesNode with empty output symbols list
ValuesNode(PlanNodeId, List<Symbol>, int, Optional<List<Expression>>) - Constructor for class io.prestosql.sql.planner.plan.ValuesNode
 
ValuesNode(PlanNodeId, List<Symbol>, List<Expression>) - Constructor for class io.prestosql.sql.planner.plan.ValuesNode
Constructor of ValuesNode with non-empty output symbols list
ValuesOperator - Class in io.prestosql.operator
 
ValuesOperator(OperatorContext, List<Page>) - Constructor for class io.prestosql.operator.ValuesOperator
 
ValuesOperator.ValuesOperatorFactory - Class in io.prestosql.operator
 
ValuesOperatorFactory(int, PlanNodeId, List<Page>) - Constructor for class io.prestosql.operator.ValuesOperator.ValuesOperatorFactory
 
ValuesStatsRule - Class in io.prestosql.cost
 
ValuesStatsRule(Metadata) - Constructor for class io.prestosql.cost.ValuesStatsRule
 
ValueStore - Class in io.prestosql.operator.aggregation.histogram
helper class for GroupedTypedHistogram May be used for other cases that need a simple hash for values
ValueStore(Type, BlockTypeOperators.BlockPositionEqual, int, BlockBuilder) - Constructor for class io.prestosql.operator.aggregation.histogram.ValueStore
 
valueToSessionTimeZoneOffsetDiff(long, DateTimeZone) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
VarArgsToArrayAdapterGenerator - Class in io.prestosql.sql.gen
 
VarArgsToArrayAdapterGenerator.MethodHandleAndConstructor - Class in io.prestosql.sql.gen
 
VarArgsToArrayAdapterGenerator.VarArgsToArrayAdapterState - Class in io.prestosql.sql.gen
 
VarArgsToArrayAdapterState(Object, Object) - Constructor for class io.prestosql.sql.gen.VarArgsToArrayAdapterGenerator.VarArgsToArrayAdapterState
 
VarArgsToMapAdapterGenerator - Class in io.prestosql.sql.gen
 
VARBINARY_CONCAT - Static variable in class io.prestosql.operator.scalar.ConcatFunction
 
VarbinaryFunctions - Class in io.prestosql.operator.scalar
 
VARCHAR - Static variable in class io.prestosql.type.VarcharParametricType
 
VARCHAR_CONCAT - Static variable in class io.prestosql.operator.scalar.ConcatFunction
 
VARCHAR_TO_DECIMAL_CAST - Static variable in class io.prestosql.type.DecimalCasts
 
VarcharApproximateMostFrequent - Class in io.prestosql.operator.aggregation
Aggregation function that approximates the frequency of the top-K elements.
VarcharApproximateMostFrequent.State - Interface in io.prestosql.operator.aggregation
 
varcharIsJsonScalar(Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
varcharJsonArrayContains(Slice, boolean) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
varcharJsonArrayContains(Slice, double) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
varcharJsonArrayContains(Slice, long) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
varcharJsonArrayContains(Slice, Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
varcharJsonArrayGet(Slice, long) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
varcharJsonArrayLength(Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
varcharJsonExtract(Slice, JsonPath) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
varcharJsonExtractScalar(Slice, JsonPath) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
varcharJsonSize(Slice, JsonPath) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
VarcharOperators - Class in io.prestosql.type
 
VarcharParametricType - Class in io.prestosql.type
 
VarcharParametricType() - Constructor for class io.prestosql.type.VarcharParametricType
 
varcharToCharCast(Long, Slice) - Static method in class io.prestosql.operator.scalar.CharacterStringCasts
 
varcharToCharSaturatedFloorCast(long, Slice) - Static method in class io.prestosql.operator.scalar.CharacterStringCasts
 
varcharToLongDecimal(Slice, long, long, BigInteger) - Static method in class io.prestosql.type.DecimalCasts
 
varcharToShortDecimal(Slice, long, long, long) - Static method in class io.prestosql.type.DecimalCasts
 
VarcharToTimestampCast - Class in io.prestosql.operator.scalar.timestamp
 
VarcharToTimestampWithTimeZoneCast - Class in io.prestosql.operator.scalar.timestamptz
 
VarcharToTimeWithTimeZoneCast - Class in io.prestosql.operator.scalar.timetz
 
varcharToVarcharCast(Long, Long, Slice) - Static method in class io.prestosql.operator.scalar.CharacterStringCasts
 
variable() - Method in annotation type io.prestosql.type.Constraint
 
VariableReferenceExpression - Class in io.prestosql.sql.relational
 
VariableReferenceExpression(String, Type) - Constructor for class io.prestosql.sql.relational.VariableReferenceExpression
 
variance(VarianceState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.VarianceAggregation
 
VarianceAggregation - Class in io.prestosql.operator.aggregation
 
variancePop(VarianceState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.VarianceAggregation
 
VarianceState - Interface in io.prestosql.operator.aggregation.state
 
verifyAccuracy(double) - Static method in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
verifyAllPartitionsRead() - Method in class io.prestosql.spiller.GenericPartitioningSpiller
 
verifyAllPartitionsRead() - Method in interface io.prestosql.spiller.PartitioningSpiller
 
verifyExpressionIsConstant(Set<NodeRef<Expression>>, Expression) - Static method in class io.prestosql.sql.analyzer.ConstantExpressionVerifier
 
VerifyNoFilteredAggregations - Class in io.prestosql.sql.planner.sanity
 
VerifyNoFilteredAggregations() - Constructor for class io.prestosql.sql.planner.sanity.VerifyNoFilteredAggregations
 
VerifyOnlyOneOutputNode - Class in io.prestosql.sql.planner.sanity
 
VerifyOnlyOneOutputNode() - Constructor for class io.prestosql.sql.planner.sanity.VerifyOnlyOneOutputNode
 
verifyTypes() - Method in interface io.prestosql.metadata.Metadata
 
verifyTypes() - Method in class io.prestosql.metadata.MetadataManager
 
verifyWeight(double) - Static method in class io.prestosql.operator.scalar.TDigestFunctions
 
verifyWeight(long) - Static method in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
VersionedDynamicFilterDomains(long, Map<DynamicFilterId, Domain>) - Constructor for class io.prestosql.execution.DynamicFiltersCollector.VersionedDynamicFilterDomains
 
VersionedMemoryPoolId - Class in io.prestosql.memory
 
VersionedMemoryPoolId(MemoryPoolId, long) - Constructor for class io.prestosql.memory.VersionedMemoryPoolId
 
VIEW_QUERY - io.prestosql.testing.TestingAccessControlManager.TestingPrivilegeType
 
ViewAccessControl - Class in io.prestosql.security
 
ViewAccessControl(AccessControl, Identity) - Constructor for class io.prestosql.security.ViewAccessControl
 
viewOf(Map<Symbol, Type>) - Static method in class io.prestosql.sql.planner.TypeProvider
 
VIEWS - io.prestosql.connector.informationschema.InformationSchemaTable
 
visitAggregation(AggregationNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitApply(ApplyNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitAssignUniqueId(AssignUniqueId, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitCall(CallExpression, C) - Method in interface io.prestosql.sql.relational.RowExpressionVisitor
 
visitConstant(ConstantExpression, C) - Method in interface io.prestosql.sql.relational.RowExpressionVisitor
 
visitCorrelatedJoin(CorrelatedJoinNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitDelete(DeleteNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitDistinctLimit(DistinctLimitNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitDriverContext(DriverContext, C) - Method in interface io.prestosql.memory.QueryContextVisitor
 
visitDriverContext(DriverContext, C) - Method in class io.prestosql.memory.TraversingQueryContextVisitor
 
visitEnforceSingleRow(EnforceSingleRowNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitExcept(ExceptNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitExchange(ExchangeNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitExplainAnalyze(ExplainAnalyzeNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitFilter(FilterNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitGroupId(GroupIdNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitGroupReference(GroupReference, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitIndexJoin(IndexJoinNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitIndexSource(IndexSourceNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitInputReference(InputReferenceExpression, C) - Method in interface io.prestosql.sql.relational.RowExpressionVisitor
 
visitIntersect(IntersectNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitJoin(JoinNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitLambda(LambdaDefinitionExpression, C) - Method in interface io.prestosql.sql.relational.RowExpressionVisitor
 
visitLimit(LimitNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitMarkDistinct(MarkDistinctNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitOffset(OffsetNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitOperatorContext(OperatorContext, C) - Method in interface io.prestosql.memory.QueryContextVisitor
 
visitOperatorContext(OperatorContext, C) - Method in class io.prestosql.memory.TraversingQueryContextVisitor
 
visitOutput(OutputNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitPipelineContext(PipelineContext, C) - Method in interface io.prestosql.memory.QueryContextVisitor
 
visitPipelineContext(PipelineContext, C) - Method in class io.prestosql.memory.TraversingQueryContextVisitor
 
visitPlan(PlanNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitPlan(PlanNode, C) - Method in class io.prestosql.sql.planner.SimplePlanVisitor
 
visitPlan(PlanNode, SimplePlanRewriter.RewriteContext<C>) - Method in class io.prestosql.sql.planner.plan.SimplePlanRewriter
 
visitProject(ProjectNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitQueryContext(QueryContext, C) - Method in interface io.prestosql.memory.QueryContextVisitor
 
visitQueryContext(QueryContext, C) - Method in class io.prestosql.memory.TraversingQueryContextVisitor
 
visitRemoteSource(RemoteSourceNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitRowNumber(RowNumberNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitSample(SampleNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitSemiJoin(SemiJoinNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitSort(SortNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitSpatialJoin(SpatialJoinNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitSpecialForm(SpecialForm, C) - Method in interface io.prestosql.sql.relational.RowExpressionVisitor
 
visitStatisticsWriterNode(StatisticsWriterNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitTableDelete(TableDeleteNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitTableFinish(TableFinishNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitTableScan(TableScanNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitTableWriter(TableWriterNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitTaskContext(TaskContext, C) - Method in interface io.prestosql.memory.QueryContextVisitor
 
visitTaskContext(TaskContext, C) - Method in class io.prestosql.memory.TraversingQueryContextVisitor
 
visitTopN(TopNNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitTopNRowNumber(TopNRowNumberNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitUnion(UnionNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitUnnest(UnnestNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitValues(ValuesNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitVariableReference(VariableReferenceExpression, C) - Method in interface io.prestosql.sql.relational.RowExpressionVisitor
 
visitWindow(WindowNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
VoidTraversingQueryContextVisitor<C> - Class in io.prestosql.memory
 
VoidTraversingQueryContextVisitor() - Constructor for class io.prestosql.memory.VoidTraversingQueryContextVisitor
 

W

waitForDispatched(QueryId) - Method in class io.prestosql.dispatcher.DispatchManager
 
waitForMinimumWorkers(int, Duration) - Method in class io.prestosql.execution.ClusterSizeMonitor
Returns a listener that completes when the minimum number of workers for the cluster has been met.
waitForNodeRefresh(Duration) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
waitForReading() - Method in class io.prestosql.operator.exchange.LocalExchangeSource
 
waitForShutdownComplete(long) - Method in class io.prestosql.server.testing.TestingPrestoServer.TestShutdownAction
 
waitForWriting() - Method in interface io.prestosql.operator.exchange.LocalExchanger
 
waitForWriting() - Method in class io.prestosql.operator.exchange.LocalExchangeSink
 
waitForWriting() - Method in class io.prestosql.operator.exchange.PassthroughExchanger
 
WAITING_FOR_MEMORY - io.prestosql.operator.BlockedReason
 
WAITING_FOR_RESOURCES - io.prestosql.execution.QueryState
Query is waiting for the required resources (beta).
WAITING_FOR_SOURCE - io.prestosql.execution.scheduler.ScheduleResult.BlockedReason
 
WarningCollector - Interface in io.prestosql.execution.warnings
 
WarningCollectorConfig - Class in io.prestosql.execution.warnings
 
WarningCollectorConfig() - Constructor for class io.prestosql.execution.warnings.WarningCollectorConfig
 
WarningCollectorFactory - Interface in io.prestosql.execution.warnings
 
WarningCollectorModule - Class in io.prestosql.execution.warnings
 
WarningCollectorModule() - Constructor for class io.prestosql.execution.warnings.WarningCollectorModule
 
wasCalled() - Method in class io.prestosql.testing.ProcedureTester
 
wasNull() - Method in class io.prestosql.sql.gen.BytecodeGeneratorContext
 
WEB_UI - io.prestosql.server.security.ResourceSecurity.AccessType
 
WebUiAuthenticationConfig - Class in io.prestosql.server.ui
 
WebUiAuthenticationConfig() - Constructor for class io.prestosql.server.ui.WebUiAuthenticationConfig
 
WebUiAuthenticationFilter - Interface in io.prestosql.server.ui
 
WebUiAuthenticationModule - Class in io.prestosql.server.ui
 
WebUiAuthenticationModule() - Constructor for class io.prestosql.server.ui.WebUiAuthenticationModule
 
webUiAuthenticator(String, Module) - Static method in class io.prestosql.server.ui.WebUiAuthenticationModule
 
webUiAuthenticator(String, Class<? extends Authenticator>, Module) - Static method in class io.prestosql.server.ui.WebUiAuthenticationModule
 
WebUiConfig - Class in io.prestosql.server.ui
 
WebUiConfig() - Constructor for class io.prestosql.server.ui.WebUiConfig
 
WebUiModule - Class in io.prestosql.server.ui
 
WebUiModule() - Constructor for class io.prestosql.server.ui.WebUiModule
 
WebUiStaticResource - Class in io.prestosql.server.ui
 
WebUiStaticResource() - Constructor for class io.prestosql.server.ui.WebUiStaticResource
 
weekFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
WEIGHTED_EXPECTED_HASH_COLLISIONS - Static variable in class io.prestosql.operator.HashCollisionsInfo
 
WEIGHTED_HASH_COLLISIONS_PROPERTY - Static variable in class io.prestosql.operator.HashCollisionsInfo
 
WEIGHTED_SUM_SQUARED_HASH_COLLISIONS - Static variable in class io.prestosql.operator.HashCollisionsInfo
 
weightedInput(QuantileDigestAndPercentileState, double, double, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
Deprecated.
weightedInput(QuantileDigestAndPercentileState, long, double, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
Deprecated.
weightedInput(QuantileDigestAndPercentileState, long, double, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
Deprecated.
weightedInput(TDigestAndPercentileArrayState, double, double, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileArrayAggregations
 
weightedInput(TDigestAndPercentileArrayState, long, double, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileArrayAggregations
 
weightedInput(TDigestAndPercentileArrayState, long, double, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileArrayAggregations
 
weightedInput(TDigestAndPercentileState, double, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
weightedInput(TDigestAndPercentileState, long, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
weightedInput(TDigestAndPercentileState, long, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
weightedInput(TDigestState, double, double) - Static method in class io.prestosql.operator.aggregation.TDigestAggregationFunction
 
WHEN - io.prestosql.sql.relational.SpecialForm.Form
 
whenBuildFinishes() - Method in class io.prestosql.operator.index.IndexLookupSourceFactory
 
whenBuildFinishes() - Method in interface io.prestosql.operator.JoinBridge
 
whenBuildFinishes() - Method in interface io.prestosql.operator.NestedLoopJoinBridge
 
whenBuildFinishes() - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
whenSplitQueueHasSpace(int) - Method in interface io.prestosql.execution.RemoteTask
 
whenSplitQueueHasSpace(int) - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
where(Predicate<PlanNode>) - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
WHITE - io.prestosql.operator.scalar.ColorFunctions.SystemColor
 
widthBucket(double, double, double, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
widthBucket(double, Block) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
WilsonInterval - Class in io.prestosql.operator.scalar
 
wilsonIntervalLower(long, long, double) - Static method in class io.prestosql.operator.scalar.WilsonInterval
 
wilsonIntervalUpper(long, long, double) - Static method in class io.prestosql.operator.scalar.WilsonInterval
 
window() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
window(WindowFunctionSupplier, Type, FrameInfo, boolean, List<LambdaProvider>, Integer...) - Static method in class io.prestosql.operator.WindowFunctionDefinition
 
window(WindowFunctionSupplier, Type, FrameInfo, boolean, List<LambdaProvider>, List<Integer>) - Static method in class io.prestosql.operator.WindowFunctionDefinition
 
window(Class<? extends WindowFunction>) - Method in class io.prestosql.metadata.FunctionListBuilder
 
WINDOW - io.prestosql.metadata.FunctionKind
 
WindowAnnotationsParser - Class in io.prestosql.operator.window
 
WindowFilterPushDown - Class in io.prestosql.sql.planner.optimizations
 
WindowFilterPushDown(Metadata, TypeOperators) - Constructor for class io.prestosql.sql.planner.optimizations.WindowFilterPushDown
 
WindowFunctionDefinition - Class in io.prestosql.operator
 
WindowFunctionSupplier - Interface in io.prestosql.operator.window
 
WindowInfo - Class in io.prestosql.operator
 
WindowInfo(List<WindowInfo.DriverWindowInfo>) - Constructor for class io.prestosql.operator.WindowInfo
 
WindowInfo.DriverWindowInfo - Class in io.prestosql.operator
 
WindowInfo.IndexInfo - Class in io.prestosql.operator
 
WindowNode - Class in io.prestosql.sql.planner.plan
 
WindowNode(PlanNodeId, PlanNode, WindowNode.Specification, Map<Symbol, WindowNode.Function>, Optional<Symbol>, Set<Symbol>, int) - Constructor for class io.prestosql.sql.planner.plan.WindowNode
 
WindowNode.Frame - Class in io.prestosql.sql.planner.plan
 
WindowNode.Function - Class in io.prestosql.sql.planner.plan
 
WindowNode.Specification - Class in io.prestosql.sql.planner.plan
 
WindowNodeUtil - Class in io.prestosql.sql.planner.optimizations
 
WindowOperator - Class in io.prestosql.operator
 
WindowOperator(OperatorContext, List<Type>, List<Integer>, List<WindowFunctionDefinition>, List<Integer>, List<Integer>, List<Integer>, List<SortOrder>, int, int, PagesIndex.Factory, boolean, SpillerFactory, OrderingCompiler) - Constructor for class io.prestosql.operator.WindowOperator
 
WindowOperator.FrameBoundKey - Class in io.prestosql.operator
 
WindowOperator.FrameBoundKey.Type - Enum in io.prestosql.operator
 
WindowOperator.WindowOperatorFactory - Class in io.prestosql.operator
 
WindowOperatorFactory(int, PlanNodeId, List<? extends Type>, List<Integer>, List<WindowFunctionDefinition>, List<Integer>, List<Integer>, List<Integer>, List<SortOrder>, int, int, PagesIndex.Factory, boolean, SpillerFactory, OrderingCompiler) - Constructor for class io.prestosql.operator.WindowOperator.WindowOperatorFactory
 
WindowPartition - Class in io.prestosql.operator.window
 
WindowPartition(PagesIndex, int, int, int[], List<FramedWindowFunction>, PagesHashStrategy, Map<WindowOperator.FrameBoundKey, PagesIndexComparator>) - Constructor for class io.prestosql.operator.window.WindowPartition
 
WindowPlanNodeStats - Class in io.prestosql.sql.planner.planprinter
 
WindowPlanNodeStats(PlanNodeId, Duration, Duration, long, DataSize, long, DataSize, Map<String, OperatorInputStats>, WindowOperatorStats) - Constructor for class io.prestosql.sql.planner.planprinter.WindowPlanNodeStats
 
withAlias(String, List<String>) - Method in class io.prestosql.sql.analyzer.RelationType
Creates a new tuple descriptor with the relation, and, optionally, the columns aliased.
withAlternativePartitiongingHandle(PartitioningHandle) - Method in class io.prestosql.sql.planner.Partitioning
 
withAlwaysRevokeMemory() - Method in class io.prestosql.testing.LocalQueryRunner.Builder
 
withBucketToPartition(Optional<int[]>) - Method in class io.prestosql.sql.planner.PartitioningScheme
 
withBucketToPartition(Optional<int[]>) - Method in class io.prestosql.sql.planner.PlanFragment
 
withBucketToPartition(Optional<int[]>) - Method in class io.prestosql.sql.planner.StageExecutionPlan
 
withBuffer(OutputBuffers.OutputBufferId, int) - Method in class io.prestosql.execution.buffer.OutputBuffers
 
withBuffers(Map<OutputBuffers.OutputBufferId, Integer>) - Method in class io.prestosql.execution.buffer.OutputBuffers
 
withColumnsAndTypes(List<Column>, List<Type>) - Method in class io.prestosql.server.protocol.QueryResultRows.Builder
 
withDefaultParallelism(Session) - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
withDefaultProperties(Map<String, String>, Map<String, Map<String, String>>) - Method in class io.prestosql.Session
 
withDefaultSessionProperties(Map<String, List<PropertyMetadata<?>>>) - Method in class io.prestosql.testing.LocalQueryRunner.Builder
 
withDistributionType(JoinNode.DistributionType) - Method in class io.prestosql.sql.planner.plan.JoinNode
 
withDistributionType(SemiJoinNode.DistributionType) - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
withDynamicLifespanScheduleGroupedExecution(List<PlanNodeId>) - Method in class io.prestosql.sql.planner.PlanFragment
 
withExceptionConsumer(Consumer<Throwable>) - Method in class io.prestosql.server.protocol.QueryResultRows.Builder
 
withExtraParameters(Function<PolymorphicScalarFunctionBuilder.SpecializeContext, List<Object>>) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.MethodsGroupBuilder
 
withFeaturesConfig(FeaturesConfig) - Method in class io.prestosql.testing.LocalQueryRunner.Builder
 
withFilter(Expression) - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
withFixedLifespanScheduleGroupedExecution(List<PlanNodeId>) - Method in class io.prestosql.sql.planner.PlanFragment
 
withFixedParallelism() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
withInitialTransaction() - Method in class io.prestosql.testing.LocalQueryRunner.Builder
 
withIsolationLevel(IsolationLevel) - Method in class io.prestosql.transaction.TransactionBuilder
 
withLease(Function<LookupSourceProvider.LookupSourceLease, R>) - Method in interface io.prestosql.operator.LookupSourceProvider
 
withLease(Function<LookupSourceProvider.LookupSourceLease, R>) - Method in class io.prestosql.operator.StaticLookupSourceProvider
 
withNamedQuery(String, WithQuery) - Method in class io.prestosql.sql.analyzer.Scope.Builder
 
withNodeCountForStats(int) - Method in class io.prestosql.testing.LocalQueryRunner.Builder
 
withNodeSpillConfig(NodeSpillConfig) - Method in class io.prestosql.testing.LocalQueryRunner.Builder
 
withNoMoreBufferIds() - Method in class io.prestosql.execution.buffer.OutputBuffers
 
withOnlyVisibleFields() - Method in class io.prestosql.sql.analyzer.RelationType
Creates a new tuple descriptor containing only the visible fields.
withOrderSensitivity() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
withoutEmbeddedJsonRepresentation() - Method in class io.prestosql.sql.planner.PlanFragment
 
withOuterQueryParent(Scope) - Method in class io.prestosql.sql.analyzer.Scope.Builder
 
withoutPreference() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
withParallelism() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
withParent(Scope) - Method in class io.prestosql.sql.analyzer.Scope.Builder
 
withPartitioning(Collection<Symbol>) - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
withProcessEntryMonitor(Runnable) - Method in interface io.prestosql.operator.WorkProcessor
 
withProcessStateMonitor(Consumer<WorkProcessor.ProcessState<T>>) - Method in interface io.prestosql.operator.WorkProcessor
 
withRelationType(RelationId, RelationType) - Method in class io.prestosql.sql.analyzer.Scope.Builder
 
withRelationType(RelationType) - Method in class io.prestosql.sql.analyzer.Scope
 
withReorderJoinStatsAndCost(PlanNodeStatsAndCostSummary) - Method in class io.prestosql.sql.planner.plan.JoinNode
 
withReplicatedNulls(boolean) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
withReplicatedNulls(boolean) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
withSingleBooleanValue(Column, boolean) - Method in class io.prestosql.server.protocol.QueryResultRows.Builder
 
withSpillable(boolean) - Method in class io.prestosql.sql.planner.plan.JoinNode
 
withTaskStatus(TaskStatus) - Method in class io.prestosql.execution.TaskInfo
 
WithTimeZone - Class in io.prestosql.operator.scalar.timestamp
 
withVariadicBound(String, String) - Static method in class io.prestosql.metadata.Signature
 
wordStem(Slice) - Static method in class io.prestosql.operator.scalar.WordStemFunction
 
wordStem(Slice, Slice) - Static method in class io.prestosql.operator.scalar.WordStemFunction
 
WordStemFunction - Class in io.prestosql.operator.scalar
 
Work<T> - Interface in io.prestosql.operator
The interface is used when a function call needs to yield/pause during the process.
WORKER_NODE_ERROR - Static variable in class io.prestosql.util.Failures
 
WorkerModule - Class in io.prestosql.server
 
WorkerModule() - Constructor for class io.prestosql.server.WorkerModule
 
WorkerResource - Class in io.prestosql.server.ui
 
WorkerResource(DispatchManager, InternalNodeManager, AccessControl, HttpClient, GroupProvider) - Constructor for class io.prestosql.server.ui.WorkerResource
 
WorkProcessor<T> - Interface in io.prestosql.operator
 
WorkProcessor.Process<T> - Interface in io.prestosql.operator
 
WorkProcessor.ProcessState<T> - Class in io.prestosql.operator
 
WorkProcessor.ProcessState.Type - Enum in io.prestosql.operator
 
WorkProcessor.Transformation<T,​R> - Interface in io.prestosql.operator
 
WorkProcessor.TransformationState<T> - Class in io.prestosql.operator
 
WorkProcessorOperator - Interface in io.prestosql.operator
 
WorkProcessorOperatorAdapter - Class in io.prestosql.operator
This WorkProcessorOperator adapter allows to adapt WorkProcessor operators that require customization of input handling (e.g aggregation operators that want to skip extra buffering step or operators that require more sophisticated initial blocking condition).
WorkProcessorOperatorAdapter(OperatorContext, WorkProcessorOperatorAdapter.AdapterWorkProcessorOperatorFactory) - Constructor for class io.prestosql.operator.WorkProcessorOperatorAdapter
 
WorkProcessorOperatorAdapter.AdapterWorkProcessorOperator - Interface in io.prestosql.operator
 
WorkProcessorOperatorAdapter.AdapterWorkProcessorOperatorFactory - Interface in io.prestosql.operator
 
WorkProcessorOperatorFactory - Interface in io.prestosql.operator
 
WorkProcessorPipelineSourceOperator - Class in io.prestosql.operator
 
WorkProcessorPipelineSourceOperator.WorkProcessorPipelineSourceOperatorFactory - Class in io.prestosql.operator
 
WorkProcessorSourceOperator - Interface in io.prestosql.operator
 
WorkProcessorSourceOperatorAdapter - Class in io.prestosql.operator
 
WorkProcessorSourceOperatorAdapter(OperatorContext, WorkProcessorSourceOperatorAdapter.AdapterWorkProcessorSourceOperatorFactory) - Constructor for class io.prestosql.operator.WorkProcessorSourceOperatorAdapter
 
WorkProcessorSourceOperatorAdapter.AdapterWorkProcessorSourceOperatorFactory - Interface in io.prestosql.operator
 
WorkProcessorSourceOperatorFactory - Interface in io.prestosql.operator
 
WorkProcessorUtils - Class in io.prestosql.operator
 
write(Type, BlockPositionState, BlockBuilder) - Static method in interface io.prestosql.operator.aggregation.state.BlockPositionState
 
write(Type, BlockState, BlockBuilder) - Static method in interface io.prestosql.operator.aggregation.state.BlockState
 
write(Type, NullableBooleanState, BlockBuilder) - Static method in interface io.prestosql.operator.aggregation.state.NullableBooleanState
 
write(Type, NullableDoubleState, BlockBuilder) - Static method in interface io.prestosql.operator.aggregation.state.NullableDoubleState
 
write(Type, NullableLongState, BlockBuilder) - Static method in interface io.prestosql.operator.aggregation.state.NullableLongState
 
write(Type, SliceState, BlockBuilder) - Static method in interface io.prestosql.operator.aggregation.state.SliceState
 
write(Type, TriStateBooleanState, BlockBuilder) - Static method in interface io.prestosql.operator.aggregation.state.TriStateBooleanState
 
writeAll(BlockBuilder) - Method in class io.prestosql.operator.aggregation.TypedHeap
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Static method in class io.prestosql.block.BlockSerdeUtil
 
writeBoolean(BlockBuilder, boolean) - Method in class io.prestosql.type.FunctionType
 
writeBoolean(BlockBuilder, boolean) - Method in class io.prestosql.type.UnknownType
Deprecated.
writeBytesTo(int, int, int, BlockBuilder) - Method in class io.prestosql.operator.GroupByIdBlock
 
writeDouble(BlockBuilder, double) - Method in class io.prestosql.type.FunctionType
 
writeJsonValue(JsonGenerator, Block, int) - Method in interface io.prestosql.util.JsonUtil.JsonGeneratorWriter
 
writeLong(BlockBuilder, long) - Method in class io.prestosql.type.FunctionType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.type.CodePointsType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.type.FunctionType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.type.JoniRegexpType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.type.JsonPathType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.type.LikePatternType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.type.Re2JRegexpType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.type.TDigestType
 
writePages(PagesSerde, SliceOutput, Page...) - Static method in class io.prestosql.execution.buffer.PagesSerdeUtil
 
writePages(PagesSerde, SliceOutput, Iterator<Page>) - Static method in class io.prestosql.execution.buffer.PagesSerdeUtil
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.operator.GroupByIdBlock
 
WRITER_MIN_SIZE - Static variable in class io.prestosql.SystemSessionProperties
 
WRITER_SCALING - io.prestosql.execution.scheduler.ScheduleResult.BlockedReason
 
WriterTarget() - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.WriterTarget
 
writeSerializedPage(SliceOutput, SerializedPage) - Static method in class io.prestosql.execution.buffer.PagesSerdeUtil
 
writeSerializedPages(SliceOutput, Iterable<SerializedPage>) - Static method in class io.prestosql.execution.buffer.PagesSerdeUtil
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.type.FunctionType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.type.IpAddressType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.type.JsonType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.type.setdigest.SetDigestType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.type.UuidType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.type.FunctionType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.type.IpAddressType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.type.JsonType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.type.setdigest.SetDigestType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.type.UuidType
 
writeStatistics(Collection<ComputedStatistics>) - Method in interface io.prestosql.operator.StatisticsWriterOperator.StatisticsWriter
 
WriteStatisticsHandle(AnalyzeTableHandle) - Constructor for class io.prestosql.sql.planner.plan.StatisticsWriterNode.WriteStatisticsHandle
 
WriteStatisticsReference(TableHandle) - Constructor for class io.prestosql.sql.planner.plan.StatisticsWriterNode.WriteStatisticsReference
 
WriteStatisticsTarget() - Constructor for class io.prestosql.sql.planner.plan.StatisticsWriterNode.WriteStatisticsTarget
 
writeString(BlockBuilder, String) - Method in class io.prestosql.type.JsonType
 
writeTo(List<SerializedPage>, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class io.prestosql.server.PagesResponseWriter
 
writeValue(BytecodeExpression, BytecodeExpression) - Method in class io.prestosql.sql.gen.SqlTypeBytecodeExpression
 

X

xxhash64(Slice) - Static method in class io.prestosql.operator.scalar.VarbinaryFunctions
 
xxHash64(Block, int) - Method in interface io.prestosql.type.BlockTypeOperators.BlockPositionXxHash64
 

Y

yearFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
yearFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
yearOfWeekFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
YELLOW - io.prestosql.operator.scalar.ColorFunctions.SystemColor
 
yield() - Static method in class io.prestosql.operator.WorkProcessor.ProcessState
Signals that process has yielded.
yield() - Static method in class io.prestosql.operator.WorkProcessor.TransformationState
Signals that transformation has yielded.
YIELD - io.prestosql.operator.WorkProcessor.ProcessState.Type
 
yielding(BooleanSupplier) - Method in interface io.prestosql.operator.WorkProcessor
Makes WorkProcessor yield when given yieldSignal is set.
yieldingIterator() - Method in interface io.prestosql.operator.WorkProcessor
Converts WorkProcessor into an yielding Iterator.

Z

zero() - Static method in class io.prestosql.cost.LocalCostEstimate
 
zero() - Static method in class io.prestosql.cost.PlanCostEstimate
 
zero() - Static method in class io.prestosql.cost.SymbolStatsEstimate
 
zip(List<Type>, Block...) - Static method in class io.prestosql.operator.scalar.ZipFunction
 
ZIP_FUNCTIONS - Static variable in class io.prestosql.operator.scalar.ZipFunction
 
ZIP_WITH_FUNCTION - Static variable in class io.prestosql.operator.scalar.ZipWithFunction
 
ZipFunction - Class in io.prestosql.operator.scalar
 
zipWith(Type, Type, ArrayType, Object, Block, Block, BinaryFunctionInterface) - Static method in class io.prestosql.operator.scalar.ZipWithFunction
 
ZipWithFunction - Class in io.prestosql.operator.scalar
 

_

_deserialize(String, DeserializationContext) - Method in class io.prestosql.type.TypeDeserializer
 
_deserialize(String, DeserializationContext) - Method in class io.prestosql.type.TypeSignatureDeserializer
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes All Packages