Skip navigation links
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 _ 

A

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() - 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
 
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(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
abs(double) - 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(String, OperatorType) - 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) - Constructor for class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
AbstractMinMaxBy - Class in io.prestosql.operator.aggregation.minmaxby
 
AbstractMinMaxBy(boolean) - Constructor for class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxBy
 
AbstractMinMaxByNAggregationFunction - Class in io.prestosql.operator.aggregation.minmaxby
 
AbstractMinMaxByNAggregationFunction(String, Function<Type, BlockComparator>) - Constructor for class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
AbstractMinMaxNAggregationFunction - Class in io.prestosql.operator.aggregation
 
AbstractMinMaxNAggregationFunction(String, Function<Type, BlockComparator>) - 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) - Constructor for class io.prestosql.operator.window.AbstractWindowFunctionSupplier
 
accept(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.memory.QueryContext
 
accept(T, PageBuilder, int) - Method in class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
 
accept(Block, int) - Method in interface io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateConsumer
 
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, Block, int) - Method in interface io.prestosql.operator.aggregation.multimapagg.MultimapAggregationStateConsumer
 
accept(QueryContextVisitor<C, R>, C) - Method in class io.prestosql.operator.DriverContext
 
accept(Page) - Method in interface io.prestosql.operator.exchange.LocalExchanger
 
accept(Page) - Method in class io.prestosql.operator.exchange.PassthroughExchanger
 
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(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.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.LateralJoinNode
 
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.MetadataDeleteNode
 
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.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.VariableReferenceExpression
 
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
 
AccessControlInfo(AccessControl, Identity) - Constructor for class io.prestosql.sql.analyzer.Analysis.AccessControlInfo
 
AccessControlManager - Class in io.prestosql.security
 
AccessControlManager(TransactionManager) - Constructor for class io.prestosql.security.AccessControlManager
 
AccessControlModule - Class in io.prestosql.security
 
AccessControlModule() - Constructor for class io.prestosql.security.AccessControlModule
 
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
 
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
 
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(PrestoWarning) - Method in class io.prestosql.execution.warnings.DefaultWarningCollector
 
add(PrestoWarning) - Method in interface io.prestosql.execution.warnings.WarningCollector
 
add(Object...) - Method in class io.prestosql.metadata.InternalTable.Builder
 
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.LegacyArrayAggregationGroupState
Deprecated.
 
add(Block, int) - Method in class io.prestosql.operator.aggregation.arrayagg.SingleArrayAggregationState
 
add(DoubleHistogramAggregation.State, long, double, double) - Static method in class io.prestosql.operator.aggregation.DoubleHistogramAggregation
 
add(DoubleHistogramAggregation.State, long, double) - Static method in class io.prestosql.operator.aggregation.DoubleHistogramAggregation
 
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(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(Block, Block, int) - Method in class io.prestosql.operator.aggregation.multimapagg.GroupedMultimapAggregationState
 
add(Block, Block, int) - Method in class io.prestosql.operator.aggregation.multimapagg.LegacyGroupedMultimapAggregationState
Deprecated.
 
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(double) - Method in class io.prestosql.operator.aggregation.NumericHistogram
 
add(double, double) - Method in class io.prestosql.operator.aggregation.NumericHistogram
 
add(DoubleHistogramAggregation.State, long, long, double) - Static method in class io.prestosql.operator.aggregation.RealHistogramAggregation
 
add(DoubleHistogramAggregation.State, long, long) - Static method in class io.prestosql.operator.aggregation.RealHistogramAggregation
 
add(Block, int) - Method in class io.prestosql.operator.aggregation.TypedHeap
 
add(Block, Block, int) - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
add(Block, int) - Method in class io.prestosql.operator.aggregation.TypedSet
 
add(Page) - Method in class io.prestosql.operator.index.PageBuffer
Adds a page to the buffer.
add(OperatorStats...) - Method in class io.prestosql.operator.OperatorStats
 
add(Iterable<OperatorStats>) - Method in class io.prestosql.operator.OperatorStats
 
add(PrestoWarning) - Method in class io.prestosql.testing.TestingWarningCollector
 
add(long, long) - Static method in class io.prestosql.type.BigintOperators
 
add(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
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) - Method in class io.prestosql.type.setdigest.SetDigest
 
add(Slice) - Method in class io.prestosql.type.setdigest.SetDigest
 
add(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
add(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
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(Block) - Method in class io.prestosql.operator.aggregation.TypedHeap
 
addAll(TypedKeyValueHeap) - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
addAll(Block, Block) - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
addAllEqualities(Iterable<Expression>) - Method in class io.prestosql.sql.planner.EqualityInference.Builder
 
addAndCollapseDistinctValues(StatisticRange) - Method in class io.prestosql.cost.StatisticRange
 
addAndGetPosition(Type, 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
 
addAssignedSplit(Node) - Method in class io.prestosql.execution.scheduler.NodeAssignmentStats
 
addBlockEncoding(BlockEncoding) - Method in class io.prestosql.block.BlockEncodingManager
 
addCatalogAccessControl(ConnectorId, ConnectorAccessControl) - Method in class io.prestosql.security.AccessControlManager
 
addChangeListener(MemoryPoolId, Consumer<MemoryPoolInfo>) - Method in class io.prestosql.memory.ClusterMemoryManager
 
addCoercion(Expression, Type, boolean) - Method in class io.prestosql.sql.analyzer.Analysis
 
addCoercions(Map<NodeRef<Expression>, Type>, Set<NodeRef<Expression>>) - 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
 
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
 
addColumnReferences(Map<NodeRef<Expression>, FieldId>) - 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) - Method in class io.prestosql.connector.ConnectorManager
 
addConnectorName(String, ConnectorHandleResolver) - Method in class io.prestosql.metadata.HandleResolver
 
addConnectorPageSinkProvider(ConnectorId, ConnectorPageSinkProvider) - Method in class io.prestosql.split.PageSinkManager
 
addConnectorPageSourceProvider(ConnectorId, ConnectorPageSourceProvider) - Method in class io.prestosql.split.PageSourceManager
 
addConnectorSessionProperties(ConnectorId, List<PropertyMetadata<?>>) - Method in class io.prestosql.metadata.SessionPropertyManager
 
addConnectorSplitManager(ConnectorId, ConnectorSplitManager) - Method in class io.prestosql.split.SplitManager
 
addCurrentNodeConnector(ConnectorId) - 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
 
addEquality(Expression) - Method in class io.prestosql.sql.planner.EqualityInference.Builder
 
addEquality(Expression, Expression) - Method in class io.prestosql.sql.planner.EqualityInference.Builder
 
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, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.optimizations.AddExchanges
 
AddExchangesBelowPartialAggregationOverGroupIdRuleSet - Class in io.prestosql.sql.planner.iterative.rule
Transforms
AddExchangesBelowPartialAggregationOverGroupIdRuleSet(Metadata, 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
 
addFieldValueTime(ConnectorSession, Slice, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
addFieldValueTimestamp(ConnectorSession, Slice, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
addFieldValueTimestampWithTimeZone(Slice, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
addFieldValueTimeWithTimeZone(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 class io.prestosql.execution.FailedQueryExecution
 
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.
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
 
addFunctionSignatures(Map<NodeRef<FunctionCall>, Signature>) - Method in class io.prestosql.sql.analyzer.Analysis
 
addGrouping(String, T) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.Builder
 
addIfAbsent(int) - Method in class io.prestosql.util.JsonUtil.HashTable
 
addImplementation(T) - Method in class io.prestosql.operator.ParametricImplementationsGroup.Builder
 
addIndexProvider(ConnectorId, ConnectorIndexProvider) - Method in class io.prestosql.index.IndexManager
 
addInput(Page) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
addInput(WindowIndex, List<Integer>, int, int) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
addInput(GroupByIdBlock, Page) - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
addInput(Page) - Method in class io.prestosql.operator.AggregationOperator
 
addInput(Page) - Method in class io.prestosql.operator.AssignUniqueIdOperator
 
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.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.FilterAndProjectOperator
 
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.HashSemiJoinOperator
 
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.MetadataDeleteOperator
 
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(Iterator<Optional<Page>>) - Method in class io.prestosql.operator.project.MergingPageOutput
 
addInput(Page) - Method in class io.prestosql.operator.RowNumberOperator
 
addInput(Page) - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
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.StreamingAggregationOperator
 
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.TopNRowNumberOperator
 
addInput(Page) - Method in class io.prestosql.operator.UnnestOperator
 
addInput(Page) - Method in class io.prestosql.operator.ValuesOperator
 
addInput(Page) - Method in class io.prestosql.operator.WindowOperator
 
addInput(Page) - Method in class io.prestosql.testing.NullOutputOperator
 
addInput(Page) - Method in class io.prestosql.testing.PageConsumerOperator
 
addIntermediate(Block) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
addIntermediate(GroupByIdBlock, Block) - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
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, 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(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.LegacyHistogramGroupState
Deprecated.
 
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(int) - Method in interface io.prestosql.operator.aggregation.state.DigestAndPercentileArrayState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.GroupedDigestAndPercentileArrayState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.SingleDigestAndPercentileArrayState
 
addMemoryUsage(int) - Method in interface io.prestosql.operator.aggregation.state.DigestAndPercentileState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.GroupedDigestAndPercentileState
 
addMemoryUsage(int) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.SingleDigestAndPercentileState
 
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(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
 
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
 
addNode(ConnectorId, Node...) - Method in class io.prestosql.metadata.InMemoryNodeManager
 
addNode(ConnectorId, Iterable<Node>) - 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
 
addOperatorContext(int, PlanNodeId, String) - Method in class io.prestosql.operator.DriverContext
 
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(Consumer<QueryExecution.QueryOutputInfo>) - Method in class io.prestosql.execution.DataDefinitionExecution
 
addOutputInfoListener(Consumer<QueryExecution.QueryOutputInfo>) - Method in class io.prestosql.execution.FailedQueryExecution
 
addOutputInfoListener(Consumer<QueryExecution.QueryOutputInfo>) - Method in interface io.prestosql.execution.QueryExecution
 
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(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
 
addOutputInfoListener(QueryId, Consumer<QueryExecution.QueryOutputInfo>) - Method in class io.prestosql.execution.SqlQueryManager
 
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
 
addPages(HttpPageBufferClient, List<SerializedPage>) - Method in interface io.prestosql.operator.HttpPageBufferClient.ClientCallback
 
addParametricType(ParametricType) - Method in class io.prestosql.type.TypeRegistry
 
addPartialComponents(LocalCostEstimate, LocalCostEstimate, LocalCostEstimate...) - Static method in class io.prestosql.cost.LocalCostEstimate
Sums partial cost estimates of some (single) plan node.
addPartitioningProvider(ConnectorId, 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(ConnectorId, 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.
addRelationCoercion(Relation, Type[]) - Method in class io.prestosql.sql.analyzer.Analysis
 
addResetSessionProperties(String) - Method in class io.prestosql.execution.QueryStateMachine
 
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 class io.prestosql.operator.ScanFilterAndProjectOperator
 
addSplit(Split) - Method in interface io.prestosql.operator.SourceOperator
 
addSplit(Split) - Method in class io.prestosql.operator.TableScanOperator
 
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.execution.DataDefinitionExecution
 
addStateChangeListener(StateMachine.StateChangeListener<QueryState>) - Method in class io.prestosql.execution.FailedQueryExecution
 
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(QueryId, StateMachine.StateChangeListener<QueryState>) - Method in interface io.prestosql.execution.QueryManager
Add a listener that fires each time the query state changes.
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<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<QueryState>) - Method in class io.prestosql.execution.SqlQueryExecution
 
addStateChangeListener(QueryId, StateMachine.StateChangeListener<QueryState>) - Method in class io.prestosql.execution.SqlQueryManager
 
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<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(TaskId, StateMachine.StateChangeListener<TaskState>) - Method in class io.prestosql.execution.SqlTaskManager
 
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<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 interface io.prestosql.execution.TaskManager
Adds a state change listener to the specified task.
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 class io.prestosql.server.remotetask.HttpRemoteTask
 
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
 
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(Node, RemoteTask) - Method in class io.prestosql.execution.NodeTaskMap
 
addTaskContext(TaskStateMachine, Session, boolean, boolean, OptionalInt) - Method in class io.prestosql.memory.QueryContext
 
addToTotalSpilledBytes(long) - Method in class io.prestosql.spiller.SpillerStats
 
addType(Type) - Method in class io.prestosql.type.TypeRegistry
 
addTypes(Map<NodeRef<Expression>, Type>) - Method in class io.prestosql.sql.analyzer.Analysis
 
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
 
aggregate(Class<?>) - Method in class io.prestosql.metadata.FunctionListBuilder
 
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(FunctionCall, Signature, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
aggregation() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
Aggregation() - Constructor for class io.prestosql.sql.planner.plan.Patterns.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
 
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, MethodHandle, MethodHandle, Optional<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, MethodHandle, MethodHandle, List<AggregationMetadata.AccumulatorStateDescriptor>, Type) - Constructor for class io.prestosql.operator.aggregation.AggregationMetadata
 
AggregationMetadata(String, List<AggregationMetadata.ParameterMetadata>, 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
 
AggregationTestUtils - Class in io.prestosql.testing
 
AggregationUtils - Class in io.prestosql.operator.aggregation
 
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
 
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 class io.prestosql.execution.scheduler.SimpleNodeSelector
 
allNodes() - Method in interface io.prestosql.execution.scheduler.SplitPlacementPolicy
 
allNodes() - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
AllNodes - Class in io.prestosql.metadata
 
AllNodes(Set<Node>, Set<Node>, Set<Node>, Set<Node>) - Constructor for class io.prestosql.metadata.AllNodes
 
AllowAllAccessControl - Class in io.prestosql.security
 
AllowAllAccessControl() - Constructor for class io.prestosql.security.AllowAllAccessControl
 
AllowAllSystemAccessControl - Class in io.prestosql.security
 
AllowAllSystemAccessControl() - Constructor for class io.prestosql.security.AllowAllSystemAccessControl
 
AllowAllSystemAccessControl.Factory - Class in io.prestosql.security
 
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, List<Expression>, boolean) - Constructor for class io.prestosql.sql.analyzer.Analysis
 
Analysis.AccessControlInfo - 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
 
analyze(Statement) - Method in class io.prestosql.sql.analyzer.Analyzer
 
analyze(Statement, boolean) - Method in class io.prestosql.sql.analyzer.Analyzer
 
analyze(Expression, Scope) - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
analyze(Session, Statement, List<Expression>, WarningCollector) - Method in class io.prestosql.sql.analyzer.QueryExplainer
 
analyzeExpression(Session, Metadata, AccessControl, SqlParser, Scope, Analysis, Expression, WarningCollector) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
analyzeExpressions(Session, Metadata, SqlParser, TypeProvider, Iterable<Expression>, List<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, AccessControl, Optional<QueryExplainer>, List<Expression>, WarningCollector) - Constructor for class io.prestosql.sql.analyzer.Analyzer
 
AnalyzeTableHandle - Class in io.prestosql.metadata
 
AnalyzeTableHandle(ConnectorId, ConnectorTransactionHandle, ConnectorTableHandle) - Constructor for class io.prestosql.metadata.AnalyzeTableHandle
 
and(Expression...) - Static method in class io.prestosql.sql.ExpressionUtils
 
and(Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
and(boolean, boolean) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
AndCodeGenerator - Class in io.prestosql.sql.gen
 
AndCodeGenerator() - Constructor for class io.prestosql.sql.gen.AndCodeGenerator
 
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
 
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, long) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
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, Slice) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
appendElement(Type, Block, Object) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
appendNext(PageBuilder, int) - Method in class io.prestosql.operator.ArrayOfRowsUnnester
 
appendNext(PageBuilder, int) - Method in class io.prestosql.operator.ArrayUnnester
 
appendNext(PageBuilder, int) - Method in class io.prestosql.operator.MapUnnester
 
appendNext(PageBuilder, int) - Method in interface io.prestosql.operator.Unnester
 
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(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(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, BlockBuilder) - Method in class io.prestosql.operator.PagesIndex
 
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 class io.prestosql.operator.PartitionedLookupSource
 
appendTo(int, int, PageBuilder, int) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
appendTo(int, int, BlockBuilder) - Method in class io.prestosql.operator.window.PagesWindowIndex
 
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.UnknownType
 
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
 
apply(Page) - Method in class io.prestosql.operator.exchange.PageChannelSelector
 
apply(Object, UnaryFunctionInterface) - Static method in class io.prestosql.operator.scalar.ApplyFunction
 
apply(Block) - Method in interface io.prestosql.operator.scalar.ArrayFilterFunction.FilterBlockLambda
 
apply(Boolean) - Method in interface io.prestosql.operator.scalar.ArrayFilterFunction.FilterBooleanLambda
 
apply(Double) - Method in interface io.prestosql.operator.scalar.ArrayFilterFunction.FilterDoubleLambda
 
apply(Long) - Method in interface io.prestosql.operator.scalar.ArrayFilterFunction.FilterLongLambda
 
apply(Slice) - Method in interface io.prestosql.operator.scalar.ArrayFilterFunction.FilterSliceLambda
 
apply(Void) - Method in interface io.prestosql.operator.scalar.ArrayFilterFunction.FilterVoidLambda
 
apply(Block, Block) - Method in interface io.prestosql.operator.scalar.ArraySortComparatorFunction.ComparatorBlockLambda
 
apply(Boolean, Boolean) - Method in interface io.prestosql.operator.scalar.ArraySortComparatorFunction.ComparatorBooleanLambda
 
apply(Double, Double) - Method in interface io.prestosql.operator.scalar.ArraySortComparatorFunction.ComparatorDoubleLambda
 
apply(Long, Long) - Method in interface io.prestosql.operator.scalar.ArraySortComparatorFunction.ComparatorLongLambda
 
apply(Slice, Slice) - Method in interface io.prestosql.operator.scalar.ArraySortComparatorFunction.ComparatorSliceLambda
 
apply() - Method in interface io.prestosql.operator.scalar.InvokeFunction.InvokeLambda
 
apply(Object, Object, Object) - Method in interface io.prestosql.operator.scalar.MapZipWithFunction.MapZipWithLambda
 
apply() - Method in interface io.prestosql.operator.scalar.TryFunction.TryBlockLambda
 
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.TrySliceLambda
 
apply(OGCGeometry, OGCGeometry, OptionalDouble) - Method in interface io.prestosql.operator.SpatialIndexBuilderOperator.SpatialPredicate
 
apply(Object, Object) - Method in interface io.prestosql.sql.gen.lambda.BinaryFunctionInterface
 
apply(Object) - Method in interface io.prestosql.sql.gen.lambda.UnaryFunctionInterface
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.AddIntermediateAggregations
 
apply(T, Captures, Rule.Context) - Method in interface io.prestosql.sql.planner.iterative.Rule
 
apply(TopNNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.CreatePartialTopN
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.DetermineJoinDistributionType
 
apply(SemiJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.DetermineSemiJoinDistributionType
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.EliminateCrossJoins
 
apply(LimitNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.EvaluateZeroLimit
 
apply(SampleNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.EvaluateZeroSample
 
apply(TopNNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.EvaluateZeroTopN
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins.ExtractSpatialInnerJoin
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ExtractSpatialJoins.ExtractSpatialLeftJoin
 
apply(SampleNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ImplementBernoulliSampleAsFilter
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ImplementFilteredAggregations
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.InlineProjections
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MergeFilters
 
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(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.MultipleDistinctAggregationToMarkDistinct
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ProjectOffPushDownRule
 
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(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneJoinChildrenColumns
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneOrderByInAggregation
 
apply(OutputNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneOutputColumns
 
apply(SemiJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PruneSemiJoinFilteringSourceColumns
 
apply(AggregationNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushAggregationThroughOuterJoin
 
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.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(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(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushPredicateIntoTableScan
 
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(ExchangeNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.PushRemoteExchangeThroughAssignUniqueId
 
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.PushTopNThroughUnion
 
apply(TableFinishNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveEmptyDelete
 
apply(SampleNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveFullSample
 
apply(ProjectNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveRedundantIdentityProjections
 
apply(FilterNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveTrivialFilters
 
apply(ApplyNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveUnreferencedScalarApplyNodes
 
apply(LateralJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.RemoveUnreferencedScalarLateralNodes
 
apply(JoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.ReorderJoins
 
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.TransformCorrelatedInPredicateToJoin
 
apply(LateralJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedLateralJoinToJoin
 
apply(LateralJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedScalarAggregationToJoin
 
apply(LateralJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedScalarSubquery
 
apply(LateralJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedSingleRowSubqueryToProject
 
apply(ApplyNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformExistsApplyToLateralNode
 
apply(ApplyNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedInPredicateSubqueryToSemiJoin
 
apply(LateralJoinNode, Captures, Rule.Context) - Method in class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedLateralToJoin
 
Apply() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Apply
 
APPLY_FUNCTION - Static variable in class io.prestosql.operator.scalar.ApplyFunction
 
applyBoundVariables(Signature, BoundVariables, int) - Static method in class io.prestosql.metadata.SignatureBinder
 
applyBoundVariables(List<TypeSignature>, BoundVariables) - Static method in class io.prestosql.metadata.SignatureBinder
 
applyBoundVariables(TypeSignature, BoundVariables) - Static method in class io.prestosql.metadata.SignatureBinder
 
applyExpressionRewrite() - Method in class io.prestosql.sql.planner.iterative.rule.ExpressionRewriteRuleSet
 
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
 
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
 
applyNode() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
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
 
ApproximateRealPercentileAggregations - Class in io.prestosql.operator.aggregation
 
ApproximateRealPercentileArrayAggregations - Class in io.prestosql.operator.aggregation
 
ApproximateSetAggregation - Class in io.prestosql.operator.aggregation
 
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(Signature, BoundVariables, TypeManager, FunctionRegistry) - 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
 
argumentProperties(ScalarFunctionImplementation.ArgumentProperty...) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.ChoiceBuilder
 
ArgumentProperty(ScalarFunctionImplementation.ArgumentType, Optional<ScalarFunctionImplementation.NullConvention>, Optional<Class>) - Constructor for class io.prestosql.operator.scalar.ScalarFunctionImplementation.ArgumentProperty
 
argumentTypes(TypeSignature...) - Method in class io.prestosql.metadata.SignatureBuilder
 
argumentTypes(List<TypeSignature>) - Method in class io.prestosql.metadata.SignatureBuilder
 
arithmeticExpressionSignature(ArithmeticBinaryExpression.Operator, Type, Type, Type) - Static method in class io.prestosql.sql.relational.Signatures
 
arithmeticNegationSignature(Type, Type) - Static method in class io.prestosql.sql.relational.Signatures
 
ARRAY - Static variable in class io.prestosql.type.ArrayParametricType
 
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
 
ArrayAggGroupImplementation - Enum in io.prestosql.operator.aggregation.arrayagg
 
ArrayAggregationFunction - Class in io.prestosql.operator.aggregation.arrayagg
 
ArrayAggregationFunction(ArrayAggGroupImplementation) - Constructor for class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
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, ArrayAggGroupImplementation) - 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
 
arrayCardinality(Block) - Static method in class io.prestosql.operator.scalar.ArrayCardinalityFunction
 
ArrayCardinalityFunction - Class in io.prestosql.operator.scalar
 
ArrayConcatFunction - Class in io.prestosql.operator.scalar
 
ArrayConcatUtils - Class in io.prestosql.operator.scalar
 
ArrayConstructor - Class in io.prestosql.operator.scalar
 
ArrayConstructor() - Constructor for class io.prestosql.operator.scalar.ArrayConstructor
 
arrayConstructor() - Static method in class io.prestosql.operator.scalar.ArrayFunctions
 
arrayConstructorSignature(Type, List<? extends Type>) - Static method in class io.prestosql.sql.relational.Signatures
 
arrayConstructorSignature(TypeSignature, List<TypeSignature>) - Static method in class io.prestosql.sql.relational.Signatures
 
ArrayContains - Class in io.prestosql.operator.scalar
 
ArrayDistinctFromOperator - 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
 
ArrayEqualOperator - Class in io.prestosql.operator.scalar
 
ArrayExceptFunction - Class in io.prestosql.operator.scalar
 
ArrayFilterFunction - Class in io.prestosql.operator.scalar
 
ArrayFilterFunction.FilterBlockLambda - Interface in io.prestosql.operator.scalar
 
ArrayFilterFunction.FilterBooleanLambda - Interface in io.prestosql.operator.scalar
 
ArrayFilterFunction.FilterDoubleLambda - Interface in io.prestosql.operator.scalar
 
ArrayFilterFunction.FilterLongLambda - Interface in io.prestosql.operator.scalar
 
ArrayFilterFunction.FilterSliceLambda - Interface in io.prestosql.operator.scalar
 
ArrayFilterFunction.FilterVoidLambda - Interface 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
 
ArrayGreaterThanOperator - Class in io.prestosql.operator.scalar
 
ArrayGreaterThanOrEqualOperator - Class in io.prestosql.operator.scalar
 
ArrayHashCodeOperator - Class in io.prestosql.operator.scalar
 
ArrayIndeterminateOperator - Class in io.prestosql.operator.scalar
 
ArrayIntersectFunction - Class in io.prestosql.operator.scalar
 
ArrayIntersectFunction(Type) - Constructor for class io.prestosql.operator.scalar.ArrayIntersectFunction
 
ArrayJoin - Class in io.prestosql.operator.scalar
 
ArrayJoin() - Constructor for class io.prestosql.operator.scalar.ArrayJoin
 
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.ArrayJoinWithNullReplacement - Class in io.prestosql.operator.scalar
 
ArrayJoinWithNullReplacement() - Constructor for class io.prestosql.operator.scalar.ArrayJoin.ArrayJoinWithNullReplacement
 
ArrayLessThanOperator - Class in io.prestosql.operator.scalar
 
ArrayLessThanOrEqualOperator - Class in io.prestosql.operator.scalar
 
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
 
ArrayMinMaxUtils - Class in io.prestosql.operator.scalar
 
ArrayNgramsFunction - Class in io.prestosql.operator.scalar
 
ArrayNotEqualOperator - Class in io.prestosql.operator.scalar
 
ArrayOfRowsUnnester - Class in io.prestosql.operator
 
ArrayOfRowsUnnester(Type) - Constructor for class io.prestosql.operator.ArrayOfRowsUnnester
 
ArrayParametricType - Class in io.prestosql.type
 
arrayPosition(Type, MethodHandle, Block, boolean) - 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, double) - Static method in class io.prestosql.operator.scalar.ArrayPositionFunction
 
arrayPosition(Type, MethodHandle, Block, Slice) - Static method in class io.prestosql.operator.scalar.ArrayPositionFunction
 
arrayPosition(Type, MethodHandle, Block, Block) - 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.ComparatorBlockLambda - Interface in io.prestosql.operator.scalar
 
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.ComparatorSliceLambda - Interface in io.prestosql.operator.scalar
 
ArraySortFunction - Class in io.prestosql.operator.scalar
 
ArraySortFunction(Type) - Constructor for class io.prestosql.operator.scalar.ArraySortFunction
 
arraysOverlap(MethodHandle, Type, Block, Block) - Method in class io.prestosql.operator.scalar.ArraysOverlapFunction
 
arraysOverlapBigInt(MethodHandle, 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
 
arraysOverlapInt(MethodHandle, 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
 
ArrayUnnester - Class in io.prestosql.operator
 
ArrayUnnester(Type) - Constructor for class io.prestosql.operator.ArrayUnnester
 
asBucketNodeMap() - Method in class io.prestosql.sql.planner.NodePartitionMap
 
asCatalogSchemaTableName() - Method in class io.prestosql.metadata.QualifiedObjectName
 
asin(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
asQualifiedTablePrefix() - 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
 
assignBucketToNode(int, Node) - Method in class io.prestosql.execution.scheduler.BucketNodeMap
 
assignBucketToNode(int, Node) - Method in class io.prestosql.execution.scheduler.FixedBucketNodeMap
 
assignBucketToNode(int, Node) - 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 - Class in io.prestosql.sql.planner.plan
 
AssignUniqueId(PlanNodeId, PlanNode, Symbol) - Constructor for class io.prestosql.sql.planner.plan.AssignUniqueId
 
assignUniqueId() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
AssignUniqueIdOperator - Class in io.prestosql.operator
 
AssignUniqueIdOperator(OperatorContext, AtomicLong) - Constructor for class io.prestosql.operator.AssignUniqueIdOperator
 
AssignUniqueIdOperator.AssignUniqueIdOperatorFactory - Class in io.prestosql.operator
 
AssignUniqueIdOperatorFactory(int, PlanNodeId) - Constructor for class io.prestosql.operator.AssignUniqueIdOperator.AssignUniqueIdOperatorFactory
 
AssignUniqueIdStatsRule - Class in io.prestosql.cost
 
AssignUniqueIdStatsRule() - Constructor for class io.prestosql.cost.AssignUniqueIdStatsRule
 
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(MemoryPoolAssignmentsRequest) - Method in class io.prestosql.memory.RemoteNodeMemory
 
asyncRefresh() - Method in class io.prestosql.metadata.RemoteNodeState
 
atan(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
atan2(double, double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
AttributeJdbcTable - Class in io.prestosql.connector.system.jdbc
 
AttributeJdbcTable() - Constructor for class io.prestosql.connector.system.jdbc.AttributeJdbcTable
 
authenticate(HttpServletRequest) - Method in interface io.prestosql.server.security.Authenticator
 
authenticate(HttpServletRequest) - Method in class io.prestosql.server.security.CertificateAuthenticator
 
authenticate(HttpServletRequest) - Method in class io.prestosql.server.security.JsonWebTokenAuthenticator
 
authenticate(HttpServletRequest) - Method in class io.prestosql.server.security.KerberosAuthenticator
 
authenticate(HttpServletRequest) - Method in class io.prestosql.server.security.PasswordAuthenticator
 
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>) - Constructor for class io.prestosql.server.security.AuthenticationFilter
 
Authenticator - Interface in io.prestosql.server.security
 
AutoCloseableCloser - Class in io.prestosql.util
This class is inspired by com.google.common.io.Closer
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
 

B

Backoff - Class in io.prestosql.server.remotetask
 
Backoff(Duration) - Constructor for class io.prestosql.server.remotetask.Backoff
 
Backoff(Duration, Ticker) - Constructor for class io.prestosql.server.remotetask.Backoff
 
Backoff(int, Duration, Ticker, List<Duration>) - 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
 
BasicQueryInfo - Class in io.prestosql.server
Lightweight version of QueryInfo.
BasicQueryInfo(QueryId, SessionRepresentation, Optional<ResourceGroupId>, QueryState, MemoryPoolId, boolean, URI, String, BasicQueryStats, ErrorType, ErrorCode) - Constructor for class io.prestosql.server.BasicQueryInfo
 
BasicQueryInfo(QueryInfo) - Constructor for class io.prestosql.server.BasicQueryInfo
 
BasicQueryStats - Class in io.prestosql.server
Lightweight version of QueryStats.
BasicQueryStats(DateTime, DateTime, Duration, Duration, Duration, int, int, int, int, DataSize, long, double, DataSize, DataSize, DataSize, DataSize, Duration, Duration, boolean, Set<BlockedReason>, OptionalDouble) - Constructor for class io.prestosql.server.BasicQueryStats
 
BasicQueryStats(QueryStats) - Constructor for class io.prestosql.server.BasicQueryStats
 
BasicStageStats - Class in io.prestosql.execution
 
BasicStageStats(boolean, int, int, int, int, DataSize, long, DataSize, long, DataSize, long, long, DataSize, DataSize, Duration, Duration, boolean, Set<BlockedReason>, OptionalDouble) - Constructor for class io.prestosql.execution.BasicStageStats
 
begin(String, Session, URI, ResourceGroupId, boolean, TransactionManager, AccessControl, Executor, Metadata, WarningCollector) - 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
 
beginConsumption() - Method in class io.prestosql.operator.PartitionedConsumption
 
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
 
beginDistributedPlanning() - Method in class io.prestosql.execution.QueryStateMachine
 
beginInsert(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Begin insert query
beginInsert(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
beginInsert(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.testing.TestingMetadata
 
beginQuery(Session, Set<ConnectorId>) - Method in interface io.prestosql.metadata.Metadata
Start a SELECT/UPDATE/INSERT/DELETE query
beginQuery(Session, Set<ConnectorId>) - 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(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(boolean) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
beginTransaction(IsolationLevel, boolean, boolean) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
beginTransaction(IsolationLevel, boolean) - Method in interface io.prestosql.transaction.InternalConnector
 
beginTransaction(TransactionId, IsolationLevel, boolean) - Method in interface io.prestosql.transaction.InternalConnector
 
beginTransaction(boolean) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
beginTransaction(IsolationLevel, boolean, boolean) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
beginTransaction(boolean) - Method in interface io.prestosql.transaction.TransactionManager
 
beginTransaction(IsolationLevel, boolean, boolean) - Method in interface io.prestosql.transaction.TransactionManager
 
beginTransactionId(TransactionId, TransactionManager, AccessControl) - Method in class io.prestosql.Session
 
BENCHMARK - Static variable in class io.prestosql.execution.scheduler.NodeSchedulerConfig.NetworkTopologyType
 
betaCdf(double, double, double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
between(long, long, long) - Static method in class io.prestosql.type.BigintOperators
 
between(boolean, boolean, boolean) - Static method in class io.prestosql.type.BooleanOperators
 
between(Slice, Slice, Slice) - Static method in class io.prestosql.type.CharOperators
 
between(long, long, long) - Static method in class io.prestosql.type.DateOperators
 
between(double, double, double) - Static method in class io.prestosql.type.DoubleOperators
 
between(long, long, long) - Static method in class io.prestosql.type.IntegerOperators
 
between(long, long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
between(long, long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
between(Slice, Slice, Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
between(long, long, long) - Static method in class io.prestosql.type.RealOperators
 
between(long, long, long) - Static method in class io.prestosql.type.SmallintOperators
 
between(long, long, long) - Static method in class io.prestosql.type.TimeOperators
 
between(long, long, long) - Static method in class io.prestosql.type.TimestampOperators
 
between(long, long, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
between(long, long, long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
between(long, long, long) - Static method in class io.prestosql.type.TinyintOperators
 
between(boolean, boolean, boolean) - Static method in class io.prestosql.type.UnknownOperators
 
between(Slice, Slice, Slice) - Static method in class io.prestosql.type.VarbinaryOperators
 
between(Slice, Slice, Slice) - Static method in class io.prestosql.type.VarcharOperators
 
betweenLongLongLong(Slice, Slice, Slice) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
betweenShortShortShort(long, long, long) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
betweenSignature(Type, Type, Type) - Static method in class io.prestosql.sql.relational.Signatures
 
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
 
bigintDistinct(Block) - Method in class io.prestosql.operator.scalar.ArrayDistinctFunction
 
BigintDistinctFromOperator() - Constructor for class io.prestosql.type.BigintOperators.BigintDistinctFromOperator
 
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
 
BigintOperators.BigintDistinctFromOperator - 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(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>, List<Type>, List<Integer>, List<SortOrder>, PagesIndex.Factory, boolean, JoinCompiler, 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, List<LambdaProvider>, Session) - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactoryBinder
 
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, 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, List<LambdaProvider>, Session) - Method in class io.prestosql.operator.aggregation.LazyAccumulatorFactoryBinder
 
bind(MethodHandle) - Method in class io.prestosql.sql.gen.CallSiteBinder
 
bind(Object, Class<?>) - Method in class io.prestosql.sql.gen.CallSiteBinder
 
BIND - Static variable in class io.prestosql.sql.relational.Signatures
 
BindCodeGenerator - Class in io.prestosql.sql.gen
 
BindCodeGenerator(Map<LambdaDefinitionExpression, LambdaBytecodeGenerator.CompiledLambda>, Class) - Constructor for class io.prestosql.sql.gen.BindCodeGenerator
 
bindDependencies(MethodHandle, List<ImplementationDependency>, BoundVariables, TypeManager, FunctionRegistry) - Static method in class io.prestosql.operator.ParametricFunctionHelpers
 
Binding - Class in io.prestosql.sql.gen
 
Binding(long, MethodType) - Constructor for class io.prestosql.sql.gen.Binding
 
bindSignature(Type, List<Type>, Type) - Static method in class io.prestosql.sql.relational.Signatures
 
bindVariables(List<? extends TypeSignatureProvider>) - Method in class io.prestosql.metadata.SignatureBinder
 
bindVariables(List<? extends TypeSignatureProvider>, Type) - Method in class io.prestosql.metadata.SignatureBinder
 
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
 
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
 
bitwiseXor(long, long) - Static method in class io.prestosql.operator.scalar.BitwiseFunctions
 
BlockAndBlockPositionValueState - Interface in io.prestosql.operator.aggregation.minmaxby
 
blockArrayMax(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMaxFunction
 
blockArrayMin(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMinFunction
 
BlockBooleanState - Interface in io.prestosql.operator.aggregation.minmaxby
 
BlockComparator - Interface in io.prestosql.operator.aggregation
 
BlockDoubleState - Interface in io.prestosql.operator.aggregation.minmaxby
 
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.
BlockedReason - Enum in io.prestosql.operator
 
blockElementAt(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayElementAtFunction
 
BlockEncodingManager - Class in io.prestosql.block
 
BlockEncodingManager(TypeManager, BlockEncoding...) - Constructor for class io.prestosql.block.BlockEncodingManager
 
BlockEncodingManager(TypeManager, Set<BlockEncoding>) - Constructor for class io.prestosql.block.BlockEncodingManager
 
BlockJsonSerde - Class in io.prestosql.block
 
BlockJsonSerde.Deserializer - Class in io.prestosql.block
 
BlockJsonSerde.Serializer - Class in io.prestosql.block
 
BlockLongState - Interface in io.prestosql.operator.aggregation.minmaxby
 
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
 
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
 
booleanArrayMinMax(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMinMaxUtils
 
BooleanBooleanState - Interface in io.prestosql.operator.aggregation.minmaxby
 
BooleanDistinctFromOperator() - Constructor for class io.prestosql.type.BooleanOperators.BooleanDistinctFromOperator
 
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
 
BooleanOperators.BooleanDistinctFromOperator - 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
 
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 - Class in io.prestosql.sql.gen
 
bootstrap(MethodHandles.Lookup, String, MethodType, long) - Static method in class io.prestosql.sql.gen.Bootstrap
 
BOOTSTRAP_METHOD - Static variable in class io.prestosql.sql.gen.Bootstrap
 
BoundVariables - Class in io.prestosql.metadata
 
BoundVariables(Map<String, Type>, Map<String, Long>) - Constructor for class io.prestosql.metadata.BoundVariables
 
BoundVariables.Builder - Class in io.prestosql.metadata
 
boxedLongLong(Slice, Slice, MethodHandle) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
boxedShortShort(long, long, MethodHandle) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
boxPrimitive(Class<?>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
boxPrimitiveIfNecessary(Scope, Class<?>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
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) - Constructor for class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
BucketedSplitPlacementPolicy(NodeSelector, List<Node>, 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.BoundVariables.Builder
 
build() - Method in class io.prestosql.metadata.InternalTable.Builder
 
build() - Method in class io.prestosql.metadata.MetadataUtil.SchemaMetadataBuilder
 
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(JoinProbe) - Method in class io.prestosql.operator.LookupJoinPageBuilder
 
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.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.EqualityInference.Builder
 
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.MaterializedResult.Builder
 
build() - Method in class io.prestosql.testing.TestingTaskContext.Builder
 
builder() - Static method in class io.prestosql.cost.PlanNodeStatsEstimate
 
Builder() - Constructor for class io.prestosql.cost.PlanNodeStatsEstimate.Builder
 
builder() - Static method in class io.prestosql.cost.SymbolStatsEstimate
 
Builder() - Constructor for class io.prestosql.cost.SymbolStatsEstimate.Builder
 
builder() - Static method in class io.prestosql.metadata.BoundVariables
 
Builder() - Constructor for class io.prestosql.metadata.BoundVariables.Builder
 
builder(ColumnMetadata...) - Static method in class io.prestosql.metadata.InternalTable
 
builder(List<ColumnMetadata>) - Static method in class io.prestosql.metadata.InternalTable
 
Builder(List<String>, List<Type>) - Constructor for class io.prestosql.metadata.InternalTable.Builder
 
builder() - Static method in class io.prestosql.metadata.Signature
 
builder(Class<?>) - Static method in class io.prestosql.metadata.SqlScalarFunction
 
builder(int) - Static method in class io.prestosql.operator.ArrayPositionLinks
 
builder() - Static method in class io.prestosql.operator.ParametricImplementationsGroup
 
Builder(Signature, List<Optional<Class<?>>>, Map<String, Class<?>>, Class<?>) - Constructor for class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.Builder
 
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() - Static method in class io.prestosql.sql.analyzer.Scope
 
Builder() - Constructor for class io.prestosql.sql.analyzer.Scope.Builder
 
Builder() - Constructor for class io.prestosql.sql.planner.EqualityInference.Builder
 
builder() - Static method in class io.prestosql.sql.planner.iterative.RuleIndex
 
Builder() - Constructor for class io.prestosql.sql.planner.iterative.RuleIndex.Builder
 
builder() - Static method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
Builder() - Constructor for class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
Builder(ActualProperties.Global, List<LocalProperty<Symbol>>, Map<Symbol, NullableValue>) - Constructor for class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
builder() - Static method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
Builder() - Constructor for class io.prestosql.sql.planner.optimizations.SymbolMapper.Builder
 
builder() - Static method in class io.prestosql.sql.planner.plan.Assignments
 
Builder() - Constructor for class io.prestosql.sql.planner.plan.Assignments.Builder
 
builder() - Static method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
Builder() - Constructor for class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.Builder
 
builder(Executor, ScheduledExecutorService, Session) - Static method in class io.prestosql.testing.TestingTaskContext
 
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(PlanNode) - Static method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
Builds all (distinct) JoinGraph-es whole plan tree.
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
 
buildShallowFrom(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
Builds JoinGraph containing plan node.
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, FunctionRegistry) - 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
 

C

CachedInstanceBinder - Class in io.prestosql.sql.gen
 
CachedInstanceBinder(ClassDefinition, CallSiteBinder) - Constructor for class io.prestosql.sql.gen.CachedInstanceBinder
 
CacheStatsMBean - Class in io.prestosql.sql.gen
 
CacheStatsMBean(LoadingCache<?, ?>) - Constructor for class io.prestosql.sql.gen.CacheStatsMBean
 
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(T, StatsProvider, Lookup, Session, TypeProvider) - Method in interface io.prestosql.cost.ComposableStatsCalculator.Rule
 
calculate(OutputNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.OutputStatsRule
 
calculate(Expression, PlanNodeStatsEstimate, Session, TypeProvider) - Method in class io.prestosql.cost.ScalarStatsCalculator
 
calculate(SemiJoinNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.SemiJoinStatsRule
 
calculate(T, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.SimpleStatsRule
 
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
 
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
 
calculatePrefixesWithTableName(ConnectorSession, Set<QualifiedTablePrefix>, TupleDomain<ColumnHandle>, Optional<Predicate<Map<ColumnHandle, NullableValue>>>) - Method in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
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(Signature, Type, RowExpression...) - Static method in class io.prestosql.sql.relational.Expressions
 
call(Signature, Type, List<RowExpression>) - Static method in class io.prestosql.sql.relational.Expressions
 
CallExpression - Class in io.prestosql.sql.relational
 
CallExpression(Signature, Type, 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(Type) - Method in class io.prestosql.metadata.TypeVariableConstraint
 
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.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
 
cancelQuery() - Method in class io.prestosql.execution.DataDefinitionExecution
 
cancelQuery() - Method in class io.prestosql.execution.FailedQueryExecution
 
cancelQuery() - Method in interface io.prestosql.execution.QueryExecution
 
cancelQuery(QueryId) - Method in interface io.prestosql.execution.QueryManager
Attempts to fail the query due to a user cancellation.
cancelQuery() - Method in class io.prestosql.execution.SqlQueryExecution
 
cancelQuery(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
cancelQuery(QueryId, long) - Method in class io.prestosql.server.protocol.StatementResource
 
cancelQuery(QueryId) - Method in class io.prestosql.server.QueryResource
 
cancelStage(StageId) - Method in class io.prestosql.execution.DataDefinitionExecution
 
cancelStage(StageId) - Method in class io.prestosql.execution.FailedQueryExecution
 
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
 
cancelStage(StageId) - Method in class io.prestosql.server.QueryResource
 
cancelStage(StageId) - Method in class io.prestosql.server.StageResource
 
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.TypeRegistry
 
canonicalizeExpression(Expression) - 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() - 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
 
canResolveOperator(OperatorType, Type, List<? extends Type>) - Method in class io.prestosql.metadata.FunctionRegistry
 
capStats(PlanNodeStatsEstimate, PlanNodeStatsEstimate) - Static method in class io.prestosql.cost.PlanNodeStatsEstimateMath
 
cardinality(Slice) - Static method in class io.prestosql.operator.scalar.HyperLogLogFunctions
 
cardinality() - Method in class io.prestosql.type.setdigest.SetDigest
 
cardinality(Slice) - Static method in class io.prestosql.type.setdigest.SetDigestFunctions
 
CAST - Static variable in class io.prestosql.sql.relational.Signatures
 
CAST_FROM_UNKNOWN - Static variable in class io.prestosql.operator.scalar.CastFromUnknownOperator
 
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
 
castCharToLikePattern(Long, Slice) - Static method in class io.prestosql.type.LikeFunctions
 
castCharToRe2JRegexp(int, int) - Static method in class io.prestosql.operator.scalar.Re2JCastToRegexpFunction
 
CastCodeGenerator - Class in io.prestosql.sql.gen
 
CastCodeGenerator() - Constructor for class io.prestosql.sql.gen.CastCodeGenerator
 
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
 
castFromSlice(ConnectorSession, Slice) - Static method in class io.prestosql.type.TimeOperators
 
castFromSlice(ConnectorSession, Slice) - Static method in class io.prestosql.type.TimestampOperators
 
castFromSlice(ConnectorSession, Slice) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
castFromSlice(Slice) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
castFromSmallInt(long) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castFromTimestamp(ConnectorSession, 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
 
castFromVarbinary(Slice) - Static method in class io.prestosql.type.HyperLogLogOperators
 
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
 
castFromVarchar(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castFromVarcharToIpAddress(Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
castSignature(Type, Type) - Static method in class io.prestosql.sql.relational.Signatures
 
castToBigint(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
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.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
 
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(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToBoolean(long) - Static method in class io.prestosql.type.BigintOperators
 
castToBoolean(double) - Static method in class io.prestosql.type.DoubleOperators
 
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.type.VarcharOperators
 
castToDate(ConnectorSession, long) - Static method in class io.prestosql.type.TimestampOperators
 
castToDate(long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
castToDouble(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToDouble(long) - Static method in class io.prestosql.type.BigintOperators
 
castToDouble(boolean) - Static method in class io.prestosql.type.BooleanOperators
 
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.type.VarcharOperators
 
castToFloat(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
castToHyperLogLog(Slice) - Static method in class io.prestosql.type.setdigest.SetDigestOperators
 
castToInteger(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToInteger(long) - Static method in class io.prestosql.type.BigintOperators
 
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.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.type.VarcharOperators
 
castToLong(double) - Static method in class io.prestosql.type.DoubleOperators
 
castToLong(long) - Static method in class io.prestosql.type.RealOperators
 
castToP4Hll(Slice) - Static method in class io.prestosql.type.HyperLogLogOperators
 
castToReal(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToReal(long) - Static method in class io.prestosql.type.BigintOperators
 
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.IntegerOperators
 
castToReal(long) - Static method in class io.prestosql.type.SmallintOperators
 
castToReal(long) - Static method in class io.prestosql.type.TinyintOperators
 
castToRegexp(int, int, boolean, long, Slice) - Static method in class io.prestosql.operator.scalar.Re2JCastToRegexpFunction
 
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
 
castToSlice(ConnectorSession, long) - Static method in class io.prestosql.type.TimeOperators
 
castToSlice(ConnectorSession, long) - Static method in class io.prestosql.type.TimestampOperators
 
castToSlice(long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
castToSlice(long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
castToSmallint(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToSmallint(long) - Static method in class io.prestosql.type.BigintOperators
 
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.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.type.VarcharOperators
 
castToTime(ConnectorSession, long) - Static method in class io.prestosql.type.TimestampOperators
 
castToTime(ConnectorSession, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
castToTime(ConnectorSession, long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
castToTimestamp(ConnectorSession, long) - Static method in class io.prestosql.type.DateOperators
 
castToTimestamp(long) - Static method in class io.prestosql.type.TimeOperators
 
castToTimestamp(ConnectorSession, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
castToTimestamp(ConnectorSession, long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
castToTimestampWithTimeZone(ConnectorSession, long) - Static method in class io.prestosql.type.DateOperators
 
castToTimestampWithTimeZone(ConnectorSession, long) - Static method in class io.prestosql.type.TimeOperators
 
castToTimestampWithTimeZone(ConnectorSession, long) - Static method in class io.prestosql.type.TimestampOperators
 
castToTimestampWithTimeZone(long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
castToTimeWithTimeZone(ConnectorSession, long) - Static method in class io.prestosql.type.TimeOperators
 
castToTimeWithTimeZone(ConnectorSession, long) - Static method in class io.prestosql.type.TimestampOperators
 
castToTimeWithTimeZone(ConnectorSession, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
castToTinyint(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToTinyint(long) - Static method in class io.prestosql.type.BigintOperators
 
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.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.type.VarcharOperators
 
castToVarchar(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
castToVarchar(long) - Static method in class io.prestosql.type.BigintOperators
 
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.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
 
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
 
castVarcharToLikePattern(Slice) - Static method in class io.prestosql.type.LikeFunctions
 
castVarcharToRe2JRegexp(int, int) - Static method in class io.prestosql.operator.scalar.Re2JCastToRegexpFunction
 
Catalog - Class in io.prestosql.metadata
 
Catalog(String, ConnectorId, Connector, ConnectorId, Connector, ConnectorId, 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
 
CatalogAccessControlRule - Class in io.prestosql.security
 
CatalogAccessControlRule(boolean, Optional<Pattern>, Optional<Pattern>) - Constructor for class io.prestosql.security.CatalogAccessControlRule
 
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(ConnectorId, ConnectorMetadata, ConnectorTransactionHandle, ConnectorId, ConnectorMetadata, ConnectorTransactionHandle, ConnectorId, ConnectorMetadata, ConnectorTransactionHandle, Set<ConnectorCapabilities>) - Constructor for class io.prestosql.metadata.CatalogMetadata
 
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(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
ceiling(double) - 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() - Constructor for class io.prestosql.server.security.CertificateAuthenticator
 
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) - 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
 
CharDistinctFromOperator() - Constructor for class io.prestosql.type.CharOperators.CharDistinctFromOperator
 
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
 
CharOperators - Class in io.prestosql.type
 
CharOperators.CharDistinctFromOperator - Class in io.prestosql.type
 
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(Slice, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
charSubstr(Slice, long, 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
 
checkCanAccessCatalog(Identity, String) - Method in interface io.prestosql.security.AccessControl
Check whether identity is allowed to access catalog
checkCanAccessCatalog(Identity, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanAccessCatalog(Identity, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanAccessCatalog(Identity, String) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanAccessCatalog(Identity, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanAccessCatalog(Identity, String) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanAccessCatalog(Identity, String) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
checkCanAddColumn(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanAddColumn(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanAddColumns(TransactionId, Identity, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to add columns to the specified table.
checkCanAddColumns(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanAddColumns(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanAddColumns(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanAddColumns(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanCreateRole(TransactionId, Identity, String, Optional<PrestoPrincipal>, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to create the specified role.
checkCanCreateRole(TransactionId, Identity, String, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanCreateRole(TransactionId, Identity, String, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanCreateRole(TransactionId, Identity, String, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanCreateSchema(TransactionId, Identity, CatalogSchemaName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to create the specified schema.
checkCanCreateSchema(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanCreateSchema(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanCreateSchema(Identity, CatalogSchemaName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanCreateSchema(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanCreateSchema(Identity, CatalogSchemaName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanCreateSchema(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanCreateTable(TransactionId, Identity, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to create the specified table.
checkCanCreateTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanCreateTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanCreateTable(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanCreateTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanCreateTable(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanCreateTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanCreateView(TransactionId, Identity, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to create the specified view.
checkCanCreateView(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanCreateView(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanCreateView(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanCreateView(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanCreateView(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanCreateView(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanCreateViewWithSelectFromColumns(TransactionId, Identity, 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(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.AccessControlManager
 
checkCanCreateViewWithSelectFromColumns(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanCreateViewWithSelectFromColumns(Identity, CatalogSchemaTableName, Set<String>) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanCreateViewWithSelectFromColumns(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanCreateViewWithSelectFromColumns(Identity, CatalogSchemaTableName, Set<String>) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanCreateViewWithSelectFromColumns(Identity, CatalogSchemaTableName, Set<String>) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
checkCanCreateViewWithSelectFromColumns(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.ViewAccessControl
 
checkCanCreateViewWithSelectFromColumns(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanDeleteFromTable(TransactionId, Identity, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to delete from the specified table.
checkCanDeleteFromTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDeleteFromTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDeleteFromTable(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanDeleteFromTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDeleteFromTable(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanDeleteFromTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanDropColumn(TransactionId, Identity, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to drop columns from the specified table.
checkCanDropColumn(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDropColumn(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDropColumn(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanDropColumn(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDropColumn(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanDropColumn(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanDropRole(TransactionId, Identity, String, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to drop the specified role.
checkCanDropRole(TransactionId, Identity, String, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDropRole(TransactionId, Identity, String, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDropRole(TransactionId, Identity, String, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDropSchema(TransactionId, Identity, CatalogSchemaName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to drop the specified schema.
checkCanDropSchema(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDropSchema(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDropSchema(Identity, CatalogSchemaName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanDropSchema(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDropSchema(Identity, CatalogSchemaName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanDropSchema(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanDropTable(TransactionId, Identity, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to drop the specified table.
checkCanDropTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDropTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDropTable(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanDropTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDropTable(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanDropTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanDropView(TransactionId, Identity, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to drop the specified view.
checkCanDropView(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanDropView(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanDropView(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanDropView(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanDropView(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanDropView(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanGrantRoles(TransactionId, Identity, 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(TransactionId, Identity, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanGrantRoles(TransactionId, Identity, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanGrantRoles(TransactionId, Identity, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanGrantTablePrivilege(TransactionId, Identity, 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(TransactionId, Identity, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AccessControlManager
 
checkCanGrantTablePrivilege(TransactionId, Identity, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanGrantTablePrivilege(Identity, Privilege, CatalogSchemaTableName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanGrantTablePrivilege(TransactionId, Identity, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanGrantTablePrivilege(Identity, Privilege, CatalogSchemaTableName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanInsertIntoTable(TransactionId, Identity, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to insert into the specified table.
checkCanInsertIntoTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanInsertIntoTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanInsertIntoTable(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanInsertIntoTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanInsertIntoTable(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanInsertIntoTable(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanRenameColumn(TransactionId, Identity, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to rename a column in the specified table.
checkCanRenameColumn(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRenameColumn(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRenameColumn(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanRenameColumn(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRenameColumn(Identity, CatalogSchemaTableName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanRenameColumn(TransactionId, Identity, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanRenameSchema(TransactionId, Identity, CatalogSchemaName, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to rename the specified schema.
checkCanRenameSchema(TransactionId, Identity, CatalogSchemaName, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRenameSchema(TransactionId, Identity, CatalogSchemaName, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRenameSchema(Identity, CatalogSchemaName, String) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanRenameSchema(TransactionId, Identity, CatalogSchemaName, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRenameSchema(Identity, CatalogSchemaName, String) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanRenameSchema(TransactionId, Identity, CatalogSchemaName, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanRenameTable(TransactionId, Identity, QualifiedObjectName, QualifiedObjectName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to rename the specified table.
checkCanRenameTable(TransactionId, Identity, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRenameTable(TransactionId, Identity, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRenameTable(Identity, CatalogSchemaTableName, CatalogSchemaTableName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanRenameTable(TransactionId, Identity, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRenameTable(Identity, CatalogSchemaTableName, CatalogSchemaTableName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanRenameTable(TransactionId, Identity, QualifiedObjectName, QualifiedObjectName) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanRevokeRoles(TransactionId, Identity, 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(TransactionId, Identity, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRevokeRoles(TransactionId, Identity, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRevokeRoles(TransactionId, Identity, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRevokeTablePrivilege(TransactionId, Identity, 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(TransactionId, Identity, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AccessControlManager
 
checkCanRevokeTablePrivilege(TransactionId, Identity, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanRevokeTablePrivilege(Identity, Privilege, CatalogSchemaTableName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanRevokeTablePrivilege(TransactionId, Identity, Privilege, QualifiedObjectName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanRevokeTablePrivilege(Identity, Privilege, CatalogSchemaTableName, PrestoPrincipal, boolean) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanSelectFromColumns(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to select from the specified columns.
checkCanSelectFromColumns(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSelectFromColumns(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSelectFromColumns(Identity, CatalogSchemaTableName, Set<String>) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanSelectFromColumns(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSelectFromColumns(Identity, CatalogSchemaTableName, Set<String>) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanSelectFromColumns(Identity, CatalogSchemaTableName, Set<String>) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
checkCanSelectFromColumns(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in class io.prestosql.security.ViewAccessControl
 
checkCanSelectFromColumns(TransactionId, Identity, QualifiedObjectName, Set<String>) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanSetCatalogSessionProperty(TransactionId, Identity, String, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to set the specified catalog property.
checkCanSetCatalogSessionProperty(TransactionId, Identity, String, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetCatalogSessionProperty(TransactionId, Identity, String, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetCatalogSessionProperty(Identity, String, String) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanSetCatalogSessionProperty(TransactionId, Identity, String, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetCatalogSessionProperty(Identity, String, String) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanSetCatalogSessionProperty(Identity, String, String) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
checkCanSetCatalogSessionProperty(TransactionId, Identity, String, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanSetRole(TransactionId, Identity, String, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to set role for specified catalog.
checkCanSetRole(TransactionId, Identity, String, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetRole(TransactionId, Identity, String, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetRole(TransactionId, Identity, String, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
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.AllowAllSystemAccessControl
 
checkCanSetSystemSessionProperty(Identity, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetSystemSessionProperty(Identity, String) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanSetSystemSessionProperty(Identity, String) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
checkCanSetSystemSessionProperty(Identity, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanSetUser(Optional<Principal>, String) - Method in interface io.prestosql.security.AccessControl
Check if the principal is allowed to be the specified user.
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
checkCanSetUser(Optional<Principal>, String) - Method in class io.prestosql.testing.TestingAccessControlManager
 
checkCanShowCurrentRoles(TransactionId, Identity, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to show current roles on the specified catalog.
checkCanShowCurrentRoles(TransactionId, Identity, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowCurrentRoles(TransactionId, Identity, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowCurrentRoles(TransactionId, Identity, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowRoleGrants(TransactionId, Identity, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to show its own role grants on the specified catalog.
checkCanShowRoleGrants(TransactionId, Identity, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowRoleGrants(TransactionId, Identity, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowRoleGrants(TransactionId, Identity, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowRoles(TransactionId, Identity, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to show roles on the specified catalog.
checkCanShowRoles(TransactionId, Identity, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowRoles(TransactionId, Identity, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowRoles(Identity, String) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanShowRoles(TransactionId, Identity, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowRoles(Identity, String) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanShowRoles(Identity, String) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
checkCanShowSchemas(TransactionId, Identity, String) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to execute SHOW SCHEMAS in a catalog.
checkCanShowSchemas(TransactionId, Identity, String) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowSchemas(TransactionId, Identity, String) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowSchemas(Identity, String) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanShowSchemas(TransactionId, Identity, String) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowSchemas(Identity, String) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanShowSchemas(Identity, String) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
checkCanShowTablesMetadata(TransactionId, Identity, CatalogSchemaName) - Method in interface io.prestosql.security.AccessControl
Check if identity is allowed to show metadata of tables by executing SHOW TABLES, SHOW GRANTS etc.
checkCanShowTablesMetadata(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.security.AccessControlManager
 
checkCanShowTablesMetadata(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.security.AllowAllAccessControl
 
checkCanShowTablesMetadata(Identity, CatalogSchemaName) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
checkCanShowTablesMetadata(TransactionId, Identity, CatalogSchemaName) - Method in class io.prestosql.security.DenyAllAccessControl
 
checkCanShowTablesMetadata(Identity, CatalogSchemaName) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
checkCanShowTablesMetadata(Identity, CatalogSchemaName) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
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
 
checkedAdd(int, int) - Static method in class io.prestosql.operator.scalar.ConcatFunction
 
checkElementNotNull(boolean, String) - Static method in class io.prestosql.type.TypeUtils
 
checkIndex(Block, long) - Static method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
checkLongIsNotNull(Long) - Static method in class io.prestosql.operator.scalar.MapToMapCast
 
checkLowerCase(String, String) - Static method in class io.prestosql.metadata.MetadataUtil
 
checkNotNaN(String, double) - Static method in class io.prestosql.operator.scalar.AbstractGreatestLeast
 
checkObjectName(String, String, String) - Static method in class io.prestosql.metadata.MetadataUtil
 
checkRulesAreFiredBeforeAddExchangesRule() - Static method in class io.prestosql.sql.planner.iterative.rule.PreconditionRules
 
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
 
CHECKSUM_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
ChecksumAggregationFunction - Class in io.prestosql.operator.aggregation
 
ChecksumAggregationFunction() - Constructor for class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
checkTableName(String, Optional<String>, Optional<String>) - Static method in class io.prestosql.metadata.MetadataUtil
 
checkTableName(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
 
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
 
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
 
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.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.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.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.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.TableWriterOperator
 
close() - Method in class io.prestosql.operator.WindowOperator
 
close() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
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.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.EmptySplitPageSource
 
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
 
closeSinks(LocalExchange.LocalExchangeSinkFactoryId) - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeFactory
 
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
 
ClusterSizeMonitor - Class in io.prestosql.execution
 
ClusterSizeMonitor(InternalNodeManager, NodeSchedulerConfig, QueryManagerConfig) - Constructor for class io.prestosql.execution.ClusterSizeMonitor
 
ClusterSizeMonitor(InternalNodeManager, boolean, int, Duration, int, Duration) - Constructor for class io.prestosql.execution.ClusterSizeMonitor
 
ClusterStats(long, long, long, long, long, double, long, long, long) - Constructor for class io.prestosql.server.ClusterStatsResource.ClusterStats
 
ClusterStatsResource - Class in io.prestosql.server
 
ClusterStatsResource(NodeSchedulerConfig, InternalNodeManager, QueryManager, ClusterMemoryManager) - Constructor for class io.prestosql.server.ClusterStatsResource
 
ClusterStatsResource.ClusterStats - Class in io.prestosql.server
 
COALESCE - Static variable in class io.prestosql.sql.relational.Signatures
 
CoalesceCodeGenerator - Class in io.prestosql.sql.gen
 
CoalesceCodeGenerator() - Constructor for class io.prestosql.sql.gen.CoalesceCodeGenerator
 
coalesceSignature(Type, List<Type>) - Static method in class io.prestosql.sql.relational.Signatures
 
CODE_POINTS - Static variable in class io.prestosql.type.CodePointsType
 
codepoint(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
CodePointsType - Class in io.prestosql.type
 
CodePointsType() - Constructor for class io.prestosql.type.CodePointsType
 
Coercer - Class in io.prestosql.sql.planner
 
coerceTypeBase(Type, String) - Method in class io.prestosql.type.TypeRegistry
coerceTypeBase and isCovariantParametrizedType defines all hand-coded rules for type coercion.
COLOCATED_JOIN - Static variable in class io.prestosql.SystemSessionProperties
 
color(Slice) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
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

The value is truncated to the range [low, high] if it's outside.

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

The value is truncated to the range [0, 1] if necessary Color must be a valid rgb value of the form #rgb

COLOR - Static variable in class io.prestosql.type.ColorType
 
ColorDistinctFromOperator() - Constructor for class io.prestosql.type.ColorOperators.ColorDistinctFromOperator
 
ColorFunctions - Class in io.prestosql.operator.scalar
 
ColorFunctions.SystemColor - Enum in io.prestosql.operator.scalar
 
ColorOperators - Class in io.prestosql.type
 
ColorOperators.ColorDistinctFromOperator - Class in io.prestosql.type
 
ColorType - Class in io.prestosql.type
 
Column - Class in io.prestosql.execution
 
Column(String, String) - Constructor for class io.prestosql.execution.Column
 
column(String, Type) - Method in class io.prestosql.metadata.MetadataUtil.TableMetadataBuilder
 
ColumnConstraint(String, TypeSignature, IoPlanPrinter.FormattedDomain) - Constructor for class io.prestosql.sql.planner.planPrinter.IoPlanPrinter.ColumnConstraint
 
ColumnHandleJacksonModule - Class in io.prestosql.metadata
 
ColumnHandleJacksonModule(HandleResolver) - Constructor for class io.prestosql.metadata.ColumnHandleJacksonModule
 
ColumnJdbcTable - Class in io.prestosql.connector.system.jdbc
 
ColumnJdbcTable(Metadata, AccessControl) - Constructor for class io.prestosql.connector.system.jdbc.ColumnJdbcTable
 
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
 
ColumnStatisticMetadataKeyDeserializer() - Constructor for class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.ColumnStatisticMetadataKeyDeserializer
 
ColumnStatisticMetadataKeySerializer() - Constructor for class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.ColumnStatisticMetadataKeySerializer
 
combine(MethodHandle, NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
combine(MethodHandle, NullableDoubleState, NullableDoubleState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
combine(MethodHandle, NullableBooleanState, NullableBooleanState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
combine(MinMaxNState, MinMaxNState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
combine(DigestAndPercentileState, DigestAndPercentileState) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
combine(DigestAndPercentileArrayState, DigestAndPercentileArrayState) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileArrayAggregations
 
combine(DigestAndPercentileState, DigestAndPercentileState) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
combine(DigestAndPercentileArrayState, DigestAndPercentileArrayState) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileArrayAggregations
 
combine(DigestAndPercentileState, DigestAndPercentileState) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
combine(DigestAndPercentileArrayState, DigestAndPercentileArrayState) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileArrayAggregations
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
combine(NullableDoubleState, NullableDoubleState) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
combine(NullableBooleanState, NullableBooleanState) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
combine(BlockPositionState, BlockPositionState) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
combine(Type, ArrayAggregationState, ArrayAggregationState) - Static method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
combine(LongAndDoubleState, LongAndDoubleState) - Static method in class io.prestosql.operator.aggregation.AverageAggregations
 
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(TriStateBooleanState, TriStateBooleanState) - Static method in class io.prestosql.operator.aggregation.BooleanAndAggregation
 
combine(TriStateBooleanState, TriStateBooleanState) - Static method in class io.prestosql.operator.aggregation.BooleanOrAggregation
 
combine(CentralMomentsState, CentralMomentsState) - Static method in class io.prestosql.operator.aggregation.CentralMomentsAggregation
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
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(LongDecimalWithOverflowAndLongState, LongDecimalWithOverflowAndLongState) - Static method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
combine(LongDecimalWithOverflowState, LongDecimalWithOverflowState) - Static method in class io.prestosql.operator.aggregation.DecimalSumAggregation
 
combine(CorrelationState, CorrelationState) - Static method in class io.prestosql.operator.aggregation.DoubleCorrelationAggregation
 
combine(CovarianceState, CovarianceState) - Static method in class io.prestosql.operator.aggregation.DoubleCovarianceAggregation
 
combine(RegressionState, RegressionState) - Static method in class io.prestosql.operator.aggregation.DoubleRegressionAggregation
 
combine(NullableDoubleState, NullableDoubleState) - Static method in class io.prestosql.operator.aggregation.DoubleSumAggregation
 
combine(LongAndDoubleState, LongAndDoubleState) - Static method in class io.prestosql.operator.aggregation.GeometricMeanAggregations
 
combine(HistogramState, HistogramState) - Static method in class io.prestosql.operator.aggregation.histogram.Histogram
 
combine(LongAndDoubleState, LongAndDoubleState) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondAverageAggregation
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondSumAggregation
 
combine(LongAndDoubleState, LongAndDoubleState) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthAverageAggregation
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthSumAggregation
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.LongSumAggregation
 
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(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.MaxDataSizeForStats
 
combine(HyperLogLogState, HyperLogLogState) - Static method in class io.prestosql.operator.aggregation.MergeHyperLogLogAggregation
 
combine(QuantileDigestState, QuantileDigestState) - Static method in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
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(LongState, DoubleState, LongState, DoubleState) - Static method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
combine(CorrelationState, CorrelationState) - Static method in class io.prestosql.operator.aggregation.RealCorrelationAggregation
 
combine(CovarianceState, CovarianceState) - Static method in class io.prestosql.operator.aggregation.RealCovarianceAggregation
 
combine(LongAndDoubleState, LongAndDoubleState) - Static method in class io.prestosql.operator.aggregation.RealGeometricMeanAggregations
 
combine(RegressionState, RegressionState) - Static method in class io.prestosql.operator.aggregation.RealRegressionAggregation
 
combine(NullableDoubleState, NullableDoubleState) - Static method in class io.prestosql.operator.aggregation.RealSumAggregation
 
combine(NullableLongState, NullableLongState, BinaryFunctionInterface, BinaryFunctionInterface) - Static method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
combine(NullableDoubleState, NullableDoubleState, BinaryFunctionInterface, BinaryFunctionInterface) - Static method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
combine(NullableBooleanState, NullableBooleanState, BinaryFunctionInterface, BinaryFunctionInterface) - Static method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
combine(NullableLongState, NullableLongState) - Static method in class io.prestosql.operator.aggregation.SumDataSizeForStats
 
combine(VarianceState, VarianceState) - Static method in class io.prestosql.operator.aggregation.VarianceAggregation
 
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(Optional<T>, Optional<T>, BinaryOperator<T>) - Static method in class io.prestosql.util.Optionals
 
combineConjuncts(Expression...) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineConjuncts(Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineDisjuncts(Expression...) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineDisjuncts(Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineDisjunctsWithDefault(Collection<Expression>, Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
CombineHashFunction - Class in io.prestosql.operator.scalar
 
combinePredicates(LogicalBinaryExpression.Operator, Expression...) - Static method in class io.prestosql.sql.ExpressionUtils
 
combinePredicates(LogicalBinaryExpression.Operator, Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
combineState(HyperLogLogState, HyperLogLogState) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
combineState(BooleanDistinctState, BooleanDistinctState) - 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(BooleanDistinctState, BooleanDistinctState) - 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
 
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
 
comparableTypeParameter(String) - Static method in class io.prestosql.metadata.Signature
 
comparableWithVariadicBound(String, String) - Static method in class io.prestosql.metadata.Signature
 
compare(Session, PlanCostEstimate, PlanCostEstimate) - Method in class io.prestosql.cost.CostComparator
 
compare(Page, Page) - Method in class io.prestosql.operator.RowComparator
 
compare(RowType, List<MethodHandle>, Block, Block) - Static method in class io.prestosql.operator.scalar.RowComparisonOperator
 
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(PrioritizedSplitRunner) - Method in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
compareTo(Block, int, Block, int) - Method in interface io.prestosql.operator.aggregation.BlockComparator
 
compareTo(int, int, int, Block, int, int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
compareTo(PagesIndex, int, int) - Method in interface io.prestosql.operator.PagesIndexComparator
 
compareTo(Page, int, Page, int) - Method in interface io.prestosql.operator.PageWithPositionComparator
 
compareTo(ParametricScalarImplementation.ParametricScalarImplementationChoice) - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
compareTo(PagesIndex, int, int) - Method in class io.prestosql.operator.SimplePagesIndexComparator
 
compareTo(Page, int, Page, int) - Method in class io.prestosql.operator.SimplePageWithPositionComparator
 
compareTo(Symbol) - Method in class io.prestosql.sql.planner.Symbol
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.type.ColorType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.type.FunctionType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.type.IpAddressType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.type.UnknownType
 
comparisonExpressionSignature(ComparisonExpression.Operator, Type, Type) - Static method in class io.prestosql.sql.relational.Signatures
 
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, FunctionRegistry, Class) - Static method in class io.prestosql.sql.gen.LambdaBytecodeGenerator
 
compileLookupSourceFactory(List<? extends Type>, List<Integer>, Optional<Integer>) - Method in class io.prestosql.sql.gen.JoinCompiler
 
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>, Optional<String>) - Method in class io.prestosql.sql.gen.ExpressionCompiler
 
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
 
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
 
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>, List<RemoteTask>) - Method in interface io.prestosql.execution.scheduler.NodeSelector
Identifies the nodes for running the specified splits.
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>) - Method in class io.prestosql.execution.scheduler.SimpleNodeSelector
 
computeAssignments(Set<Split>, List<RemoteTask>, BucketNodeMap) - Method in class io.prestosql.execution.scheduler.SimpleNodeSelector
 
computeAssignments(Set<Split>) - Method in interface io.prestosql.execution.scheduler.SplitPlacementPolicy
 
computeAssignments(Set<Split>, List<RemoteTask>) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
computeAssignments(Set<Split>, List<RemoteTask>, BucketNodeMap) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
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.
 
computeHash(Iterable<Symbol>) - Static method in class io.prestosql.sql.planner.optimizations.HashGenerationOptimizer
 
computeLevel(long) - Static method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
computeNext() - Method in class io.prestosql.operator.scalar.JsonPathTokenizer
 
computeSemiJoin(PlanNodeStatsEstimate, PlanNodeStatsEstimate, Symbol, Symbol) - Static method in class io.prestosql.cost.SemiJoinStatsCalculator
 
concat(Function<PolymorphicScalarFunctionBuilder.SpecializeContext, List<Object>>...) - Static method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
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
 
ConcatFunction - 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(ResourceGroup, SelectionContext<LegacyResourceGroupConfigurationManager.VoidContext>) - Method in class io.prestosql.execution.resourcegroups.LegacyResourceGroupConfigurationManager
 
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.WorkerModule
 
configure(Binder) - Method in class io.prestosql.testing.TestingWarningCollectorModule
 
ConnectorAwareNodeManager - Class in io.prestosql.connector
 
ConnectorAwareNodeManager(InternalNodeManager, String, ConnectorId) - Constructor for class io.prestosql.connector.ConnectorAwareNodeManager
 
ConnectorAwareSplitSource - Class in io.prestosql.split
 
ConnectorAwareSplitSource(ConnectorId, ConnectorTransactionHandle, ConnectorSplitSource) - Constructor for class io.prestosql.split.ConnectorAwareSplitSource
 
ConnectorContextInstance - Class in io.prestosql.connector
 
ConnectorContextInstance(NodeManager, TypeManager, PageSorter, PageIndexerFactory) - Constructor for class io.prestosql.connector.ConnectorContextInstance
 
ConnectorId - Class in io.prestosql.connector
 
ConnectorId(String) - Constructor for class io.prestosql.connector.ConnectorId
 
ConnectorManager - Class in io.prestosql.connector
 
ConnectorManager(MetadataManager, CatalogManager, AccessControlManager, SplitManager, PageSourceManager, IndexManager, NodePartitioningManager, PageSinkManager, HandleResolver, InternalNodeManager, NodeInfo, TypeManager, PageSorter, PageIndexerFactory, TransactionManager) - Constructor for class io.prestosql.connector.ConnectorManager
 
constant(T) - Static method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
constant(Object, Type) - Static method in class io.prestosql.sql.relational.Expressions
 
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(Class<?>, Class<?>...) - Static method in class io.prestosql.util.Reflection
Returns a MethodHandle corresponding to the specified constructor.
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.
contains(Block, int) - Method in class io.prestosql.operator.aggregation.TypedSet
 
contains(int, Page, int[]) - Method in class io.prestosql.operator.BigintGroupByHash
 
contains(int, Page) - Method in class io.prestosql.operator.ChannelSet
 
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(Type, MethodHandle, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayContains
 
contains(Type, MethodHandle, Block, Slice) - Static method in class io.prestosql.operator.scalar.ArrayContains
 
contains(Type, MethodHandle, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayContains
 
contains(Type, MethodHandle, Block, boolean) - Static method in class io.prestosql.operator.scalar.ArrayContains
 
contains(Type, MethodHandle, Block, double) - Static method in class io.prestosql.operator.scalar.ArrayContains
 
contains(int) - Method in class io.prestosql.util.JsonUtil.HashTable
 
containsAnnotation(Annotation[], Predicate<Annotation>) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
containsImplementationDependencyAnnotation(Annotation[]) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
containsLegacyNullable(Annotation[]) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
containsLongVariable(String) - Method in class io.prestosql.metadata.BoundVariables.Builder
 
containsLongVariable(String) - Method in class io.prestosql.metadata.BoundVariables
 
containsNamedQuery(String) - Method in class io.prestosql.sql.analyzer.Scope.Builder
 
containsNull() - Method in class io.prestosql.operator.ChannelSet
 
containsTypeVariable(String) - Method in class io.prestosql.metadata.BoundVariables.Builder
 
containsTypeVariable(String) - Method in class io.prestosql.metadata.BoundVariables
 
Context() - Constructor for class io.prestosql.sql.planner.optimizations.BeginTableWrite.Context
 
convertFromSchemaTableName(String) - Static method in class io.prestosql.metadata.QualifiedObjectName
 
COORDINATOR_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
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
 
copyOf(Map<Symbol, Expression>) - Static method in class io.prestosql.sql.planner.plan.Assignments
 
copyOf(Map<Symbol, Type>) - Static method in class io.prestosql.sql.planner.TypeProvider
 
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
 
correlation() - Static method in class io.prestosql.sql.planner.plan.Patterns.Apply
 
correlation() - Static method in class io.prestosql.sql.planner.plan.Patterns.LateralJoin
 
CorrelationState - Interface in io.prestosql.operator.aggregation.state
 
cos(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
cosh(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
cosineSimilarity(Block, Block) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
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(FeaturesConfig) - Constructor for class io.prestosql.cost.CostComparator
 
CostComparator(double, double, double) - 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(String, Map<String, String>, ConnectorContext) - Method in class io.prestosql.connector.system.GlobalSystemConnectorFactory
 
create(PlanNode, StatsProvider, CostProvider) - Static method in class io.prestosql.cost.StatsAndCosts
 
create(List<String>) - Static method in class io.prestosql.execution.scheduler.NetworkLocation
 
create(Session, QueryContext, TaskStateMachine, OutputBuffer, PlanFragment, List<TaskSource>, OptionalInt) - Method in class io.prestosql.execution.SqlTaskExecutionFactory
 
create() - Method in interface io.prestosql.execution.warnings.WarningCollectorFactory
 
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(WorkProcessor.Process<T>) - Static method in interface io.prestosql.operator.WorkProcessor
Creates WorkProcessor from Process.
create(Map<String, String>) - Method in class io.prestosql.security.AllowAllSystemAccessControl.Factory
 
create(Map<String, String>) - Method in class io.prestosql.security.FileBasedSystemAccessControl.Factory
 
create(Map<String, String>) - Method in class io.prestosql.security.ReadOnlySystemAccessControl.Factory
 
create(List<Type>, SpillContext, LocalMemoryContext) - Method in class io.prestosql.spiller.FileSingleStreamSpillerFactory
 
create(List<Type>, PartitionFunction, SpillContext, AggregatedMemoryContext) - Method in class io.prestosql.spiller.GenericPartitioningSpillerFactory
 
create(List<Type>, SpillContext, AggregatedMemoryContext) - Method in class io.prestosql.spiller.GenericSpillerFactory
 
create(List<Type>, PartitionFunction, SpillContext, AggregatedMemoryContext) - Method in interface io.prestosql.spiller.PartitioningSpillerFactory
 
create(List<Type>, SpillContext, LocalMemoryContext) - Method in interface io.prestosql.spiller.SingleStreamSpillerFactory
 
create(List<Type>, SpillContext, AggregatedMemoryContext) - Method in interface io.prestosql.spiller.SpillerFactory
 
create(Analysis, Session, Metadata, SqlParser, AccessControl, TypeProvider, WarningCollector) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
create() - Static method in class io.prestosql.sql.analyzer.Scope
 
create(ConnectorSession, LongArrayList, List<Page>) - Method in interface io.prestosql.sql.gen.JoinFilterFunctionCompiler.JoinFilterFunctionFactory
 
create(PartitioningHandle, List<Symbol>) - Static method in class io.prestosql.sql.planner.Partitioning
 
create() - Static method in class io.prestosql.testing.TestingTransactionHandle
 
create() - Method in class io.prestosql.testing.TestingWarningCollectorFactory
 
create(TransactionManagerConfig, ScheduledExecutorService, CatalogManager, ExecutorService) - Static method in class io.prestosql.transaction.InMemoryTransactionManager
 
create() - Static method in class io.prestosql.transaction.TransactionId
 
create() - Static method in class io.prestosql.util.AutoCloseableCloser
 
createAccumulator() - Method in interface io.prestosql.operator.aggregation.AccumulatorFactory
 
createAccumulator() - Method in class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
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, int) - Method in class io.prestosql.type.CodePointsType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.type.CodePointsType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.type.FunctionType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.type.FunctionType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.type.JoniRegexpType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.type.JoniRegexpType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.type.JsonPathType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.type.JsonPathType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.type.LikePatternType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.type.LikePatternType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.type.Re2JRegexpType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.type.Re2JRegexpType
 
createBlockBuilderAppender(Type) - Static method in interface io.prestosql.util.JsonUtil.BlockBuilderAppender
 
createBogusTestingCatalog(String) - Static method in class io.prestosql.testing.TestingSession
 
createBucketFunction(List<Type>, boolean, int) - Method in enum io.prestosql.sql.planner.SystemPartitioningHandle.SystemPartitionFunction
 
createCatalog(String, String) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
createCatalog(String, String, Map<String, String>) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
createCatalog(String, ConnectorFactory, Map<String, String>) - Method in class io.prestosql.testing.LocalQueryRunner
 
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
 
createCatalogName(Session, Node) - Static method in class io.prestosql.metadata.MetadataUtil
 
createCatalogSchemaName(Session, Node, Optional<QualifiedName>) - Static method in class io.prestosql.metadata.MetadataUtil
 
createConnection(String, String, Map<String, String>) - Method in class io.prestosql.connector.ConnectorManager
 
createConstantAnalyzer(Metadata, Session, List<Expression>, WarningCollector) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
createConstantAnalyzer(Metadata, Session, List<Expression>, WarningCollector, boolean) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
createDateTimeFormatter(Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
createDependency(Annotation, Set<String>) - Static method in class io.prestosql.operator.annotations.ImplementationDependency.Factory
 
createDriver(DriverContext, List<Operator>) - Static method in class io.prestosql.operator.Driver
 
createDriver(DriverContext, Operator, Operator...) - Static method in class io.prestosql.operator.Driver
 
createDriver(DriverContext) - Method in class io.prestosql.operator.DriverFactory
 
createDrivers(String, OutputFactory, TaskContext) - Method in class io.prestosql.testing.LocalQueryRunner
 
createDrivers(Session, String, OutputFactory, TaskContext) - Method in class io.prestosql.testing.LocalQueryRunner
 
createEmptyPagesResponse(String, long, long, boolean) - Static method in class io.prestosql.operator.HttpPageBufferClient.PagesResponse
 
createEmptySplit() - Static method in class io.prestosql.testing.TestingSplit
 
createEqualityInference(Expression...) - Static method in class io.prestosql.sql.planner.EqualityInference
 
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
 
createFunctionByAnnotations(Class<?>) - Static method in class io.prestosql.metadata.SqlAggregationFunction
 
createFunctionInvoker(Signature, Optional<InvocationConvention>) - Method in class io.prestosql.metadata.FunctionInvokerProvider
 
createFunctionsByAnnotations(Class<?>) - Static method in class io.prestosql.metadata.SqlAggregationFunction
 
createGroupByHash(Session, List<? extends Type>, int[], Optional<Integer>, int, JoinCompiler) - Static method in interface io.prestosql.operator.GroupByHash
 
createGroupByHash(List<? extends Type>, int[], Optional<Integer>, int, boolean, JoinCompiler, 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.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.DigestAndPercentileArrayStateFactory
 
createGroupedState() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory
 
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.QuantileDigestStateFactory
 
createGroupedState() - Method in class io.prestosql.type.setdigest.SetDigestStateFactory
 
CreateHandle(OutputTableHandle, SchemaTableName) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.CreateHandle
 
createHashCollisionsInfo(long, double, double) - Static method in class io.prestosql.operator.HashCollisionsInfo
 
createIndexSnapshot(UnloadedIndexKeyRecordSet) - Method in class io.prestosql.operator.index.IndexSnapshotBuilder
 
createInformationSchemaConnectorId(ConnectorId) - Static method in class io.prestosql.connector.ConnectorId
 
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, 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
 
createLookupSourceSupplier(Session, LongArrayList, List<List<Block>>, OptionalInt, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, Optional<Integer>, List<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>) - Method in class io.prestosql.sql.gen.JoinCompiler.LookupSourceSupplierFactory
 
createMap(MapType, MethodHandle, MethodHandle, 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
 
createMemoryInfoLocation(Node) - Method in interface io.prestosql.execution.LocationFactory
 
createMemoryInfoLocation(Node) - Method in class io.prestosql.server.remotetask.HttpLocationFactory
 
CreateName(String, ConnectorTableMetadata, Optional<NewTableLayout>) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.CreateName
 
createNewListener() - Method in class io.prestosql.execution.FutureStateChange
 
createNewStatsCalculator(Metadata) - 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

Index rolls at the start of every day or when it reaches 99,999, and the coordId is a randomly generated when this instance is created.

createNodeSelector(ConnectorId) - Method in class io.prestosql.execution.scheduler.NodeScheduler
 
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.AssignUniqueIdOperator.AssignUniqueIdOperatorFactory
 
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.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.FilterAndProjectOperator.FilterAndProjectOperatorFactory
 
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.HashSemiJoinOperator.HashSemiJoinOperatorFactory
 
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.MetadataDeleteOperator.MetadataDeleteOperatorFactory
 
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.StreamingAggregationOperator.StreamingAggregationOperatorFactory
 
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.TopNOperator.TopNOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.TopNRowNumberOperator.TopNRowNumberOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.operator.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.testing.NullOutputOperator.NullOutputOperatorFactory
 
createOperator(DriverContext) - Method in class io.prestosql.testing.PageConsumerOperator.PageConsumerOperatorFactory
 
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<Integer>, OptionalInt) - Method in class io.prestosql.operator.PagesIndex
 
createPagesHashStrategy(List<Integer>, OptionalInt, Optional<List<Integer>>) - Method in class io.prestosql.operator.PagesIndex
 
createPagesHashStrategy(List<? extends List<Block>>, OptionalInt) - Method in class io.prestosql.sql.gen.JoinCompiler.PagesHashStrategyFactory
 
createPageSink(Session, OutputTableHandle) - Method in class io.prestosql.split.PageSinkManager
 
createPageSink(Session, InsertTableHandle) - Method in class io.prestosql.split.PageSinkManager
 
createPageSink(Session, OutputTableHandle) - Method in interface io.prestosql.split.PageSinkProvider
 
createPageSink(Session, InsertTableHandle) - Method in interface io.prestosql.split.PageSinkProvider
 
createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorOutputTableHandle) - Method in class io.prestosql.testing.TestingPageSinkProvider
 
createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorInsertTableHandle) - Method in class io.prestosql.testing.TestingPageSinkProvider
 
createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, List<ColumnHandle>) - Method in class io.prestosql.connector.informationSchema.InformationSchemaPageSourceProvider
 
createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, List<ColumnHandle>) - Method in class io.prestosql.connector.system.SystemPageSourceProvider
 
createPageSource(Session, Split, List<ColumnHandle>) - Method in class io.prestosql.split.PageSourceManager
 
createPageSource(Session, Split, List<ColumnHandle>) - Method in interface io.prestosql.split.PageSourceProvider
 
createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, List<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
 
createPagesSpatialIndex(Session, int, Optional<Integer>, Optional<Integer>, SpatialIndexBuilderOperator.SpatialPredicate, Optional<JoinFilterFunctionCompiler.JoinFilterFunctionFactory>, List<Integer>, Map<Integer, Rectangle>) - Method in class io.prestosql.operator.PagesIndex
 
createPagesSpatialIndex() - Method in class io.prestosql.operator.PagesSpatialIndexFactory
createParsingOptions(Session) - Static method in class io.prestosql.sql.ParsingUtil
 
createPartialAggregations(SymbolAllocator, FunctionRegistry) - 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) - Static method in class io.prestosql.operator.PartitionedLookupSource
 
createPartitionedSplitCountTracker(Node, TaskId) - Method in class io.prestosql.execution.NodeTaskMap
 
createPlan(Session, String, WarningCollector) - Method in class io.prestosql.testing.LocalQueryRunner
 
createPlan(Session, String, LogicalPlanner.Stage, WarningCollector) - Method in class io.prestosql.testing.LocalQueryRunner
 
createPlan(Session, String, LogicalPlanner.Stage, boolean, 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
 
createPlan(Session, String, WarningCollector) - Method in interface io.prestosql.testing.QueryRunner
 
createPreemptQueryException(String) - Static method in class io.prestosql.connector.system.KillQueryProcedure
 
createPrincipal(Session, GrantorSpecification) - 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(QueryId, SessionContext, String) - Method in interface io.prestosql.execution.QueryManager
Creates a new query.
createQuery(QueryId, SessionContext, String) - Method in class io.prestosql.execution.SqlQueryManager
 
createQuery(String, String, HttpServletRequest, UriInfo) - Method in class io.prestosql.server.protocol.StatementResource
 
createQueryExecution(String, Session, QueryPreparer.PreparedQuery, ResourceGroupId, WarningCollector) - Method in class io.prestosql.execution.DataDefinitionExecution.DataDefinitionExecutionFactory
 
createQueryExecution(String, Session, QueryPreparer.PreparedQuery, ResourceGroupId, WarningCollector) - Method in interface io.prestosql.execution.QueryExecution.QueryExecutionFactory
 
createQueryExecution(String, Session, QueryPreparer.PreparedQuery, ResourceGroupId, WarningCollector) - Method in class io.prestosql.execution.SqlQueryExecution.SqlQueryExecutionFactory
 
createQueryId() - Method in interface io.prestosql.execution.QueryManager
 
createQueryId() - Method in class io.prestosql.execution.SqlQueryManager
 
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
 
createRemoteSplit() - Static method in class io.prestosql.testing.TestingSplit
 
createRemoteTask(Session, TaskId, Node, PlanFragment, Multimap<PlanNodeId, Split>, OptionalInt, OutputBuffers, NodeTaskMap.PartitionedSplitCountTracker, boolean) - Method in class io.prestosql.execution.MemoryTrackingRemoteTaskFactory
 
createRemoteTask(Session, TaskId, Node, PlanFragment, Multimap<PlanNodeId, Split>, OptionalInt, OutputBuffers, NodeTaskMap.PartitionedSplitCountTracker, boolean) - Method in interface io.prestosql.execution.RemoteTaskFactory
 
createRemoteTask(Session, TaskId, Node, 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>) - Method in interface io.prestosql.metadata.Metadata
Creates a schema.
createSchema(Session, CatalogSchemaName, Map<String, Object>) - 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
 
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.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.DigestAndPercentileArrayStateFactory
 
createSingleState() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory
 
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.QuantileDigestStateFactory
 
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, LocationFactory, StageExecutionPlan, NodePartitioningManager, NodeScheduler, RemoteTaskFactory, Session, boolean, int, ExecutorService, ScheduledExecutorService, FailureDetector, OutputBuffers, NodeTaskMap, ExecutionPolicy, SplitSchedulerStats) - Static method in class io.prestosql.execution.scheduler.SqlQueryScheduler
 
createSqlStageExecution(StageId, URI, PlanFragment, RemoteTaskFactory, Session, boolean, NodeTaskMap, ExecutorService, FailureDetector, SplitSchedulerStats) - Static method in class io.prestosql.execution.SqlStageExecution
 
createSqlTask(TaskId, URI, String, QueryContext, SqlTaskExecutionFactory, ExecutorService, Function<SqlTask, ?>, DataSize, CounterStat) - Static method in class io.prestosql.execution.SqlTask
 
createStageLocation(StageId) - Method in interface io.prestosql.execution.LocationFactory
 
createStageLocation(StageId) - Method in class io.prestosql.server.remotetask.HttpLocationFactory
 
createState(Type) - Static method in class io.prestosql.operator.scalar.ArrayConcatFunction
 
createState() - Static method in class io.prestosql.operator.scalar.ArrayJoin
 
createState(MapType) - Static method in class io.prestosql.operator.scalar.MapFilterFunction
 
createState(MapType) - Static method in class io.prestosql.operator.scalar.MapTransformKeyFunction
 
createState(MapType) - Static method in class io.prestosql.operator.scalar.MapTransformValueFunction
 
createState(MapType) - Static method in class io.prestosql.operator.scalar.MapZipWithFunction
 
createState(ArrayType) - Static method in class io.prestosql.operator.scalar.ZipWithFunction
 
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, WarningCollector) - Method in class io.prestosql.sql.planner.PlanFragmenter
 
createSystemTablesConnectorId(ConnectorId) - Static method in class io.prestosql.connector.ConnectorId
 
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
 
createTaskContext(QueryContext, TaskStateMachine, GcMonitor, Executor, ScheduledExecutorService, Session, MemoryTrackingContext, boolean, boolean, OptionalInt) - Static method in class io.prestosql.operator.TaskContext
 
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
 
createTaskContext(QueryContext, Executor, Session) - Static method in class io.prestosql.testing.TestingTaskContext
 
createTaskLocation(Node, TaskId) - Method in interface io.prestosql.execution.LocationFactory
 
createTaskLocation(Node, TaskId) - Method in class io.prestosql.server.remotetask.HttpLocationFactory
 
createTestMetadataManager() - Static method in class io.prestosql.metadata.MetadataManager
 
createTestMetadataManager(FeaturesConfig) - 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(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, 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
 
createTypeVariableConstraints(Iterable<TypeParameter>, List<ImplementationDependency>) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
createView(Session, QualifiedObjectName, String, boolean) - Method in interface io.prestosql.metadata.Metadata
Creates the specified view with the specified view definition.
createView(Session, QualifiedObjectName, String, boolean) - Method in class io.prestosql.metadata.MetadataManager
 
createView(ConnectorSession, SchemaTableName, String, boolean) - Method in class io.prestosql.testing.TestingMetadata
 
CreateViewTask - Class in io.prestosql.execution
 
CreateViewTask(JsonCodec<ViewDefinition>, SqlParser, FeaturesConfig) - 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(List<Integer>) - Method in class io.prestosql.operator.window.AbstractWindowFunctionSupplier
 
createWindowFunction(List<Integer>) - Method in interface io.prestosql.operator.window.WindowFunctionSupplier
 
createWindowFunction() - Method in class io.prestosql.operator.WindowFunctionDefinition
 
createWithExpressions(PartitioningHandle, List<Expression>) - Static method in class io.prestosql.sql.planner.Partitioning
 
createWithoutSubqueries(FunctionRegistry, TypeManager, Session, List<Expression>, SemanticErrorCode, String, WarningCollector, boolean) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
createWithoutSubqueries(FunctionRegistry, TypeManager, Session, TypeProvider, List<Expression>, Function<? super Node, ? extends RuntimeException>, WarningCollector, boolean) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
CumulativeDistributionFunction - Class in io.prestosql.operator.window
 
CumulativeDistributionFunction() - Constructor for class io.prestosql.operator.window.CumulativeDistributionFunction
 
current() - Static method in class io.prestosql.server.JavaVersion
 
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
currentTime(ConnectorSession) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
currentTimestamp(ConnectorSession) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
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(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.TaskSystemTable
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in class io.prestosql.connector.system.TransactionsSystemTable
 
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
 
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
 

D

DataDefinitionExecution<T extends Statement> - Class in io.prestosql.execution
 
DataDefinitionExecution.DataDefinitionExecutionFactory - Class in io.prestosql.execution
 
DataDefinitionExecutionFactory(LocationFactory, TransactionManager, MetadataManager, AccessControl, ExecutorService, Map<Class<? extends Statement>, DataDefinitionTask<?>>) - Constructor for class io.prestosql.execution.DataDefinitionExecution.DataDefinitionExecutionFactory
 
DataDefinitionTask<T extends Statement> - Interface in io.prestosql.execution
 
DataSizeFunctions - Class in io.prestosql.operator.scalar
 
DateDistinctFromOperator() - Constructor for class io.prestosql.type.DateOperators.DateDistinctFromOperator
 
dateFormat(ConnectorSession, long, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dateFormatWithTimeZone(ConnectorSession, long, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dateMinusIntervalDayToSecond(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
dateMinusIntervalYearToMonth(ConnectorSession, long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
DateOperators - Class in io.prestosql.type
 
DateOperators.DateDistinctFromOperator - 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
 
DateTimeFunctions - Class in io.prestosql.operator.scalar
 
DateTimeOperators - Class in io.prestosql.type
 
DateTimeTestingUtils - Class in io.prestosql.testing
 
DateTimeUtils - Class in io.prestosql.util
 
DateTimeZoneIndex - Class in io.prestosql.util
 
dayFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayFromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayOfWeekFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayOfWeekFromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayOfWeekFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayOfYearFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayOfYearFromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
dayOfYearFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
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_BETWEEN_OPERATOR - Static variable in class io.prestosql.type.DecimalInequalityOperators
 
DECIMAL_DISTINCT_FROM_OPERATOR - Static variable in class io.prestosql.type.DecimalInequalityOperators
 
DECIMAL_DIVIDE_OPERATOR - Static variable in class io.prestosql.type.DecimalOperators
 
DECIMAL_EQUAL_OPERATOR - Static variable in class io.prestosql.type.DecimalInequalityOperators
 
DECIMAL_GREATER_THAN_OPERATOR - Static variable in class io.prestosql.type.DecimalInequalityOperators
 
DECIMAL_GREATER_THAN_OR_EQUAL_OPERATOR - Static variable in class io.prestosql.type.DecimalInequalityOperators
 
DECIMAL_LESS_THAN_OPERATOR - Static variable in class io.prestosql.type.DecimalInequalityOperators
 
DECIMAL_LESS_THAN_OR_EQUAL_OPERATOR - Static variable in class io.prestosql.type.DecimalInequalityOperators
 
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_NOT_EQUAL_OPERATOR - Static variable in class io.prestosql.type.DecimalInequalityOperators
 
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
 
DecimalInequalityOperators - Class in io.prestosql.type
 
DecimalOperators - Class in io.prestosql.type
 
DecimalOperators.HashCode - Class in io.prestosql.type
 
DecimalOperators.Indeterminate - Class in io.prestosql.type
 
DecimalOperators.Negation - Class in io.prestosql.type
 
DecimalOperators.XxHash64Operator - 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
 
decodeCatalogPropertyValue(ConnectorId, String, String, String, Class<T>) - Method in class io.prestosql.metadata.SessionPropertyManager
 
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
 
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
 
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
 
DefaultApproximateCountDistinctAggregation - Class in io.prestosql.operator.aggregation
 
DefaultFactory(OrderingCompiler, JoinCompiler, FeaturesConfig, Metadata) - Constructor for class io.prestosql.operator.PagesIndex.DefaultFactory
 
defaultParallelism(Session) - Static method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
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>, Map<Long, MethodHandle>, ClassLoader) - Static method in class io.prestosql.util.CompilerUtils
 
defineClass(ClassDefinition, Class<T>, DynamicClassLoader) - Static method in class io.prestosql.util.CompilerUtils
 
degrees(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
DelegatingSystemTablesProvider - Class in io.prestosql.connector.system
 
DelegatingSystemTablesProvider(SystemTablesProvider...) - Constructor for class io.prestosql.connector.system.DelegatingSystemTablesProvider
 
DelegatingSystemTablesProvider(List<SystemTablesProvider>) - Constructor for class io.prestosql.connector.system.DelegatingSystemTablesProvider
 
delete() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
DeleteHandle(TableHandle, SchemaTableName) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.DeleteHandle
 
DeleteNode - Class in io.prestosql.sql.planner.plan
 
DeleteNode(PlanNodeId, PlanNode, TableWriterNode.DeleteHandle, 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
 
deleteRows(Block) - Method in class io.prestosql.split.EmptySplitPageSource
 
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
 
dependsOn(WindowNode, WindowNode) - Static method in class io.prestosql.sql.planner.optimizations.WindowNodeUtil
 
DEREFERENCE - Static variable in class io.prestosql.sql.relational.Signatures
 
DereferenceCodeGenerator - Class in io.prestosql.sql.gen
 
DereferenceCodeGenerator() - Constructor for class io.prestosql.sql.gen.DereferenceCodeGenerator
 
dereferenceSignature(Type, RowType) - Static method in class io.prestosql.sql.relational.Signatures
 
deriveProperties(PlanNode, List<ActualProperties>, Metadata, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.PropertyDerivations
 
deriveProperties(PlanNode, StreamPropertyDerivations.StreamProperties, Metadata, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations
 
deriveProperties(PlanNode, List<StreamPropertyDerivations.StreamProperties>, Metadata, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations
 
derivePropertiesRecursively(PlanNode, Metadata, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.PropertyDerivations
 
derivePropertiesRecursively(PlanNode, Metadata, Session, TypeProvider, TypeAnalyzer) - Static method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations
 
description(String) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder
 
deserialize(JsonParser, DeserializationContext) - Method in class io.prestosql.block.BlockJsonSerde.Deserializer
 
deserialize(SerializedPage) - Method in class io.prestosql.execution.buffer.PagesSerde
 
deserialize(Block, int, ArrayAggregationState) - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateSerializer
 
deserialize(Block, Type, int) - Method in class io.prestosql.operator.aggregation.histogram.GroupedHistogramState
 
deserialize(Block, Type, int) - Method in interface io.prestosql.operator.aggregation.histogram.HistogramState
 
deserialize(Block, int, HistogramState) - Method in class io.prestosql.operator.aggregation.histogram.HistogramStateSerializer
 
deserialize(Block, Type, int) - Method in class io.prestosql.operator.aggregation.histogram.LegacyHistogramGroupState
Deprecated.
 
deserialize(Block, Type, int) - Method in class io.prestosql.operator.aggregation.histogram.SingleHistogramState
 
deserialize(Block, int, T) - Method in class io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueStateSerializer
 
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, DigestAndPercentileArrayState) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateSerializer
 
deserialize(Block, int, DigestAndPercentileState) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateSerializer
 
deserialize(Block, int, DoubleHistogramAggregation.State) - Method in class io.prestosql.operator.aggregation.state.DoubleHistogramStateSerializer
 
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, QuantileDigestState) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateSerializer
 
deserialize(Block, int, TriStateBooleanState) - Method in class io.prestosql.operator.aggregation.state.TriStateBooleanStateSerializer
 
deserialize(Block, Type, Type, BlockComparator) - Static method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
deserialize(JsonParser, DeserializationContext) - Method in class io.prestosql.server.SliceDeserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class io.prestosql.sql.Serialization.ExpressionDeserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class io.prestosql.sql.Serialization.FunctionCallDeserializer
 
deserialize(Block, int, SetDigestState) - Method in class io.prestosql.type.setdigest.SetDigestStateSerializer
 
deserializeKey(String, DeserializationContext) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.ColumnStatisticMetadataKeyDeserializer
 
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.PartitionedLookupSourceFactory
 
destroy() - Method in class io.prestosql.server.security.AuthenticationFilter
 
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
 
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() - Constructor for class io.prestosql.sql.planner.iterative.rule.DesugarCurrentPath
 
DesugarCurrentUser - Class in io.prestosql.sql.planner.iterative.rule
 
DesugarCurrentUser() - 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
 
DesugarTryExpression - Class in io.prestosql.sql.planner.iterative.rule
 
DesugarTryExpression() - 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(FunctionRegistry) - 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
 
dfaRetries - Variable in class io.prestosql.type.Re2JRegexp
 
dfaStatesLimit - Variable in class io.prestosql.type.Re2JRegexp
 
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>) - Constructor for class io.prestosql.operator.project.DictionaryAwarePageProjection
 
diffDate(ConnectorSession, Slice, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
diffTime(ConnectorSession, Slice, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
diffTimestamp(ConnectorSession, Slice, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
diffTimestampWithTimeZone(Slice, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
diffTimeWithTimeZone(Slice, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
DigestAndPercentileArrayState - Interface in io.prestosql.operator.aggregation.state
 
DigestAndPercentileArrayStateFactory - Class in io.prestosql.operator.aggregation.state
 
DigestAndPercentileArrayStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory
 
DigestAndPercentileArrayStateFactory.GroupedDigestAndPercentileArrayState - Class in io.prestosql.operator.aggregation.state
 
DigestAndPercentileArrayStateFactory.SingleDigestAndPercentileArrayState - Class in io.prestosql.operator.aggregation.state
 
DigestAndPercentileArrayStateSerializer - Class in io.prestosql.operator.aggregation.state
 
DigestAndPercentileArrayStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateSerializer
 
DigestAndPercentileState - Interface in io.prestosql.operator.aggregation.state
 
DigestAndPercentileStateFactory - Class in io.prestosql.operator.aggregation.state
 
DigestAndPercentileStateFactory() - Constructor for class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory
 
DigestAndPercentileStateFactory.GroupedDigestAndPercentileState - Class in io.prestosql.operator.aggregation.state
 
DigestAndPercentileStateFactory.SingleDigestAndPercentileState - Class in io.prestosql.operator.aggregation.state
 
DigestAndPercentileStateSerializer - Class in io.prestosql.operator.aggregation.state
 
DigestAndPercentileStateSerializer() - Constructor for class io.prestosql.operator.aggregation.state.DigestAndPercentileStateSerializer
 
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
 
distinct(Type, Block) - Method in class io.prestosql.operator.scalar.ArrayDistinctFunction
 
distinctBlockPositionLongLong(Block, int, Block, int) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
distinctBlockPositionShortShort(Block, int, Block, int) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
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) - 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) - Constructor for class io.prestosql.operator.DistinctLimitOperator.DistinctLimitOperatorFactory
 
distinctLongLong(Slice, boolean, Slice, boolean) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
DistinctOutputQueryUtil - Class in io.prestosql.sql.planner.optimizations
 
distinctShortShort(long, boolean, long, boolean) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
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) - Constructor for class io.prestosql.sql.planner.DistributedExecutionPlanner
 
divide(long, long) - Static method in class io.prestosql.type.BigintOperators
 
divide(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
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(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(FilterNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.SimpleFilterProjectSemiJoinStatsRule
 
doCalculate(T, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.SimpleStatsRule
 
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(UnionNode, StatsProvider, Lookup, Session, TypeProvider) - Method in class io.prestosql.cost.UnionStatsRule
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class io.prestosql.server.security.AuthenticationFilter
 
DomainTranslator - Class in io.prestosql.sql.planner
 
DomainTranslator(LiteralEncoder) - 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
 
doubleArrayMinMax(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMinMaxUtils
 
DoubleBooleanState - Interface in io.prestosql.operator.aggregation.minmaxby
 
DoubleCorrelationAggregation - Class in io.prestosql.operator.aggregation
 
DoubleCovarianceAggregation - Class in io.prestosql.operator.aggregation
 
DoubleDistinctFromOperator() - Constructor for class io.prestosql.type.DoubleOperators.DoubleDistinctFromOperator
 
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
 
DoubleOperators.DoubleDistinctFromOperator - 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
 
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.
drainCompletedLifespans() - Method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
 
drainCompletedLifespans() - Method in interface io.prestosql.execution.scheduler.SourceScheduler
 
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
 
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
 
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 class io.prestosql.operator.AssignUniqueIdOperator.AssignUniqueIdOperatorFactory
 
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.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.FilterAndProjectOperator.FilterAndProjectOperatorFactory
 
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.HashSemiJoinOperator.HashSemiJoinOperatorFactory
 
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.MetadataDeleteOperator.MetadataDeleteOperatorFactory
 
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.StreamingAggregationOperator.StreamingAggregationOperatorFactory
 
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.TopNOperator.TopNOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.TopNRowNumberOperator.TopNRowNumberOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.UnnestOperator.UnnestOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.ValuesOperator.ValuesOperatorFactory
 
duplicate() - Method in class io.prestosql.operator.WindowOperator.WindowOperatorFactory
 
duplicate() - Method in class io.prestosql.testing.NullOutputOperator.NullOutputOperatorFactory
 
duplicate() - Method in class io.prestosql.testing.PageConsumerOperator.PageConsumerOperatorFactory
 
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
 
DynamicLifespanScheduler - Class in io.prestosql.execution.scheduler.group
See LifespanScheduler about thread safety
DynamicLifespanScheduler(BucketNodeMap, List<Node>, 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) - 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) - Constructor for class io.prestosql.sql.planner.EffectivePredicateExtractor
 
ELEMENT_TO_ARRAY_CONCAT_FUNCTION - Static variable in class io.prestosql.operator.scalar.ElementToArrayConcatFunction
 
elementAt(MethodHandle, Type, Type, Block, boolean) - Static method in class io.prestosql.operator.scalar.MapElementAtFunction
 
elementAt(MethodHandle, Type, Type, Block, long) - Static method in class io.prestosql.operator.scalar.MapElementAtFunction
 
elementAt(MethodHandle, Type, Type, Block, double) - Static method in class io.prestosql.operator.scalar.MapElementAtFunction
 
elementAt(MethodHandle, Type, Type, Block, Slice) - Static method in class io.prestosql.operator.scalar.MapElementAtFunction
 
elementAt(MethodHandle, Type, 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
 
EliminateCrossJoins - Class in io.prestosql.sql.planner.iterative.rule
 
EliminateCrossJoins() - 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 - Class in io.prestosql.version
 
EmbedVersion(ServerConfig) - Constructor for class io.prestosql.version.EmbedVersion
 
embedVersion(Runnable) - Method in 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.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_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
 
EmptyMapConstructor - Class in io.prestosql.operator.scalar
 
EmptyMapConstructor(Type) - Constructor for class io.prestosql.operator.scalar.EmptyMapConstructor
 
emptyResults(String, long, boolean) - Static method in class io.prestosql.execution.buffer.BufferResult
 
EmptySplit - Class in io.prestosql.split
 
EmptySplit(ConnectorId) - Constructor for class io.prestosql.split.EmptySplit
 
EmptySplitHandleResolver - Class in io.prestosql.split
 
EmptySplitHandleResolver() - Constructor for class io.prestosql.split.EmptySplitHandleResolver
 
EmptySplitPageSource - Class in io.prestosql.split
 
EmptySplitPageSource() - Constructor for class io.prestosql.split.EmptySplitPageSource
 
ENABLE_FORCED_EXCHANGE_BELOW_GROUP_ID - Static variable in class io.prestosql.SystemSessionProperties
 
ENABLE_INTERMEDIATE_AGGREGATIONS - Static variable in class io.prestosql.SystemSessionProperties
 
ENABLE_STATS_CALCULATOR - Static variable in class io.prestosql.SystemSessionProperties
 
encodeSyntheticAddress(int, int) - Static method in class io.prestosql.operator.SyntheticAddress
 
endAnalysis() - Method in class io.prestosql.execution.QueryStateMachine
 
endDistributedPlanning() - 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(List<SerializedPage>) - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
enqueue(int, List<SerializedPage>) - Method in class io.prestosql.execution.buffer.ArbitraryOutputBuffer
 
enqueue(List<SerializedPage>) - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
enqueue(int, List<SerializedPage>) - Method in class io.prestosql.execution.buffer.BroadcastOutputBuffer
 
enqueue(List<SerializedPage>) - Method in class io.prestosql.execution.buffer.LazyOutputBuffer
 
enqueue(int, 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(int, List<SerializedPage>) - Method in interface io.prestosql.execution.buffer.OutputBuffer
Adds a split-up page to a specific partition.
enqueue(List<SerializedPage>) - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
enqueue(int, List<SerializedPage>) - Method in class io.prestosql.execution.buffer.PartitionedOutputBuffer
 
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.arrayagg.LegacyArrayAggregationGroupState
Deprecated.
 
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 class io.prestosql.operator.aggregation.histogram.LegacyHistogramGroupState
Deprecated.
 
ensureCapacity(long) - Method in interface io.prestosql.operator.aggregation.histogram.TypedHistogram
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.GroupedMinMaxByNState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.multimapagg.LegacyGroupedMultimapAggregationState
Deprecated.
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.NumericHistogramStateFactory.GroupedState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.GroupedDigestAndPercentileArrayState
 
ensureCapacity(long) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.GroupedDigestAndPercentileState
 
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.QuantileDigestStateFactory.GroupedQuantileDigestState
 
ensureCapacity(long) - Method in class io.prestosql.type.setdigest.SetDigestStateFactory.GroupedSetDigestState
 
ENTRY_BUFFER_SIZE - Static variable in class io.prestosql.operator.aggregation.DoubleHistogramAggregation
 
entrySet() - Method in class io.prestosql.sql.planner.plan.Assignments
 
equal(long, long) - Static method in class io.prestosql.type.BigintOperators
 
equal(boolean, boolean) - Static method in class io.prestosql.type.BooleanOperators
 
equal(Slice, Slice) - Static method in class io.prestosql.type.CharOperators
 
equal(long, long) - Static method in class io.prestosql.type.ColorOperators
 
equal(long, long) - Static method in class io.prestosql.type.DateOperators
 
equal(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
equal(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
equal(long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
equal(long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
equal(Slice, Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
equal(long, long) - Static method in class io.prestosql.type.RealOperators
 
equal(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
equal(long, long) - Static method in class io.prestosql.type.TimeOperators
 
equal(long, long) - Static method in class io.prestosql.type.TimestampOperators
 
equal(long, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
equal(long, long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
equal(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
equal(boolean, boolean) - Static method in class io.prestosql.type.UnknownOperators
 
equal(Slice, Slice) - Static method in class io.prestosql.type.VarbinaryOperators
 
equal(Slice, Slice) - Static method in class io.prestosql.type.VarcharOperators
 
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.Builder - Class in io.prestosql.sql.planner
 
EqualityInference.EqualityPartition - Class in io.prestosql.sql.planner
 
EqualityPartition(Iterable<Expression>, Iterable<Expression>, Iterable<Expression>) - Constructor for class io.prestosql.sql.planner.EqualityInference.EqualityPartition
 
equals(Object) - Method in class io.prestosql.connector.ConnectorId
 
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.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.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.Output
 
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.BoundVariables
 
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.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.PrestoNode
 
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.Signature
 
equals(Object) - Method in class io.prestosql.metadata.SpecializedFunctionKey
 
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.ScalarImplementationDependency
 
equals(Object) - Method in class io.prestosql.operator.annotations.TypeImplementationDependency
 
equals(int, int, Block, int, int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
equals(Object) - Method in class io.prestosql.operator.HttpPageBufferClient
 
equals(Object) - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.SpecializedSignature
 
equals(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayEqualOperator
 
equals(Slice, Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
equals(MethodHandle, MethodHandle, MethodHandle, Type, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.MapEqualOperator
 
equals(int, int) - Method in interface io.prestosql.operator.scalar.MapGenericEquality.EqualityPredicate
 
equals(RowType, List<MethodHandle>, Block, Block) - Static method in class io.prestosql.operator.scalar.RowEqualOperator
 
equals(Object) - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ArgumentProperty
 
equals(Object) - Method in class io.prestosql.operator.window.FrameInfo
 
equals(Object) - Method in class io.prestosql.server.JavaVersion
 
equals(Object) - Method in class io.prestosql.sql.analyzer.Analysis.AccessControlInfo
 
equals(Object) - Method in class io.prestosql.sql.analyzer.FieldId
 
equals(Object) - Method in class io.prestosql.sql.analyzer.RelationId
 
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.Assignments
 
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.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.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.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
 
equalsDouble(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayEqualOperator
 
equalsLong(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayEqualOperator
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.type.FunctionType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.type.IpAddressType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.type.JsonType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.type.UnknownType
 
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.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
 
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() - Method in class io.prestosql.cost.TaskCountEstimator
 
evaluate(Supplier<T>, T) - Static method in class io.prestosql.operator.scalar.TryFunction
 
evaluate() - Method in class io.prestosql.sql.planner.ExpressionInterpreter
 
evaluate(SymbolResolver) - Method in class io.prestosql.sql.planner.ExpressionInterpreter
 
evaluate(Metadata, ConnectorSession, Expression) - Static method in class io.prestosql.sql.planner.LiteralInterpreter
 
evaluateConstantExpression(Expression, Type, Metadata, Session, List<Expression>) - Static method in class io.prestosql.sql.planner.ExpressionInterpreter
 
evaluateFinal(BlockBuilder) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
evaluateFinal(HyperLogLogState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
evaluateFinal(BooleanDistinctState, 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(BooleanDistinctState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
evaluateFinal(int, BlockBuilder) - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
evaluateFinal(QuantileDigestStateSerializer, QuantileDigestState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
evaluateIntermediate(BlockBuilder) - Method in interface io.prestosql.operator.aggregation.Accumulator
 
evaluateIntermediate(int, BlockBuilder) - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
evaluatePropertyValue(Expression, Type, Session, Metadata, List<Expression>) - Static method in class io.prestosql.metadata.SessionPropertyManager
 
EvaluateZeroLimit - Class in io.prestosql.sql.planner.iterative.rule
 
EvaluateZeroLimit() - Constructor for class io.prestosql.sql.planner.iterative.rule.EvaluateZeroLimit
 
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
 
EvaluateZeroTopN - Class in io.prestosql.sql.planner.iterative.rule
 
EvaluateZeroTopN() - Constructor for class io.prestosql.sql.planner.iterative.rule.EvaluateZeroTopN
 
EventListenerManager - Class in io.prestosql.eventlistener
 
EventListenerManager() - Constructor for class io.prestosql.eventlistener.EventListenerManager
 
EventListenerModule - Class in io.prestosql.eventlistener
 
EventListenerModule() - Constructor for class io.prestosql.eventlistener.EventListenerModule
 
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
 
ExceededSpillLimitException - Exception in io.prestosql
 
except(Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayExceptFunction
 
ExceptNode - Class in io.prestosql.sql.planner.plan
 
ExceptNode(PlanNodeId, List<PlanNode>, ListMultimap<Symbol, Symbol>, List<Symbol>) - 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(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(ExchangeClientConfig, HttpClient, ScheduledExecutorService) - Constructor for class io.prestosql.operator.ExchangeClientFactory
 
ExchangeClientFactory(DataSize, DataSize, int, Duration, boolean, int, 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(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(Commit, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.CommitTask
 
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(T, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in interface io.prestosql.execution.DataDefinitionTask
 
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(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(GrantRoles, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.GrantRolesTask
 
execute(Grant, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.GrantTask
 
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(ResetSession, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.ResetSessionTask
 
execute(RevokeRoles, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.RevokeRolesTask
 
execute(Revoke, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.RevokeTask
 
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(SetSession, TransactionManager, Metadata, AccessControl, QueryStateMachine, List<Expression>) - Method in class io.prestosql.execution.SetSessionTask
 
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(String) - Method in class io.prestosql.testing.LocalQueryRunner
 
execute(Session, String) - Method in class io.prestosql.testing.LocalQueryRunner
 
execute(String) - Method in interface io.prestosql.testing.QueryRunner
 
execute(Session, 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(Session, Consumer<Session>) - Method in class io.prestosql.transaction.TransactionBuilder
 
execute(Session, Function<Session, T>) - Method in class io.prestosql.transaction.TransactionBuilder
 
executeWithPlan(Session, String, WarningCollector) - Method in class io.prestosql.testing.LocalQueryRunner
 
executeWithPlan(Session, String, WarningCollector) - Method in interface io.prestosql.testing.QueryRunner
 
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(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(T, List<Expression>) - Method in interface io.prestosql.execution.DataDefinitionTask
 
explain(DropSchema, List<Expression>) - Method in class io.prestosql.execution.DropSchemaTask
 
explain(Prepare, List<Expression>) - Method in class io.prestosql.execution.PrepareTask
 
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, boolean) - Constructor for class io.prestosql.sql.planner.plan.ExplainAnalyzeNode
 
ExplainAnalyzeOperator - Class in io.prestosql.operator
 
ExplainAnalyzeOperator(OperatorContext, QueryPerformanceFetcher, FunctionRegistry, boolean) - Constructor for class io.prestosql.operator.ExplainAnalyzeOperator
 
ExplainAnalyzeOperator.ExplainAnalyzeOperatorFactory - Class in io.prestosql.operator
 
ExplainAnalyzeOperatorFactory(int, PlanNodeId, QueryPerformanceFetcher, FunctionRegistry, boolean) - Constructor for class io.prestosql.operator.ExplainAnalyzeOperator.ExplainAnalyzeOperatorFactory
 
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>, FieldId>, Set<NodeRef<Expression>>, Set<NodeRef<QuantifiedComparisonExpression>>, Map<NodeRef<Identifier>, LambdaArgumentDeclaration>, Set<NodeRef<FunctionCall>>) - Constructor for class io.prestosql.sql.analyzer.ExpressionAnalysis
 
ExpressionAnalyzer - Class in io.prestosql.sql.analyzer
 
ExpressionAnalyzer(FunctionRegistry, TypeManager, Function<Node, StatementAnalyzer>, Session, TypeProvider, List<Expression>, WarningCollector, boolean) - 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.sql.Serialization.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 - Class in io.prestosql.sql.planner
 
expressionInterpreter(Expression, Metadata, Session, Map<NodeRef<Expression>, Type>) - Static method in class io.prestosql.sql.planner.ExpressionInterpreter
 
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(FunctionRegistry, TypeManager, 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
 
ExpressionSerializer() - Constructor for class io.prestosql.sql.Serialization.ExpressionSerializer
 
ExpressionSymbolInliner - Class in io.prestosql.sql.planner
 
ExpressionTreeUtils - Class in io.prestosql.sql.analyzer
 
ExpressionUtils - Class in io.prestosql.sql
 
extract(Slice, JsonExtract.JsonExtractor<T>) - Static method in class io.prestosql.operator.scalar.JsonExtract
 
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(PlanNode) - Method in class io.prestosql.sql.planner.EffectivePredicateExtractor
 
extract() - Method in class io.prestosql.sql.planner.iterative.Memo
 
extract(Expression) - Static method in class io.prestosql.sql.planner.SubExpressionExtractor
 
extract(Slice, long) - Method in class io.prestosql.type.Re2JRegexp
 
extractAll(Expression) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractAll(Slice, long) - Method in class io.prestosql.type.Re2JRegexp
 
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(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
 
extractDisjuncts(Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
extractExpressions(Iterable<? extends Node>, Class<T>) - Static method in class io.prestosql.sql.analyzer.ExpressionTreeUtils
 
extractExpressions(PlanNode) - Static method in class io.prestosql.sql.planner.ExpressionExtractor
 
extractExpressions(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.ExpressionExtractor
 
extractExpressionsNonRecursive(PlanNode) - Static method in class io.prestosql.sql.planner.ExpressionExtractor
 
extractFunctions(Collection<Class<?>>) - Static method in class io.prestosql.metadata.FunctionExtractor
 
extractFunctions(Class<?>) - Static method in class io.prestosql.metadata.FunctionExtractor
 
extractInferenceCandidates(Expression) - Method in class io.prestosql.sql.planner.EqualityInference.Builder
 
extractInputs(PlanNode) - 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
 
extractNames(Expression, Set<NodeRef<Expression>>) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractOutput(PlanNode) - Method in class io.prestosql.sql.planner.OutputExtractor
 
extractOutputSymbols(PlanNode) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractOutputSymbols(PlanNode, Lookup) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractPredicates(LogicalBinaryExpression) - Static method in class io.prestosql.sql.ExpressionUtils
 
extractPredicates(LogicalBinaryExpression.Operator, Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
extractSortExpression(Set<Symbol>, Expression) - Static method in class io.prestosql.sql.planner.SortExpressionExtractor
 
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(...)
extractUnique(PlanNode) - Static method in class io.prestosql.sql.planner.SymbolsExtractor
 
extractUnique(PlanNode, Lookup) - 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
 
extractZoneOffsetMinutes(long) - Static method in class io.prestosql.util.DateTimeZoneIndex
 

F

Factory() - Constructor for class io.prestosql.security.AllowAllSystemAccessControl.Factory
 
Factory() - Constructor for class io.prestosql.security.FileBasedSystemAccessControl.Factory
 
Factory() - Constructor for class io.prestosql.security.ReadOnlySystemAccessControl.Factory
 
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(Throwable) - Method in class io.prestosql.execution.DataDefinitionExecution
 
fail(Throwable) - Method in class io.prestosql.execution.FailedQueryExecution
 
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
 
fail(Slice) - Static method in class io.prestosql.operator.scalar.FailureFunction
 
fail(long, 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
 
failAbandonedTasks() - Method in class io.prestosql.execution.SqlTaskManager
 
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
 
FailedQueryExecution - Class in io.prestosql.execution
 
FailedQueryExecution(Session, String, URI, Optional<ResourceGroupId>, Executor, Throwable) - Constructor for class io.prestosql.execution.FailedQueryExecution
 
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 - Exception in io.prestosql.execution
 
failure() - Method in class io.prestosql.server.remotetask.Backoff
 
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
 
FAST_INEQUALITY_JOINS - Static variable in class io.prestosql.SystemSessionProperties
 
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.JoinDistributionType - Enum in io.prestosql.sql.analyzer
 
FeaturesConfig.JoinReorderingStrategy - Enum in io.prestosql.sql.analyzer
 
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
 
field(int, Type) - Static method in class io.prestosql.sql.relational.Expressions
 
field(Class<?>, String) - Static method in class io.prestosql.util.Reflection
 
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(FunctionRegistry, RecordSet, List<Set<Integer>>) - Constructor for class io.prestosql.operator.index.FieldSetFilteringRecordSet
 
FileBasedSystemAccessControl - Class in io.prestosql.security
 
FileBasedSystemAccessControl.Factory - Class in io.prestosql.security
 
FileBasedSystemAccessControlRules - Class in io.prestosql.security
 
FileBasedSystemAccessControlRules(Optional<List<CatalogAccessControlRule>>, Optional<List<PrincipalUserMatchRule>>) - Constructor for class io.prestosql.security.FileBasedSystemAccessControlRules
 
FileSingleStreamSpiller - Class in io.prestosql.spiller
 
FileSingleStreamSpiller(PagesSerde, ListeningExecutorService, Path, SpillerStats, SpillContext, LocalMemoryContext) - Constructor for class io.prestosql.spiller.FileSingleStreamSpiller
 
FileSingleStreamSpillerFactory - Class in io.prestosql.spiller
 
FileSingleStreamSpillerFactory(BlockEncodingSerde, SpillerStats, FeaturesConfig) - Constructor for class io.prestosql.spiller.FileSingleStreamSpillerFactory
 
FileSingleStreamSpillerFactory(ListeningExecutorService, BlockEncodingSerde, SpillerStats, List<Path>, double) - Constructor for class io.prestosql.spiller.FileSingleStreamSpillerFactory
 
filter(ConnectorSession, Page) - Method in class io.prestosql.operator.index.TuplePageFilter
 
filter(int, Page, int, Page) - Method in interface io.prestosql.operator.InternalJoinFilterFunction
 
filter(int, int, Page) - Method in interface io.prestosql.operator.JoinFilterFunction
 
filter(ConnectorSession, Page) - Method in class io.prestosql.operator.project.DictionaryAwarePageFilter
 
filter(ConnectorSession, Page) - Method in interface io.prestosql.operator.project.PageFilter
 
filter(int, int, Page) - Method in class io.prestosql.operator.StandardJoinFilterFunction
 
filter(Collection<Symbol>) - Method in class io.prestosql.sql.planner.plan.Assignments
 
filter(Predicate<Symbol>) - Method in class io.prestosql.sql.planner.plan.Assignments
 
filter() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
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
 
FilterAndProjectOperator(OperatorContext, PageProcessor, MergingPageOutput) - Constructor for class io.prestosql.operator.FilterAndProjectOperator
 
FilterAndProjectOperator.FilterAndProjectOperatorFactory - Class in io.prestosql.operator
 
FilterAndProjectOperatorFactory(int, PlanNodeId, Supplier<PageProcessor>, List<Type>, DataSize, int) - Constructor for class io.prestosql.operator.FilterAndProjectOperator.FilterAndProjectOperatorFactory
 
filterBlock(Type, Block, ArrayFilterFunction.FilterBlockLambda) - Static method in class io.prestosql.operator.scalar.ArrayFilterFunction
 
filterBoolean(Type, Block, ArrayFilterFunction.FilterBooleanLambda) - 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.AllowAllSystemAccessControl
 
filterCatalogs(Identity, Set<String>) - Method in class io.prestosql.security.DenyAllAccessControl
 
filterCatalogs(Identity, Set<String>) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
filterCatalogs(Identity, Set<String>) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
filterConjuncts(Expression, Predicate<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
filterDeterministicConjuncts(Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
filterDouble(Type, Block, ArrayFilterFunction.FilterDoubleLambda) - Static method in class io.prestosql.operator.scalar.ArrayFilterFunction
 
filteredCopy(List<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
 
filterLong(Type, Block, ArrayFilterFunction.FilterLongLambda) - 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(Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
filterOrRewrite(Collection<Symbol>, Collection<JoinNode.EquiJoinClause>, Symbol) - Static method in class io.prestosql.sql.planner.optimizations.PropertyDerivations
 
filterRequest(Request) - Method in class io.prestosql.server.GenerateTraceTokenRequestFilter
 
filterSchemas(TransactionId, Identity, 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(TransactionId, Identity, String, Set<String>) - Method in class io.prestosql.security.AccessControlManager
 
filterSchemas(TransactionId, Identity, String, Set<String>) - Method in class io.prestosql.security.AllowAllAccessControl
 
filterSchemas(Identity, String, Set<String>) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
filterSchemas(TransactionId, Identity, String, Set<String>) - Method in class io.prestosql.security.DenyAllAccessControl
 
filterSchemas(Identity, String, Set<String>) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
filterSchemas(Identity, String, Set<String>) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
filterSlice(Type, Block, ArrayFilterFunction.FilterSliceLambda) - Static method in class io.prestosql.operator.scalar.ArrayFilterFunction
 
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(TransactionId, Identity, String, Set<SchemaTableName>) - Method in interface io.prestosql.security.AccessControl
Filter the list of tables and views to those visible to the identity.
filterTables(TransactionId, Identity, String, Set<SchemaTableName>) - Method in class io.prestosql.security.AccessControlManager
 
filterTables(TransactionId, Identity, String, Set<SchemaTableName>) - Method in class io.prestosql.security.AllowAllAccessControl
 
filterTables(Identity, String, Set<SchemaTableName>) - Method in class io.prestosql.security.AllowAllSystemAccessControl
 
filterTables(TransactionId, Identity, String, Set<SchemaTableName>) - Method in class io.prestosql.security.DenyAllAccessControl
 
filterTables(Identity, String, Set<SchemaTableName>) - Method in class io.prestosql.security.FileBasedSystemAccessControl
 
filterTables(Identity, String, Set<SchemaTableName>) - Method in class io.prestosql.security.ReadOnlySystemAccessControl
 
filterWithTuple(Page) - Method in class io.prestosql.operator.index.DynamicTupleFilterFactory
 
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.AssignUniqueIdOperator
 
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.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.FilterAndProjectOperator
 
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.HashSemiJoinOperator
 
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.MetadataDeleteOperator
 
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.PageSourceOperator
 
finish() - Method in class io.prestosql.operator.PartitionedOutputOperator
 
finish() - Method in class io.prestosql.operator.project.MergingPageOutput
 
finish() - Method in class io.prestosql.operator.RowNumberOperator
 
finish() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
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.StreamingAggregationOperator
 
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.UnnestOperator
 
finish() - Method in class io.prestosql.operator.ValuesOperator
 
finish() - Method in class io.prestosql.operator.WindowOperator
 
finish() - Method in class io.prestosql.split.EmptySplitPageSource
 
finish() - Method in class io.prestosql.testing.NullOutputOperator
 
finish() - Method in class io.prestosql.testing.PageConsumerOperator
 
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 variable in interface io.prestosql.operator.exchange.LocalExchanger
 
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.
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
 
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
 
finishProbeOperator(OptionalInt) - Method in interface io.prestosql.operator.LookupSourceFactory
 
finishProbeOperator(OptionalInt) - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
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
 
firstNonNaN(double...) - Static method in class io.prestosql.util.MoreMath
 
FirstValueFunction - Class in io.prestosql.operator.window
 
FirstValueFunction(List<Integer>) - Constructor for class io.prestosql.operator.window.FirstValueFunction
 
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_PASSTHROUGH_DISTRIBUTION - Static variable in class io.prestosql.sql.planner.SystemPartitioningHandle
 
FixedBucketNodeMap - Class in io.prestosql.execution.scheduler
 
FixedBucketNodeMap(ToIntFunction<Split>, List<Node>) - Constructor for class io.prestosql.execution.scheduler.FixedBucketNodeMap
 
FixedCountScheduler - Class in io.prestosql.execution.scheduler
 
FixedCountScheduler(SqlStageExecution, List<Node>) - Constructor for class io.prestosql.execution.scheduler.FixedCountScheduler
 
FixedCountScheduler(FixedCountScheduler.TaskScheduler, List<Node>) - Constructor for class io.prestosql.execution.scheduler.FixedCountScheduler
 
FixedCountScheduler.TaskScheduler - Interface in io.prestosql.execution.scheduler
 
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<Node>, BucketNodeMap, int, OptionalInt, NodeSelector, List<ConnectorPartitionHandle>) - Constructor for class io.prestosql.execution.scheduler.FixedSourcePartitionedScheduler
 
FixedSourcePartitionedScheduler.BucketedSplitPlacementPolicy - Class in io.prestosql.execution.scheduler
 
FLAT - Static variable in class io.prestosql.execution.scheduler.NodeSchedulerConfig.NetworkTopologyType
 
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(Type, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayFlattenFunction
 
flatten(WorkProcessor<WorkProcessor<T>>) - Static method in interface io.prestosql.operator.WorkProcessor
 
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(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
floor(double) - 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
 
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(T) - Method in class io.prestosql.operator.aggregation.AbstractGroupCollectionAggregationState
 
forEach(ArrayAggregationStateConsumer) - Method in interface io.prestosql.operator.aggregation.arrayagg.ArrayAggregationState
 
forEach(ArrayAggregationStateConsumer) - Method in class io.prestosql.operator.aggregation.arrayagg.LegacyArrayAggregationGroupState
Deprecated.
 
forEach(ArrayAggregationStateConsumer) - Method in class io.prestosql.operator.aggregation.arrayagg.SingleArrayAggregationState
 
forEach(MultimapAggregationStateConsumer) - Method in class io.prestosql.operator.aggregation.multimapagg.LegacyGroupedMultimapAggregationState
Deprecated.
 
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
 
ForExchange - Annotation Type in io.prestosql.operator
 
ForFailureDetector - Annotation Type in io.prestosql.failureDetector
 
formatDatetime(ConnectorSession, long, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
formatDatetimeWithTimeZone(ConnectorSession, long, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
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
 
ForMemoryManager - Annotation Type in io.prestosql.memory
 
ForNodeManager - Annotation Type in io.prestosql.metadata
 
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
 
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>, FrameBound.Type, Optional<Symbol>, Optional<Expression>, Optional<Expression>) - Constructor for class io.prestosql.sql.planner.plan.WindowNode.Frame
 
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>, FrameBound.Type, Optional<Integer>) - Constructor for class io.prestosql.operator.window.FrameInfo
 
free(QueryId, String, long) - Method in class io.prestosql.memory.MemoryPool
 
free(long) - Method in class io.prestosql.spiller.SpillSpaceTracker
 
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(Function<GroupReference, Stream<PlanNode>>) - Static method in interface io.prestosql.sql.planner.iterative.Lookup
 
from(Expression) - Static method in class io.prestosql.sql.planner.Symbol
 
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
 
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
 
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
 
fromPredicate(Metadata, 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.
fromSchemaTableName(ConnectorId, SchemaTableName) - Static method in class io.prestosql.connector.system.SystemTableHandle
 
fromSqlType(Type, boolean, boolean, String) - Static method in class io.prestosql.operator.aggregation.AggregationMetadata.ParameterMetadata
 
fromString(String) - Static method in class io.prestosql.execution.buffer.OutputBuffers.OutputBufferId
 
fromType(SampledRelation.Type) - Static method in enum io.prestosql.sql.planner.plan.SampleNode.Type
 
fromTypes(List<? extends Type>) - 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
 
fromUtf8(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
fromUtf8(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
fromUtf8(Slice, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
FullConnectorSession - Class in io.prestosql
 
FullConnectorSession(Session, ConnectorIdentity) - Constructor for class io.prestosql.FullConnectorSession
 
FullConnectorSession(Session, ConnectorIdentity, Map<String, String>, ConnectorId, String, SessionPropertyManager) - Constructor for class io.prestosql.FullConnectorSession
 
fullOuterJoin(int, PlanNodeId, JoinBridgeManager<? extends LookupSourceFactory>, List<Type>, List<Integer>, OptionalInt, Optional<List<Integer>>, OptionalInt, PartitioningSpillerFactory) - Method in class io.prestosql.operator.LookupJoinOperators
 
function(SqlFunction) - Method in class io.prestosql.metadata.FunctionListBuilder
 
Function(FunctionCall, Signature, WindowNode.Frame) - Constructor for class io.prestosql.sql.planner.plan.WindowNode.Function
 
FUNCTION - Static variable in class io.prestosql.type.FunctionParametricType
 
FunctionCallCodeGenerator - Class in io.prestosql.sql.gen
 
FunctionCallCodeGenerator() - Constructor for class io.prestosql.sql.gen.FunctionCallCodeGenerator
 
FunctionCallDeserializer(SqlParser) - Constructor for class io.prestosql.sql.Serialization.FunctionCallDeserializer
 
FunctionExtractor - Class in io.prestosql.metadata
 
FunctionImplementationDependency - Class in io.prestosql.operator.annotations
 
FunctionImplementationDependency(String, TypeSignature, List<TypeSignature>, Optional<InvocationConvention>) - Constructor for class io.prestosql.operator.annotations.FunctionImplementationDependency
 
FunctionInvoker - Class in io.prestosql.metadata
 
FunctionInvoker(MethodHandle) - Constructor for class io.prestosql.metadata.FunctionInvoker
 
FunctionInvokerProvider - Class in io.prestosql.metadata
 
FunctionInvokerProvider(FunctionRegistry) - Constructor for class io.prestosql.metadata.FunctionInvokerProvider
 
FunctionKind - Enum in io.prestosql.metadata
 
FunctionListBuilder - Class in io.prestosql.metadata
 
FunctionListBuilder() - Constructor for class io.prestosql.metadata.FunctionListBuilder
 
FunctionParametricType - Class in io.prestosql.type
 
FunctionRegistry - Class in io.prestosql.metadata
 
FunctionRegistry(TypeManager, BlockEncodingSerde, FeaturesConfig) - Constructor for class io.prestosql.metadata.FunctionRegistry
 
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
 
functionTypeArgumentProperty(Class) - Static method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ArgumentProperty
 
FutureStateChange<T> - Class in io.prestosql.execution
 
FutureStateChange() - Constructor for class io.prestosql.execution.FutureStateChange
 

G

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
 
generate(RowExpression, Optional<Class>) - Method in class io.prestosql.sql.gen.BytecodeGeneratorContext
 
generateAccumulatorFactoryBinder(AggregationMetadata, DynamicClassLoader) - Static method in class io.prestosql.operator.aggregation.AccumulatorCompiler
 
generateAggregation(Type, MethodHandle) - Method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
generateAggregation(Type) - Method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
generateAggregation(Type, Type) - Method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
generateAggregationName(String, TypeSignature, List<TypeSignature>) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
generateCall(String, ScalarFunctionImplementation, 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.RootInternalResourceGroup
 
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(Predicate<Symbol>) - Method in class io.prestosql.sql.planner.EqualityInference
Dumps the inference equalities as equality expressions that are partitioned by the symbolScope.
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.AndCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.BindCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in interface io.prestosql.sql.gen.BytecodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.CastCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.CoalesceCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.DereferenceCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.FunctionCallCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.IfCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.InCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.IsNullCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.NullIfCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.OrCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - Method in class io.prestosql.sql.gen.RowConstructorCodeGenerator
 
generateExpression(Signature, BytecodeGeneratorContext, Type, List<RowExpression>) - 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
 
generateInitializations(Variable, BytecodeBlock) - Method in class io.prestosql.sql.gen.CachedInstanceBinder
 
generateInternalAggregationFunction(Class<?>, TypeSignature, List<TypeSignature>) - Static method in class io.prestosql.testing.AggregationTestUtils
 
generateInternalAggregationFunction(Class<?>, TypeSignature, List<TypeSignature>, TypeManager) - Static method in class io.prestosql.testing.AggregationTestUtils
 
generateInternalAggregationFunction(Class<?>, TypeSignature, List<TypeSignature>, TypeManager, BoundVariables, int) - Static method in class io.prestosql.testing.AggregationTestUtils
 
generateInvocation(Scope, String, ScalarFunctionImplementation, Optional<BytecodeNode>, 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, FunctionRegistry) - 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>, Constructor<? extends GroupedAccumulator>, List<LambdaProvider>, List<Integer>, Optional<Integer>, List<Type>, List<Integer>, List<SortOrder>, PagesIndex.Factory, JoinCompiler, Session, boolean) - Constructor for class io.prestosql.operator.aggregation.GenericAccumulatorFactory
 
GenericAccumulatorFactoryBinder - Class in io.prestosql.operator.aggregation
 
GenericAccumulatorFactoryBinder(List<AggregationMetadata.AccumulatorStateDescriptor>, Class<? extends Accumulator>, Class<? extends GroupedAccumulator>) - Constructor for class io.prestosql.operator.aggregation.GenericAccumulatorFactoryBinder
 
genericArraysOverlap(Block, Block, AbstractType) - Method in class io.prestosql.operator.scalar.ArraysOverlapFunction
 
genericEqual(Type, Block, Block, MapGenericEquality.EqualityPredicate) - Static method in class io.prestosql.operator.scalar.MapGenericEquality
 
genericIntegerTypeToLongDecimal(long, int, int) - Static method in class io.prestosql.type.DecimalSaturatedFloorCasts
 
genericIntegerTypeToShortDecimal(long, int, int) - Static method in class io.prestosql.type.DecimalSaturatedFloorCasts
 
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
 
GeometricMeanAggregations - Class in io.prestosql.operator.aggregation
 
GeometryWithPosition(OGCGeometry, int, int) - Constructor for class io.prestosql.operator.PagesRTreeIndex.GeometryWithPosition
 
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(HostAddress) - Method in class io.prestosql.execution.scheduler.NetworkLocationCache
 
get() - Method in class io.prestosql.execution.StateMachine
 
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.LegacyHistogramGroupState
Deprecated.
 
get() - Method in class io.prestosql.operator.aggregation.histogram.SingleHistogramState
 
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(LocalMemoryContext) - Method in class io.prestosql.operator.ExchangeClientFactory
 
get(LocalMemoryContext) - Method in interface io.prestosql.operator.ExchangeClientSupplier
 
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.operator.scalar.annotations.ParametricScalarImplementation.Parser
 
get(Symbol) - Method in class io.prestosql.sql.planner.plan.Assignments
 
get() - Method in class io.prestosql.sql.planner.plan.SimplePlanRewriter.RewriteContext
 
get() - Method in class io.prestosql.sql.planner.PlanOptimizers
 
get(Symbol) - Method in class io.prestosql.sql.planner.TypeProvider
 
getAbandonedQueries() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
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
 
getAccumulatorFactoryBinder() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
getAccumulatorStateDescriptors() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getActiveConnectorNodes(ConnectorId) - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
getActiveConnectorNodes(ConnectorId) - Method in class io.prestosql.metadata.InMemoryNodeManager
 
getActiveConnectorNodes(ConnectorId) - Method in interface io.prestosql.metadata.InternalNodeManager
 
getActiveCoordinators() - Method in class io.prestosql.metadata.AllNodes
 
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(ConnectorId) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getActiveWorkers() - Method in class io.prestosql.server.ClusterStatsResource.ClusterStats
 
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.PrestoServer
 
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
 
getAddWarnings() - Method in class io.prestosql.testing.TestingWarningCollectorConfig
 
getAge() - Method in class io.prestosql.failureDetector.HeartbeatFailureDetector.Stats
 
getAggregateFunctionImplementation(Signature) - Method in class io.prestosql.metadata.FunctionRegistry
 
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
 
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
 
getAllChoices() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation
 
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.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
 
getAllQueries() - Method in class io.prestosql.execution.QueryTracker
 
getAllQueryInfo(String) - Method in class io.prestosql.server.QueryResource
 
getAllQueryTypes() - Static method in class io.prestosql.util.StatementUtils
 
getAllSessionProperties(Session, Map<String, ConnectorId>) - 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
 
getArgumentProperties() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
getArgumentProperties() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ScalarImplementationChoice
 
getArgumentProperty(int) - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation
 
getArgumentProperty(int) - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ScalarImplementationChoice
 
getArguments() - Method in class io.prestosql.sql.planner.Partitioning
 
getArguments() - Method in class io.prestosql.sql.relational.CallExpression
 
getArguments() - Method in class io.prestosql.sql.relational.LambdaDefinitionExpression
 
getArgumentType() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ArgumentProperty
 
getArgumentTypes() - Method in exception io.prestosql.metadata.OperatorNotFoundException
 
getArgumentTypes() - Method in class io.prestosql.metadata.Signature
 
getArgumentTypes() - Method in class io.prestosql.sql.relational.LambdaDefinitionExpression
 
getArgumentTypes() - Method in class io.prestosql.type.FunctionType
 
getArity() - Method in class io.prestosql.metadata.SpecializedFunctionKey
 
getArrayAggGroupImplementation() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getAssignedNode(int) - Method in class io.prestosql.execution.scheduler.BucketNodeMap
 
getAssignedNode(Split) - 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
 
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.optimizations.joins.JoinGraph
 
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
 
getAuthenticateHeader() - Method in exception io.prestosql.server.security.AuthenticationException
 
getAuthenticationFail() - Method in class io.prestosql.security.AccessControlManager
 
getAuthenticationSuccess() - Method in class io.prestosql.security.AccessControlManager
 
getAuthenticationTypes() - Method in class io.prestosql.server.security.SecurityConfig
 
getAuthenticator() - Method in class io.prestosql.server.security.PasswordAuthenticatorManager
 
getAuthorizationFail() - Method in class io.prestosql.security.AccessControlManager
 
getAuthorizationSuccess() - Method in class io.prestosql.security.AccessControlManager
 
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.execution.DataDefinitionExecution
 
getBasicQueryInfo() - Method in class io.prestosql.execution.FailedQueryExecution
 
getBasicQueryInfo() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
getBasicQueryInfo(Optional<BasicStageStats>) - Method in class io.prestosql.execution.QueryStateMachine
 
getBasicQueryInfo() - Method in class io.prestosql.execution.SqlQueryExecution
 
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
 
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
 
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.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
 
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
 
getBoundVariables() - Method in class io.prestosql.metadata.SpecializedFunctionKey
 
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.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
 
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
 
getCall(CurrentPath) - Static method in class io.prestosql.sql.planner.iterative.rule.DesugarCurrentPath
 
getCall(CurrentUser) - Static method in class io.prestosql.sql.planner.iterative.rule.DesugarCurrentUser
 
getCall() - Method in class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
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.SqlQueryManagerStats
 
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
 
getCatalog(String) - Method in class io.prestosql.metadata.CatalogManager
 
getCatalog() - Method in class io.prestosql.metadata.ViewDefinition
 
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.CreateName
 
getCatalog() - Method in class io.prestosql.sql.SqlPathElement
 
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, ConnectorId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getCatalogMetadata(TransactionId, ConnectorId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getCatalogMetadata(TransactionId, ConnectorId) - Method in interface io.prestosql.transaction.TransactionManager
 
getCatalogMetadataForWrite(TransactionId, ConnectorId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getCatalogMetadataForWrite(TransactionId, String) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getCatalogMetadataForWrite(TransactionId, ConnectorId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getCatalogMetadataForWrite(TransactionId, String) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getCatalogMetadataForWrite(TransactionId, ConnectorId) - Method in interface io.prestosql.transaction.TransactionManager
 
getCatalogMetadataForWrite(TransactionId, String) - Method in interface io.prestosql.transaction.TransactionManager
 
getCatalogName() - Method in class io.prestosql.connector.ConnectorId
 
getCatalogName() - Method in class io.prestosql.connector.informationSchema.InformationSchemaTableHandle
 
getCatalogName() - Method in class io.prestosql.metadata.Catalog
 
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
 
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
 
getCatalogRules() - Method in class io.prestosql.security.FileBasedSystemAccessControlRules
 
getCatalogs() - Method in class io.prestosql.metadata.CatalogManager
 
getCatalogsByQueryId() - Method in class io.prestosql.metadata.MetadataManager
 
getCatalogSessionProperties() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getCatalogSessionProperties() - Method in interface io.prestosql.server.SessionContext
 
getCause() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
getChannel(int) - Method in class io.prestosql.operator.PagesIndex
 
getChannelCount() - Method in class io.prestosql.operator.ArrayOfRowsUnnester
 
getChannelCount() - Method in class io.prestosql.operator.ArrayUnnester
 
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.MapUnnester
 
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
 
getChannelCount() - Method in interface io.prestosql.operator.Unnester
 
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.sql.planner.planPrinter.JsonRenderer.JsonRenderedNode
 
getChildren() - Method in class io.prestosql.sql.planner.planPrinter.NodeRepresentation
 
getChildren() - Method in class io.prestosql.sql.planner.SubPlan
 
getChoices() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation
 
getChronology(TimeZoneKey) - Static method in class io.prestosql.util.DateTimeZoneIndex
 
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
 
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
 
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
 
getClusterMemoryPoolInfo() - Method in class io.prestosql.server.ClusterStatsResource
 
getClusterStats() - Method in class io.prestosql.server.ClusterStatsResource
 
getClusterTotalMemoryReservation() - Method in class io.prestosql.memory.ClusterMemoryManager
 
getClusterUserMemoryReservation() - Method in class io.prestosql.memory.ClusterMemoryManager
 
getCode() - Method in exception io.prestosql.sql.analyzer.SemanticException
 
getCoercion(Type, Type) - Method in class io.prestosql.metadata.FunctionRegistry
 
getCoercion(TypeSignature, TypeSignature) - Method in class io.prestosql.metadata.FunctionRegistry
 
getCoercion(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
getCoercion(Expression) - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getCoercions() - Method in class io.prestosql.sql.analyzer.Analysis
 
getColumn(String) - Method in class io.prestosql.metadata.TableMetadata
 
getColumn(Field) - Method in class io.prestosql.sql.analyzer.Analysis
 
getColumn() - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
getColumnAliases() - Method in class io.prestosql.sql.analyzer.Analysis
 
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(String) - Method in class io.prestosql.metadata.HandleResolver
 
getColumnHandleClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getColumnHandleClass() - Method in class io.prestosql.split.EmptySplitHandleResolver
 
getColumnHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
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 can not be enumerated.
getColumnHandles(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.testing.TestingMetadata
 
getColumnIndex(String) - Method in class io.prestosql.metadata.InternalTable
 
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(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.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.metadata.ViewDefinition
 
getColumns() - Method in class io.prestosql.sql.analyzer.Analysis.Insert
 
getColumns() - Method in class io.prestosql.sql.planner.Partitioning
 
getColumns() - Method in class io.prestosql.sql.planner.plan.TableWriterNode
 
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(Class<?>, Class<?>) - Static method in class io.prestosql.operator.aggregation.AggregationFromAnnotationsParser
 
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(Type, Type) - Method in class io.prestosql.type.TypeRegistry
 
getCommonSuperType() - Method in class io.prestosql.type.TypeRegistry.TypeCompatibility
 
getComparator() - Method in class io.prestosql.operator.PagesIndexOrdering
 
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.EmptySplitPageSource
 
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.SqlQueryManagerStats
 
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
 
getCompression() - Method in class io.prestosql.execution.buffer.SerializedPage
 
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
 
getConnector(ConnectorId) - Method in class io.prestosql.metadata.Catalog
 
getConnectorCapabilities() - Method in class io.prestosql.metadata.CatalogMetadata
 
getConnectorCapabilities(Session, ConnectorId) - Method in interface io.prestosql.metadata.Metadata
 
getConnectorCapabilities(Session, ConnectorId) - Method in class io.prestosql.metadata.MetadataManager
 
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.connector.system.GlobalSystemTransactionHandle
 
getConnectorId() - Method in class io.prestosql.connector.system.SystemColumnHandle
 
getConnectorId() - Method in class io.prestosql.connector.system.SystemSplit
 
getConnectorId() - Method in class io.prestosql.connector.system.SystemTableHandle
 
getConnectorId() - Method in class io.prestosql.connector.system.SystemTableLayoutHandle
 
getConnectorId() - Method in class io.prestosql.connector.system.SystemTransactionHandle
 
getConnectorId() - Method in class io.prestosql.execution.Input
 
getConnectorId() - Method in class io.prestosql.execution.Output
 
getConnectorId() - Method in class io.prestosql.metadata.AnalyzeTableHandle
 
getConnectorId() - Method in class io.prestosql.metadata.Catalog
 
getConnectorId() - Method in class io.prestosql.metadata.CatalogMetadata
 
getConnectorId(Session, QualifiedObjectName) - Method in class io.prestosql.metadata.CatalogMetadata
 
getConnectorId() - Method in class io.prestosql.metadata.IndexHandle
 
getConnectorId() - Method in class io.prestosql.metadata.InsertTableHandle
 
getConnectorId() - Method in class io.prestosql.metadata.NewTableLayout
 
getConnectorId() - Method in class io.prestosql.metadata.OutputTableHandle
 
getConnectorId() - Method in class io.prestosql.metadata.Split
 
getConnectorId() - Method in class io.prestosql.metadata.TableHandle
 
getConnectorId() - Method in class io.prestosql.metadata.TableMetadata
 
getConnectorId() - Method in class io.prestosql.split.BufferingSplitSource
 
getConnectorId() - Method in class io.prestosql.split.ConnectorAwareSplitSource
 
getConnectorId() - Method in class io.prestosql.split.EmptySplit
 
getConnectorId() - Method in class io.prestosql.split.SampledSplitSource
 
getConnectorId() - Method in interface io.prestosql.split.SplitSource
 
getConnectorId() - Method in class io.prestosql.sql.planner.PartitioningHandle
 
getConnectorIds() - Method in class io.prestosql.transaction.TransactionInfo
 
getConnectorInfo() - Method in class io.prestosql.execution.Input
 
getConnectorOutputMetadata() - Method in class io.prestosql.operator.TableFinishInfo
 
getConnectorProperties() - Method in class io.prestosql.Session
 
getConnectorProperties(ConnectorId) - Method in class io.prestosql.Session
 
getConnectorSessionPropertyMetadata(ConnectorId, String) - Method in class io.prestosql.metadata.SessionPropertyManager
 
getConnectorSplit() - Method in class io.prestosql.metadata.Split
 
getConnectorTransaction(TransactionId, ConnectorId) - Method in class io.prestosql.transaction.InMemoryTransactionManager
 
getConnectorTransaction(TransactionId, ConnectorId) - Method in class io.prestosql.transaction.NoOpTransactionManager
 
getConnectorTransaction(TransactionId, ConnectorId) - 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.SystemTableLayoutHandle
 
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.SqlQueryManagerStats
 
getConsumedInputBytes() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
getConsumedInputRows() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
getConsumersCount() - Method in class io.prestosql.operator.PartitionedConsumption
 
getCoordinatorId() - Method in class io.prestosql.execution.QueryIdGenerator
 
getCoordinatorId() - Method in class io.prestosql.memory.MemoryPoolAssignmentsRequest
 
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(CorrelationState) - Static method in class io.prestosql.operator.aggregation.AggregationUtils
 
getCorrelation() - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
getCorrelation() - Method in class io.prestosql.sql.planner.plan.LateralJoinNode
 
getCost(PlanNode) - Method in class io.prestosql.cost.CachingCostProvider
 
getCost(PlanNode) - Method in interface io.prestosql.cost.CostProvider
 
getCost(int) - Method in class io.prestosql.sql.planner.iterative.Memo
 
getCost() - Method in class io.prestosql.sql.planner.iterative.rule.PlanNodeWithCost
 
getCostCalculator() - Method in class io.prestosql.testing.LocalQueryRunner
 
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.TopNNode
 
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.
getCpuCostWeight() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getCpuInputByteRate() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
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
 
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
 
getCreateTableComment() - Method in class io.prestosql.sql.analyzer.Analysis
 
getCreateTableDestination() - Method in class io.prestosql.sql.analyzer.Analysis
 
getCreateTableProperties() - Method in class io.prestosql.sql.analyzer.Analysis
 
getCreateTime() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getCreateTime() - Method in class io.prestosql.execution.FailedQueryExecution
 
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.
getCurrentConstraint() - Method in class io.prestosql.sql.planner.plan.IndexSourceNode
 
getCurrentConstraint() - Method in class io.prestosql.sql.planner.plan.TableScanNode
A TupleDomain that represents a predicate that every row this TableScan node produces is guaranteed to satisfy.
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
 
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
 
getDependencies() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
getDescription() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
getDescription() - Method in interface io.prestosql.metadata.SqlFunction
 
getDescription() - Method in class io.prestosql.metadata.SqlOperator
 
getDescription() - Method in class io.prestosql.operator.aggregation.AggregationHeader
 
getDescription() - Method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.CountColumn
 
getDescription() - Method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
getDescription() - Method in class io.prestosql.operator.aggregation.DecimalSumAggregation
 
getDescription() - Method in class io.prestosql.operator.aggregation.histogram.Histogram
 
getDescription() - Method in class io.prestosql.operator.aggregation.MapAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.MapUnionAggregation
 
getDescription() - Method in class io.prestosql.operator.aggregation.MaxAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.MaxNAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.MinAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.minmaxby.MaxByAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.minmaxby.MaxByNAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.minmaxby.MinByAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.minmaxby.MinByNAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.MinNAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.ParametricAggregation
 
getDescription() - Method in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
getDescription() - Method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.annotations.ScalarImplementationHeader
 
getDescription() - Method in class io.prestosql.operator.scalar.ApplyFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.ArrayConcatFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.ArrayConstructor
 
getDescription() - Method in class io.prestosql.operator.scalar.ArrayFlattenFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.ArrayJoin.ArrayJoinWithNullReplacement
 
getDescription() - Method in class io.prestosql.operator.scalar.ArrayJoin
 
getDescription() - Method in class io.prestosql.operator.scalar.ArrayReduceFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.ArrayToElementConcatFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.ArrayTransformFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.ConcatFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.ElementToArrayConcatFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.Greatest
 
getDescription() - Method in class io.prestosql.operator.scalar.InvokeFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.JsonStringToArrayCast
 
getDescription() - Method in class io.prestosql.operator.scalar.JsonStringToMapCast
 
getDescription() - Method in class io.prestosql.operator.scalar.JsonStringToRowCast
 
getDescription() - Method in class io.prestosql.operator.scalar.Least
 
getDescription() - Method in class io.prestosql.operator.scalar.MapConcatFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.MapConstructor
 
getDescription() - Method in class io.prestosql.operator.scalar.MapElementAtFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.MapFilterFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.MapTransformKeyFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.MapTransformValueFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.MapZipWithFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.ParametricScalar
 
getDescription() - Method in class io.prestosql.operator.scalar.ScalarHeader
 
getDescription() - Method in class io.prestosql.operator.scalar.TryCastFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.ZipFunction
 
getDescription() - Method in class io.prestosql.operator.scalar.ZipWithFunction
 
getDescription() - Method in class io.prestosql.operator.window.AbstractWindowFunctionSupplier
 
getDescription() - Method in class io.prestosql.operator.window.SqlWindowFunction
 
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
 
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.DigestAndPercentileArrayState
 
getDigest() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.GroupedDigestAndPercentileArrayState
 
getDigest() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.SingleDigestAndPercentileArrayState
 
getDigest() - Method in interface io.prestosql.operator.aggregation.state.DigestAndPercentileState
 
getDigest() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.GroupedDigestAndPercentileState
 
getDigest() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.SingleDigestAndPercentileState
 
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
 
getDisplayName() - Method in class io.prestosql.type.FunctionType
 
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
 
getDistributedPlanningTime() - Method in class io.prestosql.execution.QueryStats
 
getDistribution() - Method in class io.prestosql.connector.system.CatalogSystemTable
 
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.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
 
getDriverMemoryContext() - Method in class io.prestosql.operator.DriverContext
 
getDrivers() - Method in class io.prestosql.operator.PipelineStats
 
getDriverStats() - Method in class io.prestosql.operator.DriverContext
 
getDummyValue() - Method in class io.prestosql.metadata.RemoteTransactionHandle
 
getDurationType() - Method in class io.prestosql.operator.scalar.QuarterOfYearDateTimeField
 
getEdges(PlanNode) - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
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
 
getEncodingName() - Method in class io.prestosql.operator.GroupByIdBlock
 
getEndChannel() - Method in class io.prestosql.operator.window.FrameInfo
 
getEndTime() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getEndTime() - Method in class io.prestosql.execution.FailedQueryExecution
 
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 class io.prestosql.operator.aggregation.multimapagg.LegacyGroupedMultimapAggregationState
Deprecated.
 
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.testing.TestingNodeManager
 
getEquivalentClasses() - Method in class io.prestosql.util.DisjointSet
 
getErrorCode() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getErrorCode() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
getErrorCode() - Method in class io.prestosql.execution.FailedQueryExecution
 
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.execution.SqlQueryExecution
 
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
 
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.LegacyArrayAggregationGroupState
Deprecated.
 
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.LegacyHistogramGroupState
Deprecated.
 
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.minmaxby.MinMaxByNStateFactory.GroupedMinMaxByNState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateFactory.SingleMinMaxByNState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.multimapagg.LegacyGroupedMultimapAggregationState
Deprecated.
 
getEstimatedSize() - Method in interface io.prestosql.operator.aggregation.multimapagg.MultimapAggregationState
 
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.DigestAndPercentileArrayStateFactory.GroupedDigestAndPercentileArrayState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.SingleDigestAndPercentileArrayState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.GroupedDigestAndPercentileState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.SingleDigestAndPercentileState
 
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.QuantileDigestStateFactory.GroupedQuantileDigestState
 
getEstimatedSize() - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateFactory.SingleQuantileDigestState
 
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
 
getExactImplementations() - Method in class io.prestosql.operator.ParametricImplementationsGroup
 
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.execution.DataDefinitionExecution
 
getExecutionStartTime() - Method in class io.prestosql.execution.FailedQueryExecution
 
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.QueryStats
 
getExecutionTime() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
getExecutionTime() - Method in class io.prestosql.server.BasicQueryStats
 
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(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getExistsSubqueries() - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getExistsSubqueries() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
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.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.SqlQueryManagerStats
 
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.SqlQueryManagerStats
 
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.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(Chronology) - Method in class io.prestosql.operator.scalar.QuarterOfYearDateTimeField
 
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.testing.MaterializedRow
 
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
 
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.testing.MaterializedRow
 
getFile() - Method in class io.prestosql.server.ThreadResource.StackLine
 
getFilter() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getFilter() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
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() - 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.BlockAndBlockPositionValueState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockBooleanState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockDoubleState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockLongState
 
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.SliceAndBlockPositionValueState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceBooleanState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceDoubleState
 
getFirst() - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceLongState
 
getFirstStartTime() - Method in class io.prestosql.operator.PipelineStats
 
getFirstStartTime() - Method in class io.prestosql.operator.TaskStats
 
getFormattedSql(Statement, SqlParser, Optional<List<Expression>>) - 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
 
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
 
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
 
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(QueryId) - Method in interface io.prestosql.execution.QueryManager
 
getFullQueryInfo(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
getFullyQualifiedName() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
getFunction() - Method in class io.prestosql.metadata.SpecializedFunctionKey
 
getFunction() - Method in class io.prestosql.operator.window.FramedWindowFunction
 
getFunction() - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
getFunctionCall() - Method in class io.prestosql.sql.planner.plan.WindowNode.Function
 
getFunctionInvokerProvider() - Method in class io.prestosql.metadata.FunctionRegistry
 
getFunctionRegistry() - Method in interface io.prestosql.metadata.Metadata
 
getFunctionRegistry() - Method in class io.prestosql.metadata.MetadataManager
 
getFunctionRegistry() - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.SpecializeContext
 
getFunctions() - Method in class io.prestosql.metadata.FunctionListBuilder
 
getFunctionSignature(FunctionCall) - Method in class io.prestosql.sql.analyzer.Analysis
 
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
 
getGraphvizPlan(Session, Statement, ExplainType.Type, List<Expression>, WarningCollector) - Method in class io.prestosql.sql.analyzer.QueryExplainer
 
getGroupByExpressions(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
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.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.DigestAndPercentileArrayStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory
 
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.QuantileDigestStateFactory
 
getGroupedStateClass() - Method in class io.prestosql.type.setdigest.SetDigestStateFactory
 
getGroupId() - Method in class io.prestosql.operator.aggregation.state.AbstractGroupedAccumulatorState
 
getGroupId(int) - Method in class io.prestosql.operator.GroupByIdBlock
 
getGroupId() - Method in class io.prestosql.sql.planner.iterative.GroupReference
 
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(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
getGroupingSets() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getGroupingSets() - Method in class io.prestosql.sql.planner.plan.GroupIdNode
 
getGroupingSymbols() - Method in class io.prestosql.sql.planner.plan.StatisticAggregations
 
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.CreateHandle
 
getHandle() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.DeleteHandle
 
getHandle() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertHandle
 
getHandle() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertReference
 
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
 
getHashBlock(List<? extends Type>, Block...) - Static method in class io.prestosql.type.TypeUtils
 
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(List<Symbol>) - Static method in class io.prestosql.sql.planner.optimizations.HashGenerationOptimizer
 
getHashPage(Page, List<? extends Type>, List<Integer>) - Static method in class io.prestosql.type.TypeUtils
 
getHashPartitionCount(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getHashPosition(List<? extends Type>, Block[], int) - Static method in class io.prestosql.type.TypeUtils
 
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
 
getHistogramGroupImplementation() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getHitRate() - Method in class io.prestosql.sql.gen.CacheStatsMBean
 
getHits() - Method in class io.prestosql.sql.planner.iterative.RuleStats
 
getHll() - Method in class io.prestosql.type.setdigest.SetDigest
 
getHostAndPort() - Method in class io.prestosql.metadata.PrestoNode
 
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
 
getHttpTimeoutThreads() - Method in class io.prestosql.execution.TaskManagerConfig
 
getHttpUri() - Method in class io.prestosql.metadata.PrestoNode
 
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(ConnectorTableHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorTableLayoutHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ColumnHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorSplit) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorIndexHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorOutputTableHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorInsertTableHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorPartitioningHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId(ConnectorTransactionHandle) - Method in class io.prestosql.metadata.HandleResolver
 
getId() - Method in class io.prestosql.server.ResourceGroupInfo
 
getId() - Method in class io.prestosql.server.ThreadResource.Info
 
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
 
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.server.HttpRequestSessionContext
 
getIdentity() - Method in interface io.prestosql.server.SessionContext
 
getIdentity() - Method in class io.prestosql.Session
 
getIdentity() - Method in class io.prestosql.sql.analyzer.Analysis.AccessControlInfo
 
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
 
getInactiveNodeCount() - Method in class io.prestosql.metadata.DiscoveryNodeManager
 
getInactiveNodes() - Method in class io.prestosql.metadata.AllNodes
 
getIndex(Session, IndexHandle, List<ColumnHandle>, List<ColumnHandle>) - Method in class io.prestosql.index.IndexManager
 
getIndex() - Method in class io.prestosql.sql.planner.plan.IndexJoinNode.EquiJoinClause
 
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(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
 
getInfo(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
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.split.EmptySplit
 
getInfo() - Method in class io.prestosql.split.RemoteSplit
 
getInfo() - Method in class io.prestosql.testing.TestingSplit
 
getInfoMaxAge() - Method in class io.prestosql.execution.TaskManagerConfig
 
getInformationSchemaId() - Method in class io.prestosql.metadata.Catalog
 
getInformationSchemaTable(Session, String, SchemaTableName, Set<QualifiedTablePrefix>) - Method in class io.prestosql.connector.informationSchema.InformationSchemaPageSourceProvider
 
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
 
getInitializationRequiredWorkers() - Method in class io.prestosql.execution.QueryManagerConfig
 
getInitializationTimeout() - 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.planner.plan.ApplyNode
 
getInput() - Method in class io.prestosql.sql.planner.plan.LateralJoinNode
 
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(Page) - 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() - Method in class io.prestosql.sql.planner.InputReferenceExtractor
 
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
 
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.TaskContext
 
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
 
getInsertLayout(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
 
getInsertLayout(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getInsertTableHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getInsertTableHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
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.operator.scalar.ScalarFunctionImplementation
 
getInstanceFactory() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ScalarImplementationChoice
 
getInsufficientResourcesFailures() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
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 interface io.prestosql.operator.aggregation.Accumulator
 
getIntermediateType() - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
getIntermediateType() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
getInternalAddress() - Method in class io.prestosql.server.NodeStatus
 
getInternalFailures() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
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
 
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
 
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, Page, long) - Method in class io.prestosql.operator.index.IndexLookupSource
 
getJoinPosition(int, Page, Page) - Method in class io.prestosql.operator.index.IndexLookupSource
 
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.JoinHash
 
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) - Method in interface io.prestosql.operator.LookupSource
 
getJoinPosition(int, Page, Page, long) - Method in class io.prestosql.operator.OuterLookupSource
 
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.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
 
getJoinUsing(Join) - Method in class io.prestosql.sql.analyzer.Analysis
 
getJsonObjectValue(Type, ConnectorSession, Block, int) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
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
 
getKdbTree() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getKerberosConfig() - Method in class io.prestosql.server.security.KerberosConfig
 
getKeyChannels() - Method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
getKeyFile() - Method in class io.prestosql.server.security.JsonWebTokenConfig
 
getKeyRecordSet() - Method in class io.prestosql.operator.index.IndexSplit
 
getKeys() - Method in class io.prestosql.operator.aggregation.KeyValuePairs
 
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.Signature
 
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
 
getLambdaInterface() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ArgumentProperty
 
getLambdaInterfaces() - Method in class io.prestosql.operator.aggregation.AggregationMetadata
 
getLambdaInterfaces() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
getLanguage() - Method in class io.prestosql.server.HttpRequestSessionContext
 
getLanguage() - Method in interface io.prestosql.server.SessionContext
 
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.execution.DataDefinitionExecution
 
getLastHeartbeat() - Method in class io.prestosql.execution.FailedQueryExecution
 
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(Session, TableHandle, Constraint<ColumnHandle>, Optional<Set<ColumnHandle>>) - Method in interface io.prestosql.metadata.Metadata
Deprecated.
getLayout(Session, TableHandle, Constraint<ColumnHandle>, Optional<Set<ColumnHandle>>) - Method in class io.prestosql.metadata.MetadataManager
 
getLayout() - Method in class io.prestosql.metadata.NewTableLayout
 
getLayout() - Method in class io.prestosql.metadata.TableHandle
 
getLayout() - Method in class io.prestosql.operator.index.IndexLookupSourceFactory
 
getLayout() - Method in interface io.prestosql.operator.LookupSourceFactory
 
getLayout() - Method in class io.prestosql.operator.PartitionedLookupSourceFactory
 
getLayout() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateName
 
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
 
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
 
getLimit() - Method in class io.prestosql.sql.planner.plan.DistinctLimitNode
 
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
 
getLocation() - Method in class io.prestosql.execution.StageStateMachine
 
getLocation() - Method in class io.prestosql.split.RemoteSplit
 
getLocationSegmentNames() - Method in class io.prestosql.execution.scheduler.FlatNetworkTopology
 
getLocationSegmentNames() - Method in class io.prestosql.execution.scheduler.LegacyNetworkTopology
 
getLocationSegmentNames() - Method in interface io.prestosql.execution.scheduler.NetworkTopology
Strings describing the meaning of each segment of a NetworkLocation returned from locate().
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, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
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.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.BoundVariables.Builder
 
getLongVariable(String) - Method in class io.prestosql.metadata.BoundVariables
 
getLongVariableConstraints() - Method in class io.prestosql.metadata.Signature
 
getLongVariables() - Method in class io.prestosql.metadata.BoundVariables.Builder
 
getLongVariables() - Method in class io.prestosql.metadata.BoundVariables
 
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
 
getMagicLiteralFunctionSignature(Type) - Static method in class io.prestosql.metadata.FunctionRegistry
 
getMajor() - Method in class io.prestosql.server.JavaVersion
 
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.planner.plan.StatisticAggregations.Parts
 
getMarker() - Method in enum io.prestosql.execution.buffer.PageCompression
 
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
 
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
 
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).
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
 
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
 
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
 
getMemoryCostWeight() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getMemoryInBytes() - Method in class io.prestosql.operator.index.IndexSnapshotBuilder
 
getMemoryInfo(MemoryPoolAssignmentsRequest) - Method in class io.prestosql.memory.MemoryResource
 
getMemoryInfo(String) - Method in class io.prestosql.memory.MemoryResource
 
getMemoryInfo() - Method in class io.prestosql.server.NodeStatus
 
getMemoryPool() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getMemoryPool() - Method in class io.prestosql.execution.FailedQueryExecution
 
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
 
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(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
 
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.testing.LocalQueryRunner
 
getMetadata() - Method in interface io.prestosql.testing.QueryRunner
 
getMetadataFor(ConnectorId) - Method in class io.prestosql.metadata.CatalogMetadata
 
getMethod() - Method in class io.prestosql.server.ThreadResource.StackLine
 
getMethodHandle() - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
getMethodHandle() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation
 
getMethodHandle() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ScalarImplementationChoice
 
getMethodHandle() - Method in class io.prestosql.sql.gen.VarArgsToArrayAdapterGenerator.MethodHandleAndConstructor
 
getMethodHandles(RowType, FunctionRegistry, OperatorType) - Method in class io.prestosql.operator.scalar.RowComparisonOperator
 
getMillis() - Method in class io.prestosql.type.SqlIntervalDayTime
 
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
 
getMinor() - Method in class io.prestosql.server.JavaVersion
 
getMinQueryExpireAge() - Method in class io.prestosql.execution.QueryManagerConfig
 
getMinScheduleSplitBatchSize() - Method in class io.prestosql.execution.QueryManagerConfig
 
getMissRate() - Method in class io.prestosql.sql.gen.CacheStatsMBean
 
getMonths() - Method in class io.prestosql.type.SqlIntervalYearMonth
 
getMultimapAggGroupImplementation() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
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.CommitTask
 
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.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.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.SetSessionTask
 
getName() - Method in class io.prestosql.execution.StartTransactionTask
 
getName() - Method in class io.prestosql.execution.UseTask
 
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.metadata.ViewDefinition.ViewColumn
 
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.security.AllowAllSystemAccessControl.Factory
 
getName() - Method in class io.prestosql.security.FileBasedSystemAccessControl.Factory
 
getName() - Method in class io.prestosql.security.ReadOnlySystemAccessControl.Factory
 
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
 
getNetworkCost() - Method in class io.prestosql.cost.LocalCostEstimate
 
getNetworkCost() - Method in class io.prestosql.cost.PlanCostEstimate
Returns network component of the cost.
getNetworkCostWeight() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
getNetworkTopology() - Method in class io.prestosql.execution.scheduler.NodeSchedulerConfig
 
getNewTableHandle() - Method in class io.prestosql.metadata.TableLayoutResult
Deprecated.
 
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, int, Page) - Method in class io.prestosql.operator.index.IndexLookupSource
 
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.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.split.EmptySplitPageSource
 
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 exception io.prestosql.sql.analyzer.SemanticException
 
getNode(int) - Method in class io.prestosql.sql.planner.iterative.Memo
 
getNode(Split) - Method in class io.prestosql.sql.planner.NodePartitionMap
 
getNode(int) - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
getNode() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatedNode
 
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.PrestoNode
 
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(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
 
getNodes() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
getNodesByHost() - Method in class io.prestosql.execution.scheduler.NodeMap
 
getNodesByHostAndPort() - Method in class io.prestosql.execution.scheduler.NodeMap
 
getNodeState() - Method in class io.prestosql.metadata.RemoteNodeState
 
getNodeStats() - Method in class io.prestosql.server.NodeResource
 
getNodeVersion() - Method in class io.prestosql.metadata.PrestoNode
 
getNodeVersion() - Method in class io.prestosql.server.NodeStatus
 
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
 
getNullConvention() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ArgumentProperty
 
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, Class<T>) - Method in class io.prestosql.operator.GroupByIdBlock
 
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(Block, int) - Method in class io.prestosql.type.FunctionType
 
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.UnknownType
 
getOffset() - Method in class io.prestosql.operator.project.SelectedPositions
 
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
 
getOperatorContext() - Method in class io.prestosql.operator.AggregationOperator
 
getOperatorContext() - Method in class io.prestosql.operator.AssignUniqueIdOperator
 
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.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.FilterAndProjectOperator
 
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.HashSemiJoinOperator
 
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.LookupJoinOperator
 
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.MetadataDeleteOperator
 
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.ScanFilterAndProjectOperator
 
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.StreamingAggregationOperator
 
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.TopNOperator
 
getOperatorContext() - Method in class io.prestosql.operator.TopNRowNumberOperator
 
getOperatorContext() - Method in class io.prestosql.operator.UnnestOperator
 
getOperatorContext() - Method in class io.prestosql.operator.ValuesOperator
 
getOperatorContext() - Method in class io.prestosql.operator.WindowOperator
 
getOperatorContext() - Method in class io.prestosql.testing.NullOutputOperator
 
getOperatorContext() - Method in class io.prestosql.testing.PageConsumerOperator
 
getOperatorContexts() - Method in class io.prestosql.operator.DriverContext
 
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
 
getOperatorInputPositionsAverages() - Method in class io.prestosql.sql.planner.planPrinter.PlanNodeStats
 
getOperatorInputPositionsStdDevs() - Method in class io.prestosql.sql.planner.planPrinter.PlanNodeStats
 
getOperatorMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
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 exception io.prestosql.metadata.OperatorNotFoundException
 
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
 
getOperatorTypes() - Method in class io.prestosql.sql.planner.planPrinter.PlanNodeStats
 
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
 
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(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.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
 
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
 
getOriginalSql() - Method in class io.prestosql.metadata.ViewDefinition
 
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.LateralJoinNode
 
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.AssignUniqueIdOperator
 
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.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.FilterAndProjectOperator
 
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.HashSemiJoinOperator
 
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.LookupJoinOperator
 
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.MetadataDeleteOperator
 
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.project.MergingPageOutput
 
getOutput() - Method in class io.prestosql.operator.RowNumberOperator
 
getOutput() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
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.StreamingAggregationOperator
 
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.TopNOperator
 
getOutput() - Method in class io.prestosql.operator.TopNRowNumberOperator
 
getOutput() - Method in class io.prestosql.operator.UnnestOperator
 
getOutput() - Method in class io.prestosql.operator.ValuesOperator
 
getOutput() - Method in class io.prestosql.operator.WindowOperator
 
getOutput() - Method in class io.prestosql.sql.planner.plan.MetadataDeleteNode
 
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
 
getOutputExpressions(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
 
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.PlanNodeStatsEstimate
Returns estimated number of rows.
getOutputs() - Method in class io.prestosql.sql.planner.plan.Assignments
 
getOutputs() - Method in class io.prestosql.sql.planner.planPrinter.NodeRepresentation
 
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.DeleteNode
 
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.LateralJoinNode
 
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.MetadataDeleteNode
 
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.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(String) - Method in class io.prestosql.metadata.HandleResolver
 
getOutputTableHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
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
 
getOwner() - Method in class io.prestosql.metadata.ViewDefinition
 
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
 
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
 
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.GlobalSystemConnector
 
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
 
getParameterCount() - Method in enum io.prestosql.operator.scalar.ScalarFunctionImplementation.NullConvention
 
getParameterizedType(String, List<TypeSignatureParameter>) - Method in class io.prestosql.type.TypeRegistry
 
getParameters() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getParameters(Statement) - Static method in class io.prestosql.execution.ParameterExtractor
 
getParameters() - Method in class io.prestosql.execution.QueryPreparer.PreparedQuery
 
getParameters() - Method in class io.prestosql.sql.analyzer.Analysis
 
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 class io.prestosql.type.TypeRegistry
 
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(Page, int) - Method in class io.prestosql.operator.BucketPartitionFunction
 
getPartition(Page, int) - Method in class io.prestosql.operator.exchange.LocalPartitionGenerator
 
getPartition(long) - Method in class io.prestosql.operator.exchange.LocalPartitionGenerator
 
getPartition(int, int, Page) - Method in interface io.prestosql.operator.HashGenerator
 
getPartition() - Method in class io.prestosql.operator.PagesRTreeIndex.GeometryWithPosition
 
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(Node) - 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[]) - Method in class io.prestosql.sql.planner.SystemPartitioningHandle
 
getPartitionGenerator() - Method in class io.prestosql.operator.LookupJoinOperator
 
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(String) - Method in class io.prestosql.metadata.HandleResolver
 
getPartitioningHandleClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
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
 
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(ResourceGroupId) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
getPathToRoot(ResourceGroupId) - Method in class io.prestosql.execution.resourcegroups.NoOpResourceGroupManager
 
getPathToRoot(ResourceGroupId) - Method in interface io.prestosql.execution.resourcegroups.ResourceGroupManager
 
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.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.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.EvaluateZeroLimit
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.EvaluateZeroSample
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.EvaluateZeroTopN
 
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.ImplementFilteredAggregations
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.InlineProjections
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.MergeFilters
 
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.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.PruneCountAggregationOverScalar
 
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.PruneOutputColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PruneSemiJoinFilteringSourceColumns
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushAggregationThroughOuterJoin
 
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.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.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.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.PushTableWriteThroughUnion
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.PushTopNThroughUnion
 
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.RemoveRedundantIdentityProjections
 
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.RemoveUnreferencedScalarLateralNodes
 
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.TransformCorrelatedInPredicateToJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedLateralJoinToJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedScalarAggregationToJoin
 
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.TransformExistsApplyToLateralNode
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedInPredicateSubqueryToSemiJoin
 
getPattern() - Method in class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedLateralToJoin
 
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
 
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.DigestAndPercentileState
 
getPercentile() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.GroupedDigestAndPercentileState
 
getPercentile() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.SingleDigestAndPercentileState
 
getPercentiles() - Method in interface io.prestosql.operator.aggregation.state.DigestAndPercentileArrayState
 
getPercentiles() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.GroupedDigestAndPercentileArrayState
 
getPercentiles() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.SingleDigestAndPercentileArrayState
 
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.TaskStats
 
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.TaskStats
 
getPhysicalInputReadTime() - Method in class io.prestosql.operator.DriverStats
 
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.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
 
getPlan() - Method in class io.prestosql.execution.StageInfo
 
getPlan(Session, Statement, ExplainType.Type, List<Expression>, WarningCollector) - Method in class io.prestosql.sql.analyzer.QueryExplainer
 
getPlanNode() - Method in class io.prestosql.sql.planner.iterative.rule.PlanNodeWithCost
 
getPlanNodeCpuTime() - Method in class io.prestosql.sql.planner.planPrinter.PlanNodeStats
 
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.OperatorStats
 
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
 
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
 
getPphysicalWrittenDataSize() - Method in class io.prestosql.operator.DriverContext
 
getPrecision() - Method in class io.prestosql.testing.MaterializedRow
 
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.InformationSchemaSplit
 
getPrefixes() - Method in class io.prestosql.connector.informationSchema.InformationSchemaTableLayoutHandle
 
getPreGroupedSymbols() - Method in class io.prestosql.sql.planner.plan.AggregationNode
 
getPreloadedWarnings() - Method in class io.prestosql.testing.TestingWarningCollectorConfig
 
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
 
getPrePartitionedInputs() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getPreSortedOrderPrefix() - Method in class io.prestosql.sql.planner.plan.WindowNode
 
getPrestoVersion() - Method in class io.prestosql.server.ServerConfig
 
getPrincipal() - Method in class io.prestosql.SessionRepresentation
 
getPrincipalHostname() - Method in class io.prestosql.server.security.KerberosConfig
 
getPrincipalUserMatchRules() - Method in class io.prestosql.security.FileBasedSystemAccessControlRules
 
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
 
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 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(QueryId) - Method in class io.prestosql.execution.QueryTracker
 
getQuery() - Method in class io.prestosql.server.BasicQueryInfo
 
getQuery() - Method in class io.prestosql.server.QueryStateInfo
 
getQueryContext() - Method in class io.prestosql.execution.SqlTask
 
getQueryContext(QueryId) - Method in class io.prestosql.execution.SqlTaskManager
 
getQueryContext() - Method in class io.prestosql.operator.TaskContext
 
getQueryExecutionPolicy() - Method in class io.prestosql.execution.QueryManagerConfig
 
getQueryId() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getQueryId() - Method in class io.prestosql.execution.FailedQueryExecution
 
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.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 class io.prestosql.execution.FailedQueryExecution
 
getQueryInfo() - Method in interface io.prestosql.execution.QueryExecution
 
getQueryInfo(QueryId) - Method in interface io.prestosql.execution.QueryManager
 
getQueryInfo(QueryId) - Method in interface io.prestosql.execution.QueryPerformanceFetcher
 
getQueryInfo() - Method in class io.prestosql.execution.SqlQueryExecution
 
getQueryInfo(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
getQueryInfo(QueryId) - Method in class io.prestosql.server.QueryResource
 
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
 
getQueryMaxRunTime() - Method in class io.prestosql.execution.QueryManagerConfig
 
getQueryMaxRunTime(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
 
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 class io.prestosql.execution.FailedQueryExecution
 
getQueryPlan() - Method in interface io.prestosql.execution.QueryExecution
 
getQueryPlan() - Method in class io.prestosql.execution.SqlQueryExecution
 
getQueryPlan(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
getQueryPlan(QueryId) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
getQueryPlan() - Method in class io.prestosql.testing.QueryRunner.MaterializedResultWithPlan
 
getQueryPriority(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getQueryResults(QueryId, long, Duration, DataSize, String, UriInfo, AsyncResponse) - Method in class io.prestosql.server.protocol.StatementResource
 
getQueryState(QueryId) - Method in interface io.prestosql.execution.QueryManager
 
getQueryState() - Method in class io.prestosql.execution.QueryStateMachine
 
getQueryState(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
getQueryState() - Method in class io.prestosql.server.QueryStateInfo
 
getQueryStateInfo(String) - Method in class io.prestosql.server.QueryStateInfoResource
 
getQueryStateInfos(String) - Method in class io.prestosql.server.QueryStateInfoResource
 
getQueryStateInfos(String) - Method in class io.prestosql.server.ResourceGroupStateInfoResource
 
getQueryStats() - Method in class io.prestosql.execution.QueryInfo
 
getQueryStats() - 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.execution.resourcegroups.InternalResourceGroup
 
getQueuedQueries() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
getQueuedQueries() - Method in class io.prestosql.server.ClusterStatsResource.ClusterStats
 
getQueuedSplitCountForStage(Node) - Method in class io.prestosql.execution.scheduler.NodeAssignmentStats
 
getQueuedTime() - Method in class io.prestosql.execution.QueryStats
 
getQueuedTime() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
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
 
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(Page, int) - Method in class io.prestosql.operator.exchange.LocalPartitionGenerator
 
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
 
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
 
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.EmptySplitPageSource
 
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
 
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
 
getRegistry() - Method in class io.prestosql.sql.gen.BytecodeGeneratorContext
 
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
 
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
 
getReplicateSymbols() - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
getRequestCount() - Method in class io.prestosql.sql.gen.CacheStatsMBean
 
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.JsonWebTokenConfig
 
getRequiredIssuer() - Method in class io.prestosql.server.security.JsonWebTokenConfig
 
getRequiredTransactionId() - Method in class io.prestosql.Session
 
getRequiredWorkers() - Method in class io.prestosql.execution.QueryManagerConfig
 
getRequiredWorkersMaxWait() - Method in class io.prestosql.execution.QueryManagerConfig
 
getReservedBytes() - Method in class io.prestosql.memory.MemoryPool
 
getReservedDistributedBytes() - Method in class io.prestosql.memory.ClusterMemoryPool
 
getReservedMemory() - Method in class io.prestosql.server.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
 
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
 
getResourceGroupInfo(ResourceGroupId) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
getResourceGroupInfo(ResourceGroupId) - Method in class io.prestosql.execution.resourcegroups.NoOpResourceGroupManager
 
getResourceGroupInfo(ResourceGroupId) - Method in interface io.prestosql.execution.resourcegroups.ResourceGroupManager
 
getResourceGroupManager(ResourceGroupManager) - Static method in class io.prestosql.server.CoordinatorModule
 
getResourceGroupManager() - Method in class io.prestosql.server.testing.TestingPrestoServer
 
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.
getResultEqual(int) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
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
 
getRetainedSizeInBytes() - Method in class io.prestosql.operator.project.MergingPageOutput
 
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
 
getRightPartitionSymbol() - Method in class io.prestosql.sql.planner.plan.SpatialJoinNode
 
getRoles() - Method in class io.prestosql.SessionRepresentation
 
getRollups() - Method in class io.prestosql.sql.analyzer.Analysis.GroupingSetAnalysis
 
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
 
getRootScope() - Method in class io.prestosql.sql.analyzer.Analysis
 
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
 
getRowId() - Method in class io.prestosql.sql.planner.plan.DeleteNode
 
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
 
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.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.execution.resourcegroups.InternalResourceGroup
 
getRunningQueries() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
getRunningQueries() - Method in class io.prestosql.server.ClusterStatsResource.ClusterStats
 
getRunningQueries() - Method in class io.prestosql.server.ResourceGroupInfo
 
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(SampledRelation) - Method in class io.prestosql.sql.analyzer.Analysis
 
getSampleRatio() - Method in class io.prestosql.sql.planner.plan.SampleNode
 
getSampleType() - Method in class io.prestosql.sql.planner.plan.SampleNode
 
getScalarExtractor() - Method in class io.prestosql.operator.scalar.JsonPath
 
getScalarFunctionImplementation(Signature) - Method in class io.prestosql.metadata.FunctionRegistry
 
getScalarSubqueries(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getScalarSubqueries() - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
getScalarSubqueries() - Method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
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.execution.Output
 
getSchema() - Method in class io.prestosql.metadata.ViewDefinition
 
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.SqlPathElement
 
getSchemaName() - Method in class io.prestosql.connector.informationSchema.InformationSchemaTableHandle
 
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
 
getSchemaPropertyManager() - Method in interface io.prestosql.metadata.Metadata
 
getSchemaPropertyManager() - Method in class io.prestosql.metadata.MetadataManager
 
getSchemaTableName() - Method in class io.prestosql.connector.informationSchema.InformationSchemaTableHandle
 
getSchemaTableName() - Method in class io.prestosql.connector.system.SystemTableHandle
 
getSchemaTableName() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateHandle
 
getSchemaTableName() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.DeleteHandle
 
getSchemaTableName() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertHandle
 
getScope(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
getScope() - Method in class io.prestosql.sql.analyzer.ResolvedField
 
getScope() - Method in class io.prestosql.sql.gen.BytecodeGeneratorContext
 
getScope() - Method in class io.prestosql.sql.planner.plan.ExchangeNode
 
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
 
getSearchExpressions() - Method in class io.prestosql.sql.planner.SortExpressionContext
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockBooleanState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockDoubleState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockLongState
 
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.SliceBooleanState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceDoubleState
 
getSecond() - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceLongState
 
getSecondBlock() - Method in interface io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueState
 
getSecondPosition() - Method in interface io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueState
 
getSegments() - Method in class io.prestosql.execution.scheduler.NetworkLocation
 
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
 
getSelf() - Method in class io.prestosql.execution.QueryInfo
 
getSelf() - Method in class io.prestosql.execution.StageInfo
 
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.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.DigestAndPercentileArrayStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateSerializer
 
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.QuantileDigestStateSerializer
 
getSerializedType() - Method in class io.prestosql.operator.aggregation.state.TriStateBooleanStateSerializer
 
getSerializedType(Type, Type) - Static method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
getSerializedType() - Method in class io.prestosql.type.setdigest.SetDigestStateSerializer
 
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
 
getSession() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getSession() - Method in class io.prestosql.execution.FailedQueryExecution
 
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.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
 
getSessionProperties() - Method in class io.prestosql.SystemSessionProperties
 
getSessionPropertyManager() - Method in interface io.prestosql.metadata.Metadata
 
getSessionPropertyManager() - Method in class io.prestosql.metadata.MetadataManager
 
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
 
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.SqlAggregationFunction
 
getSignature() - Method in interface io.prestosql.metadata.SqlFunction
 
getSignature() - Method in class io.prestosql.metadata.SqlScalarFunction
 
getSignature() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getSignature() - Method in class io.prestosql.operator.annotations.ScalarImplementationDependency
 
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.window.AbstractWindowFunctionSupplier
 
getSignature() - Method in class io.prestosql.operator.window.SqlWindowFunction
 
getSignature() - Method in interface io.prestosql.operator.window.WindowFunctionSupplier
 
getSignature() - Method in class io.prestosql.sql.planner.plan.AggregationNode.Aggregation
 
getSignature() - Method in class io.prestosql.sql.planner.plan.WindowNode.Function
 
getSignature() - Method in class io.prestosql.sql.relational.CallExpression
 
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.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.DigestAndPercentileArrayStateFactory
 
getSingleStateClass() - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory
 
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.QuantileDigestStateFactory
 
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
 
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, int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
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(Block, int) - Method in class io.prestosql.type.FunctionType
 
getSlice(Block, int) - Method in class io.prestosql.type.JsonType
 
getSlice(Block, int) - Method in class io.prestosql.type.setdigest.SetDigestType
 
getSliceLength(int) - Method in class io.prestosql.operator.GroupByIdBlock
 
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.execution.resourcegroups.InternalResourceGroup
 
getSoftMemoryLimit() - Method in class io.prestosql.server.ResourceGroupInfo
 
getSortedPages() - Method in class io.prestosql.operator.PagesIndex
 
getSortExpression() - Method in class io.prestosql.sql.planner.SortExpressionContext
 
getSortExpressionContext() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
getSortItemsFromOrderBy(Optional<OrderBy>) - Static method in class io.prestosql.sql.NodeUtils
 
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.OutputNode
 
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
 
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
 
getSourceJoinSymbol() - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
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.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.LateralJoinNode
 
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.MetadataDeleteNode
 
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.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
 
getSpatialPartitioningTableName(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getSpecializedImplementations() - Method in class io.prestosql.operator.ParametricImplementationsGroup
 
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
 
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(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.
getSpilledPages() - Method in interface io.prestosql.spiller.SingleStreamSpiller
Returns list of previously spilled Pages as a single stream.
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(String) - Method in class io.prestosql.metadata.HandleResolver
 
getSplitClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getSplitClass() - Method in class io.prestosql.split.EmptySplitHandleResolver
 
getSplitClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
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.GlobalSystemConnector
 
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(ConnectorTransactionHandle, ConnectorSession, ConnectorTableLayoutHandle, ConnectorSplitManager.SplitSchedulingStrategy) - Method in class io.prestosql.connector.informationSchema.InformationSchemaSplitManager
 
getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableLayoutHandle, ConnectorSplitManager.SplitSchedulingStrategy) - Method in class io.prestosql.connector.system.SystemSplitManager
 
getSplits() - Method in class io.prestosql.execution.TaskSource
 
getSplits(Session, TableHandle, ConnectorSplitManager.SplitSchedulingStrategy) - Method in class io.prestosql.split.SplitManager
 
getSplits() - Method in class io.prestosql.split.SplitSource.SplitBatch
 
getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableLayoutHandle, ConnectorSplitManager.SplitSchedulingStrategy) - 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
 
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
 
getStartChannel() - Method in class io.prestosql.operator.window.FrameInfo
 
getStartedQueries() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
getStartedTransactionId() - Method in class io.prestosql.execution.QueryInfo
 
getStartTime() - Method in class io.prestosql.FullConnectorSession
 
getStartTime() - Method in class io.prestosql.operator.DriverStats
 
getStartTime() - Method in class io.prestosql.Session
 
getStartTime() - Method in class io.prestosql.SessionRepresentation
 
getStartTime() - Method in class io.prestosql.testing.TestingConnectorSession
 
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.execution.buffer.OutputBufferInfo
 
getState() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getState() - Method in class io.prestosql.execution.FailedQueryExecution
 
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(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
 
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
 
getStateChange(QueryState) - Method in class io.prestosql.execution.DataDefinitionExecution
 
getStateChange(QueryState) - Method in class io.prestosql.execution.FailedQueryExecution
 
getStateChange(QueryState) - Method in interface io.prestosql.execution.QueryExecution
 
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(QueryState) - Method in class io.prestosql.execution.QueryStateMachine
 
getStateChange(QueryState) - Method in class io.prestosql.execution.SqlQueryExecution
 
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).
getStateChange(TaskState) - Method in class io.prestosql.execution.TaskStateMachine
 
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
 
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
 
getStateSerializerFactory() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
getStateSerializerFactoryDependencies() - Method in class io.prestosql.operator.aggregation.AggregationImplementation
 
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(PlanNode) - Method in class io.prestosql.cost.CachingStatsProvider
 
getStats() - Method in class io.prestosql.cost.StatsAndCosts
 
getStats(PlanNode) - Method in interface io.prestosql.cost.StatsProvider
 
getStats() - Method in interface io.prestosql.execution.QueryManager
 
getStats() - Method in class io.prestosql.execution.SqlQueryManager
 
getStats() - Method in class io.prestosql.execution.TaskInfo
 
getStats() - Method in class io.prestosql.failureDetector.HeartbeatFailureDetector
 
getStats(int) - Method in class io.prestosql.sql.planner.iterative.Memo
 
getStats() - Method in class io.prestosql.sql.planner.planPrinter.NodeRepresentation
 
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(String) - Method in class io.prestosql.server.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
 
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.SqlQueryManagerStats
 
getSubquery() - Method in class io.prestosql.sql.planner.plan.ApplyNode
 
getSubquery() - Method in class io.prestosql.sql.planner.plan.LateralJoinNode
 
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
 
getSupportedFieldTypes() - Static method in class io.prestosql.operator.aggregation.state.StateCompiler
 
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(Symbol) - Method in class io.prestosql.cost.PlanNodeStatsEstimate
 
getSymbolStatistics() - 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.operator.DriverContext
 
getSystemMemoryUsage() - Method in class io.prestosql.split.EmptySplitPageSource
 
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(ConnectorSession, SchemaTableName) - Method in class io.prestosql.connector.system.DelegatingSystemTablesProvider
 
getSystemTable(ConnectorSession, SchemaTableName) - Method in class io.prestosql.connector.system.MetadataBasedSystemTablesProvider
 
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.
getSystemTable(Session, QualifiedObjectName) - Method in interface io.prestosql.metadata.Metadata
 
getSystemTable(Session, QualifiedObjectName) - Method in class io.prestosql.metadata.MetadataManager
 
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.InformationSchemaTableLayoutHandle
 
getTable() - Method in class io.prestosql.connector.system.SystemTableLayoutHandle
 
getTable() - Method in class io.prestosql.execution.Input
 
getTable() - Method in class io.prestosql.execution.Output
 
getTable() - Method in class io.prestosql.metadata.TableMetadata
 
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(ConnectorSession, SchemaTableName) - Method in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
getTableHandle() - Method in class io.prestosql.connector.informationSchema.InformationSchemaSplit
 
getTableHandle() - Method in class io.prestosql.connector.system.SystemSplit
 
getTableHandle(ConnectorSession, SchemaTableName) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
getTableHandle() - Method in class io.prestosql.metadata.AnalyzeMetadata
 
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(Table) - Method in class io.prestosql.sql.analyzer.Analysis
 
getTableHandle() - Method in class io.prestosql.sql.planner.plan.IndexSourceNode
 
getTableHandle(ConnectorSession, SchemaTableName) - Method in class io.prestosql.testing.TestingMetadata
 
getTableHandleClass() - Method in class io.prestosql.connector.informationSchema.InformationSchemaHandleResolver
 
getTableHandleClass() - Method in class io.prestosql.connector.system.SystemHandleResolver
 
getTableHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getTableHandleClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getTableHandleClass() - Method in class io.prestosql.split.EmptySplitHandleResolver
 
getTableHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
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
 
getTableLayout(ConnectorSession, ConnectorTableLayoutHandle) - Method in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
getTableLayout(ConnectorSession, ConnectorTableLayoutHandle) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
getTableLayout(ConnectorSession, ConnectorTableLayoutHandle) - Method in class io.prestosql.testing.TestingMetadata
 
getTableLayoutHandleClass() - Method in class io.prestosql.connector.informationSchema.InformationSchemaHandleResolver
 
getTableLayoutHandleClass() - Method in class io.prestosql.connector.system.SystemHandleResolver
 
getTableLayoutHandleClass(String) - Method in class io.prestosql.metadata.HandleResolver
 
getTableLayoutHandleClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getTableLayoutHandleClass() - Method in class io.prestosql.split.EmptySplitHandleResolver
 
getTableLayoutHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
getTableLayouts(ConnectorSession, ConnectorTableHandle, Constraint<ColumnHandle>, Optional<Set<ColumnHandle>>) - Method in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
getTableLayouts(ConnectorSession, ConnectorTableHandle, Constraint<ColumnHandle>, Optional<Set<ColumnHandle>>) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
getTableLayouts(ConnectorSession, ConnectorTableHandle, Constraint<ColumnHandle>, Optional<Set<ColumnHandle>>) - Method in class io.prestosql.testing.TestingMetadata
 
getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
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(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
getTableMetadata() - Method in class io.prestosql.connector.system.TaskSystemTable
 
getTableMetadata() - Method in class io.prestosql.connector.system.TransactionsSystemTable
 
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() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateName
 
getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in class io.prestosql.testing.TestingMetadata
 
getTableName() - Method in class io.prestosql.connector.informationSchema.InformationSchemaTableHandle
 
getTableName() - Method in class io.prestosql.connector.system.SystemTableHandle
 
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(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
 
getTableProperties(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
getTableProperties() - Method in class io.prestosql.metadata.TableLayoutResult
Deprecated.
 
getTablePropertyManager() - Method in interface io.prestosql.metadata.Metadata
 
getTablePropertyManager() - Method in class io.prestosql.metadata.MetadataManager
 
getTables() - Method in class io.prestosql.sql.analyzer.Analysis
 
getTableStatistics(Session, TableHandle, Constraint<ColumnHandle>) - Method in interface io.prestosql.metadata.Metadata
Return statistics for specified table for given filtering contraint.
getTableStatistics(Session, TableHandle, Constraint<ColumnHandle>) - Method in class io.prestosql.metadata.MetadataManager
 
getTableStatistics() - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
getTarget() - Method in class io.prestosql.sql.analyzer.Analysis.Insert
 
getTarget() - Method in class io.prestosql.sql.planner.plan.DeleteNode
 
getTarget() - Method in class io.prestosql.sql.planner.plan.MetadataDeleteNode
 
getTarget() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
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.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(TaskState) - Method in class io.prestosql.execution.SqlTask
 
getTaskInfo(TaskId) - Method in class io.prestosql.execution.SqlTaskManager
 
getTaskInfo(TaskId, TaskState) - 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, TaskState) - Method in interface io.prestosql.execution.TaskManager
Gets future info for the task after the state changes from current state.
getTaskInfo() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
getTaskInfo() - Method in class io.prestosql.server.remotetask.TaskInfoFetcher
 
getTaskInfo(TaskId, TaskState, 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(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.
getTaskInstanceId() - Method in class io.prestosql.execution.TaskStatus
 
getTaskInstanceId() - Method in class io.prestosql.operator.HttpPageBufferClient.PagesResponse
 
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(TaskState) - Method in class io.prestosql.execution.SqlTask
 
getTaskStatus(TaskId) - Method in class io.prestosql.execution.SqlTaskManager
 
getTaskStatus(TaskId, TaskState) - Method in class io.prestosql.execution.SqlTaskManager
 
getTaskStatus() - Method in class io.prestosql.execution.TaskInfo
 
getTaskStatus(TaskId) - Method in interface io.prestosql.execution.TaskManager
Gets the status for the specified task.
getTaskStatus(TaskId, TaskState) - Method in interface io.prestosql.execution.TaskManager
Gets future status for the task after the state changes from current state.
getTaskStatus() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
getTaskStatus(TaskId, TaskState, Duration, UriInfo, AsyncResponse) - Method in class io.prestosql.server.TaskResource
 
getTaskWriterCount(Session) - Static method in class io.prestosql.SystemSessionProperties
 
getTaskYieldThreads() - Method in class io.prestosql.execution.TaskManagerConfig
 
getThreadInfo() - Method in class io.prestosql.server.ThreadResource
 
getThreads(String) - Method in class io.prestosql.server.WorkerResource
 
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
 
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
 
getTopologicalSplitCounters() - Method in class io.prestosql.execution.scheduler.NodeScheduler
 
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.execution.BasicStageStats
 
getTotalCpuTime() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getTotalCpuTime() - Method in class io.prestosql.execution.FailedQueryExecution
 
getTotalCpuTime() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
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.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
 
getTotalIndexJoinLookups() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
getTotalInputBytes() - Method in class io.prestosql.server.ClusterStatsResource.ClusterStats
 
getTotalInputRows() - Method in class io.prestosql.server.ClusterStatsResource.ClusterStats
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.BasicStageStats
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getTotalMemoryReservation() - Method in class io.prestosql.execution.FailedQueryExecution
 
getTotalMemoryReservation() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
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
 
getTotalPlanningTime() - Method in class io.prestosql.execution.QueryStats
 
getTotalRowsCount() - Method in class io.prestosql.operator.WindowInfo.DriverWindowInfo
 
getTotalRowsCount() - Method in class io.prestosql.operator.WindowInfo.IndexInfo
 
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(Node) - 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
 
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.metadata.Split
 
getTransactionHandle() - Method in class io.prestosql.split.BufferingSplitSource
 
getTransactionHandle() - Method in class io.prestosql.split.ConnectorAwareSplitSource
 
getTransactionHandle() - Method in class io.prestosql.split.SampledSplitSource
 
getTransactionHandle() - Method in interface io.prestosql.split.SplitSource
 
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(String) - Method in class io.prestosql.metadata.HandleResolver
 
getTransactionHandleClass() - Method in class io.prestosql.metadata.RemoteHandleResolver
 
getTransactionHandleClass() - Method in class io.prestosql.testing.TestingHandleResolver
 
getTransactionHandleFor(ConnectorId) - 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.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
 
getTupleDomain() - Method in class io.prestosql.sql.planner.DomainTranslator.ExtractionResult
 
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(TypeSignature) - Method in interface io.prestosql.metadata.Metadata
 
getType(TypeSignature) - Method in class io.prestosql.metadata.MetadataManager
 
getType(String) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.SpecializeContext
 
getType() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
getType() - Method in class io.prestosql.metadata.ViewDefinition.ViewColumn
 
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(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() - 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(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
getType(Expression) - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
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.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.LateralJoinNode
 
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.NodeRepresentation
 
getType() - Method in class io.prestosql.sql.planner.planPrinter.NodeRepresentation.TypedSymbol
 
getType(Session, TypeProvider, Expression) - Method in class io.prestosql.sql.planner.TypeAnalyzer
 
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.VariableReferenceExpression
 
getType() - Method in class io.prestosql.testing.TestingMetadata.TestingColumnHandle
 
getType(TypeSignature) - Method in class io.prestosql.type.TypeRegistry
 
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 interface io.prestosql.metadata.Metadata
 
getTypeManager() - Method in class io.prestosql.metadata.MetadataManager
 
getTypeManager() - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.SpecializeContext
 
getTypeManager() - Method in class io.prestosql.testing.LocalQueryRunner
 
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
 
getTypeParameters() - Method in class io.prestosql.type.FunctionType
 
getTypes() - Method in class io.prestosql.execution.StageInfo
 
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(Session, TypeProvider, Iterable<Expression>) - Method in class io.prestosql.sql.planner.TypeAnalyzer
 
getTypes(Session, TypeProvider, Expression) - Method in class io.prestosql.sql.planner.TypeAnalyzer
 
getTypes() - Method in class io.prestosql.testing.MaterializedResult
 
getTypes() - Method in class io.prestosql.type.TypeRegistry
 
getTypeSignature() - Method in class io.prestosql.sql.analyzer.TypeSignatureProvider
 
getTypeSignature(List<Type>) - Method in class io.prestosql.sql.analyzer.TypeSignatureProvider
 
getTypeSignature() - Method in class io.prestosql.sql.planner.planPrinter.IoPlanPrinter.ColumnConstraint
 
getTypeSignature() - Method in class io.prestosql.type.FunctionType
 
getTypeVariable(String) - Method in class io.prestosql.metadata.BoundVariables.Builder
 
getTypeVariable(String) - Method in class io.prestosql.metadata.BoundVariables
 
getTypeVariableConstraints() - Method in class io.prestosql.metadata.Signature
 
getTypeVariables() - Method in class io.prestosql.metadata.BoundVariables.Builder
 
getTypeVariables() - Method in class io.prestosql.metadata.BoundVariables
 
getTypeWithCoercions(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
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.
 
getUnnestSymbols() - Method in class io.prestosql.sql.planner.plan.UnnestNode
 
getUnprocessedCatalogProperties() - Method in class io.prestosql.Session
 
getUnprocessedCatalogProperties() - Method in class io.prestosql.SessionRepresentation
 
getUnresolvedTupleDomain() - Method in class io.prestosql.metadata.ResolvedIndex
 
getUpdate() - Method in class io.prestosql.server.JavaVersion
 
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.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
 
getUri() - Method in class io.prestosql.failureDetector.HeartbeatFailureDetector.Stats
 
getUri() - Method in class io.prestosql.operator.PageBufferClientStatus
 
getUser() - Method in class io.prestosql.server.QueryStateInfo
 
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.SqlQueryManagerStats
 
getUserMemoryReservation() - Method in class io.prestosql.execution.BasicStageStats
 
getUserMemoryReservation() - Method in class io.prestosql.execution.DataDefinitionExecution
 
getUserMemoryReservation() - Method in class io.prestosql.execution.FailedQueryExecution
 
getUserMemoryReservation() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
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
 
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
 
getValue() - Method in class io.prestosql.metadata.SessionPropertyManager.SessionPropertyValue
 
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() - Method in class io.prestosql.sql.planner.planPrinter.IoPlanPrinter.FormattedMarker
 
getValue(Symbol) - Method in interface io.prestosql.sql.planner.SymbolResolver
 
getValue() - Method in class io.prestosql.sql.relational.ConstantExpression
 
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
 
getVersion() - Method in class io.prestosql.execution.buffer.OutputBuffers
 
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.PrestoNode
 
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
 
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, SchemaTablePrefix) - 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.
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.SqlQueryManagerStats
 
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(Signature) - Method in class io.prestosql.metadata.FunctionRegistry
 
getWindowFunctions(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
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
 
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
 
getWorkerMemoryInfo() - Method in class io.prestosql.server.ClusterStatsResource
 
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
 
getYieldExecutor() - Method in class io.prestosql.operator.DriverContext
 
getYieldSignal() - Method in class io.prestosql.operator.DriverContext
 
global(ActualProperties.Global) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
global(ActualProperties) - 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(String, 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(String, TransactionId) - Constructor for class io.prestosql.connector.system.GlobalSystemTransactionHandle
 
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
 
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
 
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
 
greater(RowType, List<MethodHandle>, Block, Block) - Static method in class io.prestosql.operator.scalar.RowGreaterThanOperator
 
greaterOrEqual(RowType, List<MethodHandle>, Block, Block) - Static method in class io.prestosql.operator.scalar.RowGreaterThanOrEqualOperator
 
greaterThan(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayGreaterThanOperator
 
greaterThan(int, int) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
greaterThan(long, long) - Static method in class io.prestosql.type.BigintOperators
 
greaterThan(boolean, boolean) - Static method in class io.prestosql.type.BooleanOperators
 
greaterThan(Slice, Slice) - Static method in class io.prestosql.type.CharOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.DateOperators
 
greaterThan(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
greaterThan(Slice, Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.RealOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.TimeOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.TimestampOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
greaterThan(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
greaterThan(boolean, boolean) - Static method in class io.prestosql.type.UnknownOperators
 
greaterThan(Slice, Slice) - Static method in class io.prestosql.type.VarbinaryOperators
 
greaterThan(Slice, Slice) - Static method in class io.prestosql.type.VarcharOperators
 
greaterThanLong(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayGreaterThanOperator
 
greaterThanOrEqual(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayGreaterThanOrEqualOperator
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.BigintOperators
 
greaterThanOrEqual(boolean, boolean) - Static method in class io.prestosql.type.BooleanOperators
 
greaterThanOrEqual(Slice, Slice) - Static method in class io.prestosql.type.CharOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.DateOperators
 
greaterThanOrEqual(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
greaterThanOrEqual(Slice, Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.RealOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.TimeOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.TimestampOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
greaterThanOrEqual(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
greaterThanOrEqual(boolean, boolean) - Static method in class io.prestosql.type.UnknownOperators
 
greaterThanOrEqual(Slice, Slice) - Static method in class io.prestosql.type.VarbinaryOperators
 
greaterThanOrEqual(Slice, Slice) - Static method in class io.prestosql.type.VarcharOperators
 
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
 
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(List<? extends Type>, JoinCompiler) - Constructor for class io.prestosql.GroupByHashPageIndexer
 
GroupByHashPageIndexer(GroupByHash) - Constructor for class io.prestosql.GroupByHashPageIndexer
 
GroupByHashPageIndexerFactory - Class in io.prestosql
 
GroupByHashPageIndexerFactory(JoinCompiler) - 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 - Static variable in class io.prestosql.SystemSessionProperties
 
GroupedAccumulator - Interface in io.prestosql.operator.aggregation
 
GroupedDigestAndPercentileArrayState() - Constructor for class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.GroupedDigestAndPercentileArrayState
 
GroupedDigestAndPercentileState() - Constructor for class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.GroupedDigestAndPercentileState
 
groupedExecution(List<PlanNodeId>) - Static method in class io.prestosql.operator.StageExecutionDescriptor
 
GroupedHistogramState - Class in io.prestosql.operator.aggregation.histogram
state object that uses a single histogram for all groups.
GroupedHistogramState(Type, int) - Constructor for class io.prestosql.operator.aggregation.histogram.GroupedHistogramState
 
GroupedHyperLogLogState() - Constructor for class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.GroupedHyperLogLogState
 
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
 
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
 
GroupedTopNBuilder - Class in io.prestosql.operator
This class finds the top N rows defined by for each group specified by .
GroupedTopNBuilder(List<Type>, PageWithPositionComparator, int, boolean, GroupByHash) - Constructor for class io.prestosql.operator.GroupedTopNBuilder
 
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(Type, int) - Constructor for class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
GroupedTypedHistogram(long, Block, Type, int) - Constructor for class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
TODO: use RowBlock in the future
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<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
 
GroupReference - Class in io.prestosql.sql.planner.iterative
 
GroupReference(PlanNodeId, int, List<Symbol>) - Constructor for class io.prestosql.sql.planner.iterative.GroupReference
 

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
 
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
 
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
 
hasFreeReferencesToLambdaArgument(Node, Analysis) - Static method in class io.prestosql.sql.analyzer.FreeLambdaReferenceExtractor
 
hash(int, int, int) - Method in class io.prestosql.operator.GroupByIdBlock
 
hash(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayHashCodeOperator
 
hash(MethodHandle, MethodHandle, Type, Type, Block) - Static method in class io.prestosql.operator.scalar.MapHashCodeOperator
 
hash(Type, Block) - Static method in class io.prestosql.operator.scalar.RowHashCodeOperator
 
hash(Block, int) - Method in class io.prestosql.type.FunctionType
 
hash(Block, int) - Method in class io.prestosql.type.IpAddressType
 
hash(Block, int) - Method in class io.prestosql.type.JsonType
 
hash(Block, int) - Method in class io.prestosql.type.UnknownType
 
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, 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, List<AccumulatorFactory>, Optional<Integer>, Optional<Integer>, int, Optional<DataSize>, JoinCompiler, boolean) - Constructor for class io.prestosql.operator.HashAggregationOperator.HashAggregationOperatorFactory
 
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, boolean) - Constructor for class io.prestosql.operator.HashAggregationOperator.HashAggregationOperatorFactory
 
hashBoolean(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayHashCodeOperator
 
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.ConnectorId
 
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.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.Column
 
hashCode() - Method in class io.prestosql.execution.Input
 
hashCode() - Method in class io.prestosql.execution.Lifespan
 
hashCode() - Method in class io.prestosql.execution.Output
 
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.BoundVariables
 
hashCode() - Method in class io.prestosql.metadata.IndexHandle
 
hashCode() - Method in class io.prestosql.metadata.InsertTableHandle
 
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.PrestoNode
 
hashCode() - Method in class io.prestosql.metadata.QualifiedObjectName
 
hashCode() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
hashCode() - Method in class io.prestosql.metadata.Signature
 
hashCode() - Method in class io.prestosql.metadata.SpecializedFunctionKey
 
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.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(Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
hashCode() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ArgumentProperty
 
hashCode() - Method in class io.prestosql.operator.window.FrameInfo
 
hashCode() - Method in class io.prestosql.server.JavaVersion
 
hashCode() - Method in class io.prestosql.sql.analyzer.Analysis.AccessControlInfo
 
hashCode() - Method in class io.prestosql.sql.analyzer.FieldId
 
hashCode() - Method in class io.prestosql.sql.analyzer.RelationId
 
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.Assignments
 
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.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.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.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(long) - Static method in class io.prestosql.type.BigintOperators
 
hashCode(boolean) - Static method in class io.prestosql.type.BooleanOperators
 
hashCode(Slice) - Static method in class io.prestosql.type.CharOperators
 
hashCode(long) - Static method in class io.prestosql.type.ColorOperators
 
hashCode() - Method in class io.prestosql.type.ColorType
 
hashCode(long) - Static method in class io.prestosql.type.DateOperators
 
HashCode() - Constructor for class io.prestosql.type.DecimalOperators.HashCode
 
hashCode(long) - Static method in class io.prestosql.type.DecimalOperators.HashCode
 
hashCode(Slice) - Static method in class io.prestosql.type.DecimalOperators.HashCode
 
hashCode(double) - Static method in class io.prestosql.type.DoubleOperators
 
hashCode(long) - Static method in class io.prestosql.type.IntegerOperators
 
hashCode(long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
hashCode() - Method in class io.prestosql.type.IntervalDayTimeType
 
hashCode(long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
hashCode() - Method in class io.prestosql.type.IntervalYearMonthType
 
hashCode(Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
hashCode(long) - Static method in class io.prestosql.type.RealOperators
 
hashCode(long) - Static method in class io.prestosql.type.SmallintOperators
 
hashCode() - Method in class io.prestosql.type.SqlIntervalDayTime
 
hashCode() - Method in class io.prestosql.type.SqlIntervalYearMonth
 
hashCode(long) - Static method in class io.prestosql.type.TimeOperators
 
hashCode(long) - Static method in class io.prestosql.type.TimestampOperators
 
hashCode(long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
hashCode(long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
hashCode(long) - Static method in class io.prestosql.type.TinyintOperators
 
hashCode(boolean) - Static method in class io.prestosql.type.UnknownOperators
 
hashCode(Slice) - Static method in class io.prestosql.type.VarbinaryOperators
 
hashCode(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
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(Type, Slice) - Static method in class io.prestosql.type.setdigest.SetDigestFunctions
 
hashCounts(Slice) - Static method in class io.prestosql.type.setdigest.SetDigestFunctions
 
hashDouble(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayHashCodeOperator
 
HashGenerationOptimizer - Class in io.prestosql.sql.planner.optimizations
 
HashGenerationOptimizer() - Constructor for class io.prestosql.sql.planner.optimizations.HashGenerationOptimizer
 
HashGenerator - Interface in io.prestosql.operator
 
hashLong(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayHashCodeOperator
 
hashPosition(int, Page) - Method in interface io.prestosql.operator.HashGenerator
 
hashPosition(int, Page) - Method in class io.prestosql.operator.InterpretedHashGenerator
 
hashPosition(int, IntFunction<Block>) - Method in class io.prestosql.operator.InterpretedHashGenerator
 
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, Page) - Method in class io.prestosql.operator.PrecomputedHashGenerator
 
hashPosition(int, int) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
hashPosition(Type, Block, int) - Static method in class io.prestosql.type.TypeUtils
 
hashPosition(MethodHandle, Type, Block, int) - Static method in class io.prestosql.type.TypeUtils
 
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
 
HashSemiJoinOperator(OperatorContext, SetBuilderOperator.SetSupplier, int) - Constructor for class io.prestosql.operator.HashSemiJoinOperator
 
HashSemiJoinOperator.HashSemiJoinOperatorFactory - Class in io.prestosql.operator
 
HashSemiJoinOperatorFactory(int, PlanNodeId, SetBuilderOperator.SetSupplier, List<? extends Type>, int) - Constructor for class io.prestosql.operator.HashSemiJoinOperator.HashSemiJoinOperatorFactory
 
hashSlice(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayHashCodeOperator
 
HashTable(Type, BlockBuilder) - Constructor for class io.prestosql.util.JsonUtil.HashTable
 
HashUtil - Class in io.prestosql.operator.aggregation.histogram
 
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.ArrayOfRowsUnnester
 
hasNext() - Method in class io.prestosql.operator.ArrayUnnester
 
hasNext() - Method in class io.prestosql.operator.MapUnnester
 
hasNext() - Method in interface io.prestosql.operator.Unnester
 
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
 
hasSchemaName() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
hasSession() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ScalarImplementationChoice
 
hasSingleNodeExecutionPreference(FunctionRegistry) - 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 class io.prestosql.operator.LookupJoinOperator.SpillInfoSnapshot
 
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.
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(HistogramGroupImplementation) - Constructor for class io.prestosql.operator.aggregation.histogram.Histogram
 
HISTOGRAM_BUCKETS - Static variable in class io.prestosql.operator.JoinStatisticsCounter
 
HistogramGroupImplementation - Enum in io.prestosql.operator.aggregation.histogram
 
HistogramState - Interface in io.prestosql.operator.aggregation.histogram
 
HistogramStateFactory - Class in io.prestosql.operator.aggregation.histogram
 
HistogramStateFactory(Type, int, HistogramGroupImplementation) - Constructor for class io.prestosql.operator.aggregation.histogram.HistogramStateFactory
 
HistogramStateSerializer - Class in io.prestosql.operator.aggregation.histogram
 
HistogramStateSerializer(Type, 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
 
hourFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
hourFromTime(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
hourFromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
hourFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
hourFromTimeWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
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(HttpClient, DataSize, Duration, boolean, URI, HttpPageBufferClient.ClientCallback, ScheduledExecutorService, Executor) - Constructor for class io.prestosql.operator.HttpPageBufferClient
 
HttpPageBufferClient(HttpClient, DataSize, Duration, boolean, URI, HttpPageBufferClient.ClientCallback, ScheduledExecutorService, Ticker, 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<TaskInfo>, JsonCodec<TaskUpdateRequest>, NodeTaskMap.PartitionedSplitCountTracker, RemoteTaskStats) - Constructor for class io.prestosql.server.remotetask.HttpRemoteTask
 
HttpRemoteTaskFactory - Class in io.prestosql.server
 
HttpRemoteTaskFactory(QueryManagerConfig, TaskManagerConfig, HttpClient, LocationFactory, JsonCodec<TaskStatus>, JsonCodec<TaskInfo>, JsonCodec<TaskUpdateRequest>, RemoteTaskStats) - Constructor for class io.prestosql.server.HttpRemoteTaskFactory
 
HttpRequestSessionContext - Class in io.prestosql.server
 
HttpRequestSessionContext(HttpServletRequest) - Constructor for class io.prestosql.server.HttpRequestSessionContext
 
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
 
IF - Static variable in class io.prestosql.sql.relational.Signatures
 
IfCodeGenerator - Class in io.prestosql.sql.gen
 
IfCodeGenerator() - Constructor for class io.prestosql.sql.gen.IfCodeGenerator
 
ifSignature(Type) - Static method in class io.prestosql.sql.relational.Signatures
 
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_STATS_CALCULATOR_FAILURES - Static variable in class io.prestosql.SystemSessionProperties
 
ignoredZone() - Static method in class io.prestosql.util.GenerateTimeZoneIndex
 
immediateFailureQueryInfo(Session, String, URI, Optional<ResourceGroupId>, Throwable) - Static method in class io.prestosql.execution.QueryInfo
 
immediateFailureQueryStats() - Static method in class io.prestosql.execution.QueryStats
 
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() - Constructor for class io.prestosql.sql.planner.iterative.rule.ImplementBernoulliSampleAsFilter
 
ImplementFilteredAggregations - Class in io.prestosql.sql.planner.iterative.rule
Implements filtered aggregations by transforming plans of the following shape:
ImplementFilteredAggregations() - Constructor for class io.prestosql.sql.planner.iterative.rule.ImplementFilteredAggregations
 
ImplementIntersectAndExceptAsUnion - Class in io.prestosql.sql.planner.optimizations
Converts INTERSECT and EXCEPT queries into UNION ALL..GROUP BY...WHERE Eg: SELECT a FROM foo INTERSECT SELECT x FROM bar

=>

SELECT a FROM (SELECT a, COUNT(foo_marker) AS foo_cnt, COUNT(bar_marker) AS bar_cnt FROM ( SELECT a, true as foo_marker, null as bar_marker FROM foo UNION ALL SELECT x, null as foo_marker, true as bar_marker FROM bar ) T1 GROUP BY a) T2 WHERE foo_cnt >= 1 AND bar_cnt >= 1;

ImplementIntersectAndExceptAsUnion() - Constructor for class io.prestosql.sql.planner.optimizations.ImplementIntersectAndExceptAsUnion
 
in(Object, Set<?>) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
IN - Static variable in class io.prestosql.sql.relational.Signatures
 
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
 
InCodeGenerator - Class in io.prestosql.sql.gen
 
InCodeGenerator(FunctionRegistry) - Constructor for class io.prestosql.sql.gen.InCodeGenerator
 
incrementProbeFactoryCount() - Method in class io.prestosql.operator.JoinBridgeManager
 
indeterminate(MethodHandle, Type, Block, boolean) - Static method in class io.prestosql.operator.scalar.ArrayIndeterminateOperator
 
indeterminate(Slice, boolean) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
indeterminate(MethodHandle, Type, Type, Block, boolean) - Static method in class io.prestosql.operator.scalar.MapIndeterminateOperator
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.BigintOperators
 
indeterminate(boolean, boolean) - Static method in class io.prestosql.type.BooleanOperators
 
indeterminate(Slice, boolean) - Static method in class io.prestosql.type.CharOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.ColorOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.DateOperators
 
Indeterminate() - Constructor for class io.prestosql.type.DecimalOperators.Indeterminate
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.DecimalOperators.Indeterminate
 
indeterminate(Slice, boolean) - Static method in class io.prestosql.type.DecimalOperators.Indeterminate
 
indeterminate(double, boolean) - Static method in class io.prestosql.type.DoubleOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.IntegerOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
indeterminate(Slice, boolean) - Static method in class io.prestosql.type.IpAddressOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.RealOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.SmallintOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.TimeOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.TimestampOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
indeterminate(long, boolean) - Static method in class io.prestosql.type.TinyintOperators
 
indeterminate(Boolean) - Static method in class io.prestosql.type.UnknownOperators
 
indeterminate(Slice, boolean) - Static method in class io.prestosql.type.VarbinaryOperators
 
indeterminate(Slice, boolean) - Static method in class io.prestosql.type.VarcharOperators
 
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
 
IndexHandle - Class in io.prestosql.metadata
 
IndexHandle(ConnectorId, ConnectorTransactionHandle, ConnectorIndexHandle) - Constructor for class io.prestosql.metadata.IndexHandle
 
IndexHandleJacksonModule - Class in io.prestosql.index
 
IndexHandleJacksonModule(HandleResolver) - Constructor for class io.prestosql.index.IndexHandleJacksonModule
 
IndexInfo(long, long, double, long) - Constructor for class io.prestosql.operator.WindowInfo.IndexInfo
 
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) - 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) - 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>, Map<Symbol, Integer>, IndexBuildDriverFactoryProvider, DataSize, IndexJoinLookupStats, boolean, PagesIndex.Factory, JoinCompiler) - 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>, TupleDomain<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 class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
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
 
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(InformationSchemaTableHandle, Set<QualifiedTablePrefix>, 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
 
InformationSchemaTableHandle - Class in io.prestosql.connector.informationSchema
 
InformationSchemaTableHandle(String, String, String) - Constructor for class io.prestosql.connector.informationSchema.InformationSchemaTableHandle
 
InformationSchemaTableLayoutHandle - Class in io.prestosql.connector.informationSchema
 
InformationSchemaTableLayoutHandle(InformationSchemaTableHandle, Set<QualifiedTablePrefix>) - Constructor for class io.prestosql.connector.informationSchema.InformationSchemaTableLayoutHandle
 
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
 
init(FilterConfig) - Method in class io.prestosql.server.security.AuthenticationFilter
 
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
 
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(Map<Symbol, ? extends Expression>, Expression) - Static method in class io.prestosql.sql.planner.ExpressionSymbolInliner
 
inlineSymbols(Function<Symbol, 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, 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, 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
 
innerJoin(int, PlanNodeId, JoinBridgeManager<? extends LookupSourceFactory>, List<Type>, List<Integer>, OptionalInt, Optional<List<Integer>>, OptionalInt, PartitioningSpillerFactory) - Method in class io.prestosql.operator.LookupJoinOperators
 
Input - Class in io.prestosql.execution
 
Input(ConnectorId, String, String, Optional<Object>, List<Column>) - Constructor for class io.prestosql.execution.Input
 
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(MethodHandle, NullableBooleanState, boolean) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
input(BlockComparator, Type, MinMaxNState, Block, long, int) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
input(HyperLogLogState, Block, int, double) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, long, double) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, Slice, double) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
input(BooleanDistinctState, boolean, double) - Static method in class io.prestosql.operator.aggregation.ApproximateCountDistinctAggregation
 
input(DigestAndPercentileState, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
input(DigestAndPercentileArrayState, double, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileArrayAggregations
 
input(DigestAndPercentileState, long, double) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
input(DigestAndPercentileArrayState, long, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileArrayAggregations
 
input(DigestAndPercentileState, long, double) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
input(DigestAndPercentileArrayState, long, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileArrayAggregations
 
input(HyperLogLogState, double) - Static method in class io.prestosql.operator.aggregation.ApproximateSetAggregation
 
input(HyperLogLogState, Slice) - Static method in class io.prestosql.operator.aggregation.ApproximateSetAggregation
 
input(HyperLogLogState, long) - Static method in class io.prestosql.operator.aggregation.ApproximateSetAggregation
 
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, NullableBooleanState, Block, int) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
input(Type, BlockPositionState, Block, int) - Static method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
input(Type, ArrayAggregationState, Block, int) - Static method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
input(LongAndDoubleState, long) - Static method in class io.prestosql.operator.aggregation.AverageAggregations
 
input(LongAndDoubleState, double) - Static method in class io.prestosql.operator.aggregation.AverageAggregations
 
input(Type, NullableLongState, Block, int) - Static method in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
input(LongState) - Static method in class io.prestosql.operator.aggregation.CountAggregation
 
input(LongState, Block, int) - Static method in class io.prestosql.operator.aggregation.CountColumn
 
input(LongState, boolean) - Static method in class io.prestosql.operator.aggregation.CountIfAggregation
 
input(HyperLogLogState, Block, int) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, long) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, double) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
input(MethodHandle, HyperLogLogState, Slice) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
input(BooleanDistinctState, boolean) - Static method in class io.prestosql.operator.aggregation.DefaultApproximateCountDistinctAggregation
 
input(CorrelationState, double, double) - Static method in class io.prestosql.operator.aggregation.DoubleCorrelationAggregation
 
input(CovarianceState, double, double) - Static method in class io.prestosql.operator.aggregation.DoubleCovarianceAggregation
 
input(RegressionState, double, double) - Static method in class io.prestosql.operator.aggregation.DoubleRegressionAggregation
 
input(LongAndDoubleState, long) - Static method in class io.prestosql.operator.aggregation.GeometricMeanAggregations
 
input(LongAndDoubleState, double) - Static method in class io.prestosql.operator.aggregation.GeometricMeanAggregations
 
input(Type, HistogramState, Block, int) - Static method in class io.prestosql.operator.aggregation.histogram.Histogram
 
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(Type, Type, KeyValuePairsState, Block, Block, int) - Static method in class io.prestosql.operator.aggregation.MapAggregationFunction
 
input(Type, Type, KeyValuePairsState, Block) - Static method in class io.prestosql.operator.aggregation.MapUnionAggregation
 
input(NullableLongState, Block, int) - Static method in class io.prestosql.operator.aggregation.MaxDataSizeForStats
 
input(HyperLogLogState, Slice) - Static method in class io.prestosql.operator.aggregation.MergeHyperLogLogAggregation
 
input(Type, QuantileDigestState, Block, int) - Static method in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
input(BlockComparator, Type, Type, MinMaxByNState, Block, Block, int, long) - Static method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
input(MultimapAggregationState, Block, Block, int) - Static method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
input(LongState, DoubleState, long) - Static method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
input(CorrelationState, long, long) - Static method in class io.prestosql.operator.aggregation.RealCorrelationAggregation
 
input(CovarianceState, long, long) - Static method in class io.prestosql.operator.aggregation.RealCovarianceAggregation
 
input(LongAndDoubleState, long) - Static method in class io.prestosql.operator.aggregation.RealGeometricMeanAggregations
 
input(RegressionState, long, long) - Static method in class io.prestosql.operator.aggregation.RealRegressionAggregation
 
input(NullableLongState, Object, long, 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(NullableBooleanState, Object, boolean, BinaryFunctionInterface, BinaryFunctionInterface) - Static method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
input(NullableLongState, Block, int) - Static method in class io.prestosql.operator.aggregation.SumDataSizeForStats
 
input(SetDigestState, long) - Static method in class io.prestosql.type.setdigest.BuildSetDigestAggregation
 
input(SetDigestState, Slice) - Static method in class io.prestosql.type.setdigest.MergeSetDigestAggregation
 
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
 
InputReferenceExtractor - Class in io.prestosql.sql.planner
 
InputReferenceExtractor() - Constructor for class io.prestosql.sql.planner.InputReferenceExtractor
 
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
 
Insert(TableHandle, List<ColumnHandle>) - Constructor for class io.prestosql.sql.analyzer.Analysis.Insert
 
InsertHandle(InsertTableHandle, SchemaTableName) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.InsertHandle
 
InsertReference(TableHandle) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode.InsertReference
 
InsertTableHandle - Class in io.prestosql.metadata
 
InsertTableHandle(ConnectorId, ConnectorTransactionHandle, ConnectorInsertTableHandle) - Constructor for class io.prestosql.metadata.InsertTableHandle
 
InsertTableHandleJacksonModule - Class in io.prestosql.metadata
 
InsertTableHandleJacksonModule(HandleResolver) - Constructor for class io.prestosql.metadata.InsertTableHandleJacksonModule
 
inSignature() - Static method in class io.prestosql.sql.relational.Signatures
 
installPlugin(Plugin) - Method in class io.prestosql.server.PluginManager
 
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
 
INSTANCE - Static variable in class io.prestosql.sql.planner.NoOpSymbolResolver
 
INSTANCE_SIZE - Static variable in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.SingleDigestAndPercentileArrayState
 
INSTANCE_SIZE - Static variable in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.SingleDigestAndPercentileState
 
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
 
IntegerDistinctFromOperator() - Constructor for class io.prestosql.type.IntegerOperators.IntegerDistinctFromOperator
 
IntegerOperators - Class in io.prestosql.type
 
IntegerOperators.IntegerDistinctFromOperator - 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
 
INTERNAL_COMMUNICATION_KERBEROS_ENABLED - Static variable in class io.prestosql.server.InternalCommunicationConfig
 
InternalAggregationFunction - Class in io.prestosql.operator.aggregation
 
InternalAggregationFunction(String, List<Type>, List<Type>, Type, boolean, boolean, AccumulatorFactoryBinder) - Constructor for class io.prestosql.operator.aggregation.InternalAggregationFunction
 
InternalAggregationFunction(String, List<Type>, List<Type>, Type, boolean, boolean, AccumulatorFactoryBinder, List<Class>) - Constructor for class io.prestosql.operator.aggregation.InternalAggregationFunction
 
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
 
internalExecute(CreateTable, Metadata, AccessControl, Session, List<Expression>) - Method in class io.prestosql.execution.CreateTableTask
 
internalGenerateCpuQuota(long) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
InternalJoinFilterFunction - Interface in io.prestosql.operator
 
InternalNodeManager - Interface in io.prestosql.metadata
 
internalOperator(OperatorType, Type, List<? extends Type>) - Static method in class io.prestosql.metadata.Signature
 
internalOperator(OperatorType, TypeSignature, TypeSignature...) - Static method in class io.prestosql.metadata.Signature
 
internalOperator(OperatorType, TypeSignature, List<TypeSignature>) - Static method in class io.prestosql.metadata.Signature
 
internalOperator(String, TypeSignature, List<TypeSignature>) - Static method in class io.prestosql.metadata.Signature
 
internalOperator(String, TypeSignature, TypeSignature...) - Static method in class io.prestosql.metadata.Signature
 
internalRefreshStats() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
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(Optional<InternalResourceGroup>, String, BiConsumer<InternalResourceGroup, Boolean>, Executor) - Constructor for class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
InternalResourceGroup.RootInternalResourceGroup - Class in io.prestosql.execution.resourcegroups
 
InternalResourceGroupManager<C> - Class in io.prestosql.execution.resourcegroups
 
InternalResourceGroupManager(LegacyResourceGroupConfigurationManager, ClusterMemoryPoolManager, NodeInfo, MBeanExporter) - Constructor for class io.prestosql.execution.resourcegroups.InternalResourceGroupManager
 
internalScalarFunction(String, TypeSignature, TypeSignature...) - Static method in class io.prestosql.metadata.Signature
 
internalScalarFunction(String, TypeSignature, List<TypeSignature>) - Static method in class io.prestosql.metadata.Signature
 
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
 
InterpretedFunctionInvoker - Class in io.prestosql.sql
 
InterpretedFunctionInvoker(FunctionRegistry) - Constructor for class io.prestosql.sql.InterpretedFunctionInvoker
 
InterpretedHashGenerator - Class in io.prestosql.operator
 
InterpretedHashGenerator(List<Type>, List<Integer>) - Constructor for class io.prestosql.operator.InterpretedHashGenerator
 
InterpretedHashGenerator(List<Type>, int[]) - Constructor for class io.prestosql.operator.InterpretedHashGenerator
 
intersect(StatisticRange) - Method in class io.prestosql.cost.StatisticRange
 
intersect(Type, Block, Block) - Method in class io.prestosql.operator.scalar.ArrayIntersectFunction
 
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>) - 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
 
IntervalDayTimeDistinctFromOperator() - Constructor for class io.prestosql.type.IntervalDayTimeOperators.IntervalDayTimeDistinctFromOperator
 
IntervalDayTimeOperators - Class in io.prestosql.type
 
IntervalDayTimeOperators.IntervalDayTimeDistinctFromOperator - 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(ConnectorSession, long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
intervalDayToSecondPlusTimestamp(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
intervalDayToSecondPlusTimestampWithTimeZone(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
intervalDayToSecondPlusTimeWithTimeZone(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
IntervalDayToSecondSumAggregation - Class in io.prestosql.operator.aggregation
 
IntervalYearMonthDistinctFromOperator() - Constructor for class io.prestosql.type.IntervalYearMonthOperators.IntervalYearMonthDistinctFromOperator
 
IntervalYearMonthOperators - Class in io.prestosql.type
 
IntervalYearMonthOperators.IntervalYearMonthDistinctFromOperator - 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
 
intervalYearToMonthPlusTime(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
intervalYearToMonthPlusTimestamp(ConnectorSession, long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
intervalYearToMonthPlusTimestampWithTimeZone(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
intervalYearToMonthPlusTimeWithTimeZone(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
IntervalYearToMonthSumAggregation - Class in io.prestosql.operator.aggregation
 
inTransaction(Function<Session, T>) - Method in class io.prestosql.testing.LocalQueryRunner
 
inTransaction(Session, 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(InvokeFunction.InvokeLambda) - Static method in class io.prestosql.operator.scalar.InvokeFunction
 
invoke(Binding, String) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
invoke(Binding, Signature) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
invoke(Signature, ConnectorSession, Object...) - Method in class io.prestosql.sql.InterpretedFunctionInvoker
 
invoke(Signature, ConnectorSession, List<Object>) - Method in class io.prestosql.sql.InterpretedFunctionInvoker
Arguments must be the native container type for the corresponding SQL types.
INVOKE_FUNCTION - Static variable in class io.prestosql.operator.scalar.InvokeFunction
 
InvokeFunction - Class in io.prestosql.operator.scalar
This scalar function exists primarily to test lambda expression support.
invokeFunction(Scope, CachedInstanceBinder, String, ScalarFunctionImplementation, BytecodeExpression...) - Static method in class io.prestosql.sql.gen.InvokeFunctionBytecodeExpression
 
invokeFunction(Scope, CachedInstanceBinder, String, ScalarFunctionImplementation, List<BytecodeExpression>) - Static method in class io.prestosql.sql.gen.InvokeFunctionBytecodeExpression
 
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.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.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.testing - package io.prestosql.server.testing
 
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>) - 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.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
 
IpAddressDistinctFromOperator() - Constructor for class io.prestosql.type.IpAddressOperators.IpAddressDistinctFromOperator
 
IpAddressOperators - Class in io.prestosql.type
 
IpAddressOperators.IpAddressDistinctFromOperator - Class in io.prestosql.type
 
IpAddressType - Class in io.prestosql.type
 
IS_NULL - Static variable in class io.prestosql.sql.relational.Signatures
 
isAcknowledgePages() - Method in class io.prestosql.operator.ExchangeClientConfig
 
isAggregation(QuerySpecification) - Method in class io.prestosql.sql.analyzer.Analysis
 
isAggregationFunction(QualifiedName) - Method in class io.prestosql.metadata.FunctionRegistry
 
isAggregationFunction(QualifiedName) - Method in interface io.prestosql.metadata.Metadata
 
isAggregationFunction(QualifiedName) - Method in class io.prestosql.metadata.MetadataManager
 
isAliased() - Method in class io.prestosql.sql.analyzer.Field
 
isAnonymous() - Method in class io.prestosql.sql.analyzer.RelationId
 
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.HashSemiJoinOperator
 
isBlocked() - Method in class io.prestosql.operator.index.PageBufferOperator
 
isBlocked() - Method in class io.prestosql.operator.LookupJoinOperator
 
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.ScanFilterAndProjectOperator
 
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.server.QueryProgressStats
 
isBlockPosition() - Method in class io.prestosql.operator.aggregation.AggregationImplementation.AggregateNativeContainerType
 
isBufferComplete() - Method in class io.prestosql.execution.buffer.BufferResult
 
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.TypeRegistry.TypeCompatibility
 
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
 
isComparableRequired() - Method in class io.prestosql.metadata.TypeVariableConstraint
 
isCompatible() - Method in class io.prestosql.type.TypeRegistry.TypeCompatibility
 
isCompatibleTablePartitioningWith(Partitioning, boolean, Metadata, Session) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
isCompatibleTablePartitioningWith(ActualProperties, Function<Symbol, Set<Symbol>>, 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
 
isConstant() - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
isCoordinator() - Method in class io.prestosql.metadata.PrestoNode
 
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.TypeRegistry
 
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
 
isCreateTableAsSelectWithData() - Method in class io.prestosql.sql.analyzer.Analysis
 
isCrossJoin() - Method in class io.prestosql.sql.planner.plan.JoinNode
 
isDecomposable() - Method in class io.prestosql.operator.aggregation.AggregationHeader
 
isDecomposable() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
Indicates that the aggregation can be decomposed, and run as partial aggregations followed by a final aggregation to combine the intermediate results
isDecomposable(FunctionRegistry) - 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
 
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.SqlAggregationFunction
 
isDeterministic() - Method in interface io.prestosql.metadata.SqlFunction
 
isDeterministic() - Method in class io.prestosql.metadata.SqlOperator
 
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.AbstractGreatestLeast
 
isDeterministic() - Method in class io.prestosql.operator.scalar.annotations.ScalarImplementationHeader
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ApplyFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ArrayConcatFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ArrayConstructor
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ArrayFlattenFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ArrayJoin.ArrayJoinWithNullReplacement
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ArrayJoin
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ArrayReduceFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ArrayToElementConcatFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ArrayTransformFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ConcatFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ElementToArrayConcatFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.InvokeFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.JsonStringToArrayCast
 
isDeterministic() - Method in class io.prestosql.operator.scalar.JsonStringToMapCast
 
isDeterministic() - Method in class io.prestosql.operator.scalar.JsonStringToRowCast
 
isDeterministic() - Method in class io.prestosql.operator.scalar.MapConcatFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.MapConstructor
 
isDeterministic() - Method in class io.prestosql.operator.scalar.MapElementAtFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.MapFilterFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.MapTransformKeyFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.MapTransformValueFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.MapZipWithFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ParametricScalar
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ScalarHeader
 
isDeterministic() - Method in class io.prestosql.operator.scalar.TryCastFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ZipFunction
 
isDeterministic() - Method in class io.prestosql.operator.scalar.ZipWithFunction
 
isDeterministic() - Method in class io.prestosql.operator.window.SqlWindowFunction
 
isDeterministic(Expression) - Static method in class io.prestosql.sql.planner.DeterminismEvaluator
 
isDeterministic(RowExpression) - Method in class io.prestosql.sql.relational.DeterminismEvaluator
 
isDictionaryAggregation() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isDictionaryAggregationEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
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(MethodHandle, Block, boolean, Block, boolean) - Static method in class io.prestosql.operator.scalar.ArrayDistinctFromOperator
 
isDistinctFrom(MethodHandle, Type, Block, int, Block, int) - Static method in class io.prestosql.operator.scalar.ArrayDistinctFromOperator
 
isDistinctFrom(Slice, boolean, Slice, boolean) - Static method in class io.prestosql.operator.scalar.JsonOperators.JsonDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.operator.scalar.JsonOperators.JsonDistinctFromOperator
 
isDistinctFrom(MethodHandle, Type, Block, boolean, Block, boolean) - Static method in class io.prestosql.operator.scalar.MapDistinctFromOperator
 
isDistinctFrom(MethodHandle, Type, Block, int, Block, int) - Static method in class io.prestosql.operator.scalar.MapDistinctFromOperator
 
isDistinctFrom(Type, List<MethodHandle>, Block, boolean, Block, boolean) - Static method in class io.prestosql.operator.scalar.RowDistinctFromOperator
 
isDistinctFrom(Type, List<MethodHandle>, Block, int, Block, int) - Static method in class io.prestosql.operator.scalar.RowDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.BigintOperators.BigintDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.BigintOperators.BigintDistinctFromOperator
 
isDistinctFrom(boolean, boolean, boolean, boolean) - Static method in class io.prestosql.type.BooleanOperators.BooleanDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.BooleanOperators.BooleanDistinctFromOperator
 
isDistinctFrom(Slice, boolean, Slice, boolean) - Static method in class io.prestosql.type.CharOperators.CharDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.CharOperators.CharDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.ColorOperators.ColorDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.ColorOperators.ColorDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.DateOperators.DateDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.DateOperators.DateDistinctFromOperator
 
isDistinctFrom(double, boolean, double, boolean) - Static method in class io.prestosql.type.DoubleOperators.DoubleDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.DoubleOperators.DoubleDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.IntegerOperators.IntegerDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.IntegerOperators.IntegerDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.IntervalDayTimeOperators.IntervalDayTimeDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.IntervalDayTimeOperators.IntervalDayTimeDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.IntervalYearMonthOperators.IntervalYearMonthDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.IntervalYearMonthOperators.IntervalYearMonthDistinctFromOperator
 
isDistinctFrom(Slice, boolean, Slice, boolean) - Static method in class io.prestosql.type.IpAddressOperators.IpAddressDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.IpAddressOperators.IpAddressDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.RealOperators.RealDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.RealOperators.RealDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.SmallintOperators.SmallintDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.SmallintOperators.SmallintDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.TimeOperators.TimeDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.TimeOperators.TimeDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.TimestampOperators.TimestampDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.TimestampOperators.TimestampDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators.TimestampWithTimeZoneDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators.TimestampWithTimeZoneDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators.TimeWithTimeZoneDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators.TimeWithTimeZoneDistinctFromOperator
 
isDistinctFrom(long, boolean, long, boolean) - Static method in class io.prestosql.type.TinyintOperators.TinyintDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.TinyintOperators.TinyintDistinctFromOperator
 
isDistinctFrom(boolean, boolean, boolean, boolean) - Static method in class io.prestosql.type.UnknownOperators.UnknownDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.UnknownOperators.UnknownDistinctFromOperator
 
isDistinctFrom(Slice, boolean, Slice, boolean) - Static method in class io.prestosql.type.VarbinaryOperators.VarbinaryDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.VarbinaryOperators.VarbinaryDistinctFromOperator
 
isDistinctFrom(Slice, boolean, Slice, boolean) - Static method in class io.prestosql.type.VarcharOperators.VarcharDistinctFromOperator
 
isDistinctFrom(Block, int, Block, int) - Static method in class io.prestosql.type.VarcharOperators.VarcharDistinctFromOperator
 
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.execution.DataDefinitionExecution
 
isDone() - Method in class io.prestosql.execution.FailedQueryExecution
 
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
 
isDynamicSchduleForGroupedExecution(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.operator.aggregation.AbstractGroupCollectionAggregationState
 
isEmpty() - Method in interface io.prestosql.operator.aggregation.arrayagg.ArrayAggregationState
 
isEmpty() - Method in class io.prestosql.operator.aggregation.arrayagg.LegacyArrayAggregationGroupState
Deprecated.
 
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 class io.prestosql.operator.aggregation.multimapagg.LegacyGroupedMultimapAggregationState
Deprecated.
 
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.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.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
 
isEnabled() - Method in class io.prestosql.failureDetector.FailureDetectorConfig
 
isEnabled() - Method in class io.prestosql.server.EmbeddedDiscoveryConfig
 
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.PushAggregationThroughOuterJoin
 
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.PushTableWriteThroughUnion
 
isEnabled(Session) - Method in class io.prestosql.sql.planner.iterative.rule.ReorderJoins
 
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
 
isEnableStatsCalculator() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isEnableStatsCalculator(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isEnhancedErrorReporting() - Method in class io.prestosql.server.ServerConfig
 
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
 
isExpressionExpensive() - Method in class io.prestosql.sql.gen.ExpressionProfiler
 
isFailure() - Method in enum io.prestosql.execution.StageState
Is this a non-success terminal state.
isFastInequalityJoin(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isFastInequalityJoins() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
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.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.AssignUniqueIdOperator
 
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.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.FilterAndProjectOperator
 
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.HashSemiJoinOperator
 
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.LimitOperator
 
isFinished() - Method in class io.prestosql.operator.LookupJoinOperator
 
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.MetadataDeleteOperator
 
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.PageSourceOperator
 
isFinished() - Method in class io.prestosql.operator.PartitionedOutputOperator
 
isFinished() - Method in class io.prestosql.operator.project.MergingPageOutput
 
isFinished() - Method in class io.prestosql.operator.RowNumberOperator
 
isFinished() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
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.StreamingAggregationOperator
 
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.TopNOperator
 
isFinished() - Method in class io.prestosql.operator.TopNRowNumberOperator
 
isFinished() - Method in class io.prestosql.operator.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.split.BufferingSplitSource
 
isFinished() - Method in class io.prestosql.split.ConnectorAwareSplitSource
 
isFinished() - Method in class io.prestosql.split.EmptySplitPageSource
 
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
 
isForceSingleNodeOutput() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isForceSingleNodeOutput(Session) - Static method in class io.prestosql.SystemSessionProperties
 
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.SessionPropertyManager.SessionPropertyValue
 
isHidden() - Method in class io.prestosql.metadata.SqlAggregationFunction
 
isHidden() - Method in interface io.prestosql.metadata.SqlFunction
 
isHidden() - Method in class io.prestosql.metadata.SqlOperator
 
isHidden() - Method in class io.prestosql.operator.aggregation.AggregationHeader
 
isHidden() - Method in class io.prestosql.operator.scalar.AbstractGreatestLeast
 
isHidden() - Method in class io.prestosql.operator.scalar.annotations.ScalarImplementationHeader
 
isHidden() - Method in class io.prestosql.operator.scalar.ApplyFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.ArrayConcatFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.ArrayConstructor
 
isHidden() - Method in class io.prestosql.operator.scalar.ArrayFlattenFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.ArrayJoin.ArrayJoinWithNullReplacement
 
isHidden() - Method in class io.prestosql.operator.scalar.ArrayJoin
 
isHidden() - Method in class io.prestosql.operator.scalar.ArrayReduceFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.ArrayToElementConcatFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.ArrayTransformFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.ConcatFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.ElementToArrayConcatFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.InvokeFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.JsonStringToArrayCast
 
isHidden() - Method in class io.prestosql.operator.scalar.JsonStringToMapCast
 
isHidden() - Method in class io.prestosql.operator.scalar.JsonStringToRowCast
 
isHidden() - Method in class io.prestosql.operator.scalar.MapConcatFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.MapConstructor
 
isHidden() - Method in class io.prestosql.operator.scalar.MapElementAtFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.MapFilterFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.MapTransformKeyFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.MapTransformValueFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.MapZipWithFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.ParametricScalar
 
isHidden() - Method in class io.prestosql.operator.scalar.ScalarHeader
 
isHidden() - Method in class io.prestosql.operator.scalar.TryCastFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.ZipFunction
 
isHidden() - Method in class io.prestosql.operator.scalar.ZipWithFunction
 
isHidden() - Method in class io.prestosql.operator.window.SqlWindowFunction
 
isHidden() - Method in class io.prestosql.sql.analyzer.Field
 
isHttpsRequired() - Method in class io.prestosql.server.InternalCommunicationConfig
 
isIdentity(Symbol) - Method in class io.prestosql.sql.planner.plan.Assignments
 
isIdentity() - Method in class io.prestosql.sql.planner.plan.ProjectNode
 
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() - 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
 
isInstanceOfAny(Class...) - Static method in class io.prestosql.util.MorePredicates
 
isInteger(long) - Static method in class io.prestosql.sql.gen.InCodeGenerator
 
isInternalSystemConnector(ConnectorId) - Static method in class io.prestosql.connector.ConnectorId
 
isIterativeOptimizerEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
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(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.PartitionedLookupSource
 
isJsonLengthLimitExceeded() - Method in class io.prestosql.operator.TableFinishInfo
 
isJsonScalar(Slice) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
isKerberosEnabled() - Method in class io.prestosql.server.InternalCommunicationConfig
 
isKerberosUseCanonicalHostname() - Method in class io.prestosql.server.InternalCommunicationConfig
 
isLastBatch() - Method in class io.prestosql.split.SplitSource.SplitBatch
Returns true if all splits for the requested driver group have been returned.
isLeaf() - Method in class io.prestosql.sql.planner.PlanFragment
 
isLegacyTimestamp() - Method in class io.prestosql.FullConnectorSession
 
isLegacyTimestamp() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isLegacyTimestamp(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isLegacyTimestamp() - Method in class io.prestosql.testing.TestingConnectorSession
 
isLikePattern(Slice, Slice) - Static method in class io.prestosql.type.LikeFunctions
 
isList() - Method in class io.prestosql.operator.project.SelectedPositions
 
isLocal() - Method in class io.prestosql.sql.analyzer.ResolvedField
 
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
 
isNewOptimizerEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
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.operator.scalar.annotations.ParametricScalarImplementation.ParametricScalarImplementationChoice
 
isNullable() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation
 
isNullable() - Method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ScalarImplementationChoice
 
IsNullCodeGenerator - Class in io.prestosql.sql.gen
 
IsNullCodeGenerator() - 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
 
isNullSignature(Type) - Static method in class io.prestosql.sql.relational.Signatures
 
isolateClass(DynamicClassLoader, Class<T>, Class<? extends T>, Class<?>...) - Static method in class io.prestosql.sql.gen.IsolatedClass
 
IsolatedClass - Class in io.prestosql.sql.gen
 
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
 
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
 
isOrderableRequired() - Method in class io.prestosql.metadata.TypeVariableConstraint
 
isOrdered() - Method in class io.prestosql.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties
 
isOrderSensitive() - Method in class io.prestosql.operator.aggregation.AggregationHeader
 
isOrderSensitive() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
Indicates that the aggregation is sensitive to input order
isOrderSensitive() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
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() - 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
 
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
 
isPreferPartialAggregation() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isPrestoAnnotation(Annotation) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
isPushAggregationThroughJoin() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isPushAggregationThroughJoin(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
 
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
 
isRegistered(Signature) - Method in class io.prestosql.metadata.FunctionRegistry
 
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
 
isReservedPoolEnabled() - Method in class io.prestosql.memory.NodeMemoryConfig
 
isResultGreaterThan(int) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
isResultGreaterThanOrEqual(int) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
isResultLessThan(int) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
isResultLessThanOrEqual(int) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
isResultNotEqual(int) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
isRowCountEnabled() - Method in class io.prestosql.sql.planner.plan.StatisticsWriterNode
 
isRunAsInvoker() - Method in class io.prestosql.metadata.ViewDefinition
 
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
 
isShareIndexLoading() - Method in class io.prestosql.execution.TaskManagerConfig
 
isShareIndexLoading(Session) - Static method in class io.prestosql.SystemSessionProperties
 
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
 
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
 
isSpillEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isSpillEnabled(Session) - Static method in class io.prestosql.SystemSessionProperties
 
isSpillerSpillPathsConfiguredIfSpillEnabled() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
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
 
isSupportedLiteralType(Type) - Static method in class io.prestosql.metadata.FunctionRegistry
 
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
 
isTransactionControl() - Method in class io.prestosql.execution.CommitTask
 
isTransactionControl() - Method in interface io.prestosql.execution.DataDefinitionTask
 
isTransactionControl() - Method in class io.prestosql.execution.RollbackTask
 
isTransactionControl() - Method in class io.prestosql.execution.StartTransactionTask
 
isTransactionControlStatement(Statement) - Static method in class io.prestosql.util.StatementUtils
 
isTypeOnlyCoercion(Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
isTypeOnlyCoercion(Expression) - Method in class io.prestosql.sql.analyzer.ExpressionAnalysis
 
isTypeOnlyCoercion(Type, Type) - Method in class io.prestosql.type.TypeRegistry
 
isUnknown() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
isUseMarkDistinct() - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
isValid(Integer, ConstraintValidatorContext) - Method in class io.prestosql.util.PowerOfTwoValidator
 
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
 
isWorkerShutdown() - Method in class io.prestosql.server.testing.TestingPrestoServer.TestShutdownAction
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class io.prestosql.server.PagesResponseWriter
 
ITERATIVE_OPTIMIZER - 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, Set<Rule<?>>) - Constructor for class io.prestosql.sql.planner.iterative.IterativeOptimizer
 
IterativeOptimizer(RuleStatsRecorder, StatsCalculator, CostCalculator, List<PlanOptimizer>, Set<Rule<?>>) - Constructor for class io.prestosql.sql.planner.iterative.IterativeOptimizer
 
iterator() - Method in interface io.prestosql.operator.WorkProcessor
Converts WorkProcessor into an Iterator.
iterator() - Method in class io.prestosql.testing.MaterializedResult
 

J

jaccardIndex(SetDigest, SetDigest) - Static method in class io.prestosql.type.setdigest.SetDigest
 
jaccardIndex(Slice, Slice) - Static method in class io.prestosql.type.setdigest.SetDigestFunctions
 
JavaVersion - Class in io.prestosql.server
 
JavaVersion(int, int, OptionalInt) - Constructor for class io.prestosql.server.JavaVersion
 
JavaVersion(int, int) - Constructor for class io.prestosql.server.JavaVersion
 
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(Metadata) - 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>, Optional<Map<Symbol, Expression>>) - 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>, Optional<Expression>, Optional<Symbol>, Optional<Symbol>, Optional<JoinNode.DistributionType>, Optional<Boolean>) - 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(long) - Method in class io.prestosql.operator.index.IndexLookupSource
 
joinPositionWithinPartition(long) - Method in class io.prestosql.operator.JoinHash
 
joinPositionWithinPartition - Variable in class io.prestosql.operator.LookupJoinOperator.SavedRow
A snapshot of LookupJoinOperator.joinPosition "de-partitioned", i.e.
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
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_REGEXP - Static variable in class io.prestosql.type.JoniRegexpType
 
joniRegexp(Slice) - Static method in class io.prestosql.operator.scalar.JoniRegexpCasts
 
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, long) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
jsonArrayContains(Slice, double) - 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(String) - Static method in class io.prestosql.execution.Lifespan
 
jsonCreator(Set<PlanNodeId>) - Static method in class io.prestosql.operator.StageExecutionDescriptor
 
JsonDistinctFromOperator() - Constructor for class io.prestosql.operator.scalar.JsonOperators.JsonDistinctFromOperator
 
JsonExtract - Class in io.prestosql.operator.scalar
Extracts values from JSON

Supports the following JSON path primitives:

jsonExtract(Slice, JsonPath) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
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>, FunctionRegistry, 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
 
JsonOperators.JsonDistinctFromOperator - 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
 
JsonPathType() - Constructor for class io.prestosql.type.JsonPathType
 
JsonRenderedNode(String, 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.HashTable - Class 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
 
JsonWebTokenAuthenticator - Class in io.prestosql.server.security
 
JsonWebTokenAuthenticator(JsonWebTokenConfig) - Constructor for class io.prestosql.server.security.JsonWebTokenAuthenticator
 
JsonWebTokenConfig - Class in io.prestosql.server.security
 
JsonWebTokenConfig() - Constructor for class io.prestosql.server.security.JsonWebTokenConfig
 

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
 
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
 
KeyValuePairs - Class in io.prestosql.operator.aggregation
 
KeyValuePairs(Type, Type) - Constructor for class io.prestosql.operator.aggregation.KeyValuePairs
 
KeyValuePairs(Block, Type, 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) - Constructor for class io.prestosql.operator.aggregation.state.KeyValuePairStateSerializer
 
killQuery(String, String) - Method in class io.prestosql.connector.system.KillQueryProcedure
 
killQuery(QueryId, String) - Method in class io.prestosql.server.QueryResource
 
KillQueryProcedure - Class in io.prestosql.connector.system
 
KillQueryProcedure(QueryManager) - Constructor for class io.prestosql.connector.system.KillQueryProcedure
 
kind(FunctionKind) - Method in class io.prestosql.metadata.SignatureBuilder
 
kurtosis(CentralMomentsState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.CentralMomentsAggregation
 

L

LagFunction - Class in io.prestosql.operator.window
 
LagFunction(List<Integer>) - 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 - Class in io.prestosql.sql.gen
 
lambdaCapture(MethodHandles.Lookup, String, MethodType, MethodType, MethodHandle, MethodType) - Static method in class io.prestosql.sql.gen.LambdaCapture
 
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
 
lastRun - Variable in class io.prestosql.execution.executor.PrioritizedSplitRunner
 
LastValueFunction - Class in io.prestosql.operator.window
 
LastValueFunction(List<Integer>) - Constructor for class io.prestosql.operator.window.LastValueFunction
 
lateralJoin() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
LateralJoin() - Constructor for class io.prestosql.sql.planner.plan.Patterns.LateralJoin
 
LateralJoinNode - Class in io.prestosql.sql.planner.plan
For every row from LateralJoinNode.input a LateralJoinNode.subquery relation is calculated.
LateralJoinNode(PlanNodeId, PlanNode, PlanNode, List<Symbol>, LateralJoinNode.Type, Node) - Constructor for class io.prestosql.sql.planner.plan.LateralJoinNode
 
LateralJoinNode.Type - Enum in io.prestosql.sql.planner.plan
 
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, Supplier<LocalMemoryContext>) - Constructor for class io.prestosql.execution.buffer.LazyOutputBuffer
 
LeadFunction - Class in io.prestosql.operator.window
 
LeadFunction(List<Integer>) - 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
 
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
 
LEGACY - Static variable in class io.prestosql.execution.scheduler.NodeSchedulerConfig.NetworkTopologyType
 
LEGACY_TIMESTAMP - Static variable in class io.prestosql.SystemSessionProperties
 
LegacyArrayAggregationGroupState - Class in io.prestosql.operator.aggregation.arrayagg
Deprecated.
LegacyArrayAggregationGroupState(Type) - Constructor for class io.prestosql.operator.aggregation.arrayagg.LegacyArrayAggregationGroupState
Deprecated.
 
LegacyGroupedMultimapAggregationState - Class in io.prestosql.operator.aggregation.multimapagg
Deprecated.
LegacyGroupedMultimapAggregationState(Type, Type) - Constructor for class io.prestosql.operator.aggregation.multimapagg.LegacyGroupedMultimapAggregationState
Deprecated.
 
LegacyHistogramGroupState - Class in io.prestosql.operator.aggregation.histogram
Deprecated.
LegacyHistogramGroupState(Type, int) - Constructor for class io.prestosql.operator.aggregation.histogram.LegacyHistogramGroupState
Deprecated.
 
LegacyNetworkTopology - Class in io.prestosql.execution.scheduler
 
LegacyNetworkTopology() - Constructor for class io.prestosql.execution.scheduler.LegacyNetworkTopology
 
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() - 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
 
less(RowType, List<MethodHandle>, Block, Block) - Static method in class io.prestosql.operator.scalar.RowLessThanOperator
 
lessOrEqual(RowType, List<MethodHandle>, Block, Block) - Static method in class io.prestosql.operator.scalar.RowLessThanOrEqualOperator
 
lessThan(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayLessThanOperator
 
lessThan(int, int) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
lessThan(long, long) - Static method in class io.prestosql.type.BigintOperators
 
lessThan(boolean, boolean) - Static method in class io.prestosql.type.BooleanOperators
 
lessThan(Slice, Slice) - Static method in class io.prestosql.type.CharOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.DateOperators
 
lessThan(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
lessThan(Slice, Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.RealOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.TimeOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.TimestampOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
lessThan(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
lessThan(boolean, boolean) - Static method in class io.prestosql.type.UnknownOperators
 
lessThan(Slice, Slice) - Static method in class io.prestosql.type.VarbinaryOperators
 
lessThan(Slice, Slice) - Static method in class io.prestosql.type.VarcharOperators
 
lessThanLong(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayLessThanOperator
 
lessThanOrEqual(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayLessThanOrEqualOperator
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.BigintOperators
 
lessThanOrEqual(boolean, boolean) - Static method in class io.prestosql.type.BooleanOperators
 
lessThanOrEqual(Slice, Slice) - Static method in class io.prestosql.type.CharOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.DateOperators
 
lessThanOrEqual(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
lessThanOrEqual(Slice, Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.RealOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.TimeOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.TimestampOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
lessThanOrEqual(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
lessThanOrEqual(boolean, boolean) - Static method in class io.prestosql.type.UnknownOperators
 
lessThanOrEqual(Slice, Slice) - Static method in class io.prestosql.type.VarbinaryOperators
 
lessThanOrEqual(Slice, Slice) - Static method in class io.prestosql.type.VarcharOperators
 
lessThanOrEqualLong(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayLessThanOrEqualOperator
 
levenshteinDistance(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
Lifespan - Class in io.prestosql.execution
 
LifespanScheduler - Interface in io.prestosql.execution.scheduler.group
 
LIKE_PATTERN - Static variable in class io.prestosql.type.LikePatternType
 
likeChar(Long, Slice, Regex) - Static method in class io.prestosql.type.LikeFunctions
 
likeCharSignature(Type) - Static method in class io.prestosql.sql.relational.Signatures
 
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
 
likePatternSignature() - Static method in class io.prestosql.sql.relational.Signatures
 
LikePatternType - Class in io.prestosql.type
 
LikePatternType() - Constructor for class io.prestosql.type.LikePatternType
 
likeVarchar(Slice, Regex) - Static method in class io.prestosql.type.LikeFunctions
 
likeVarcharSignature() - Static method in class io.prestosql.sql.relational.Signatures
 
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
 
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
 
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
 
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
 
listOperators() - Method in class io.prestosql.metadata.FunctionRegistry
 
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(ConnectorSession) - Method in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
listSchemaNames(ConnectorSession) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
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.testing.TestingMetadata
 
listSchemas(Session, Metadata, AccessControl, String) - Static method in class io.prestosql.metadata.MetadataListing
 
listSystemTables(ConnectorSession) - Method in class io.prestosql.connector.system.DelegatingSystemTablesProvider
 
listSystemTables(ConnectorSession) - Method in class io.prestosql.connector.system.MetadataBasedSystemTablesProvider
 
listSystemTables(ConnectorSession) - Method in class io.prestosql.connector.system.StaticSystemTablesProvider
 
listSystemTables(ConnectorSession) - Method in interface io.prestosql.connector.system.SystemTablesProvider
 
listTableColumns(ConnectorSession, SchemaTablePrefix) - Method in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
listTableColumns(ConnectorSession, SchemaTablePrefix) - Method in class io.prestosql.connector.system.SystemTablesMetadata
 
listTableColumns(Session, QualifiedTablePrefix) - Method in interface io.prestosql.metadata.Metadata
Gets the metadata for all columns that match the specified table prefix.
listTableColumns(Session, Metadata, AccessControl, QualifiedTablePrefix) - Static method in class io.prestosql.metadata.MetadataListing
 
listTableColumns(Session, QualifiedTablePrefix) - Method in class io.prestosql.metadata.MetadataManager
 
listTableColumns(ConnectorSession, SchemaTablePrefix) - Method in class io.prestosql.testing.TestingMetadata
 
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, Metadata, AccessControl, QualifiedTablePrefix) - Static method in class io.prestosql.metadata.MetadataListing
 
listTablePrivileges(Session, QualifiedTablePrefix) - Method in class io.prestosql.metadata.MetadataManager
 
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(Session, QualifiedTablePrefix) - Method in interface io.prestosql.metadata.Metadata
Get the names that match the specified table prefix (never null).
listTables(Session, Metadata, AccessControl, QualifiedTablePrefix) - Static method in class io.prestosql.metadata.MetadataListing
 
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.testing.TestingMetadata
 
listViews(Session, QualifiedTablePrefix) - Method in interface io.prestosql.metadata.Metadata
Get the names that match the specified table prefix (never null).
listViews(Session, Metadata, AccessControl, QualifiedTablePrefix) - Static method in class io.prestosql.metadata.MetadataListing
 
listViews(Session, QualifiedTablePrefix) - Method in class io.prestosql.metadata.MetadataManager
 
listViews(ConnectorSession, Optional<String>) - Method in class io.prestosql.testing.TestingMetadata
 
LiteralEncoder - Class in io.prestosql.sql.planner
 
LiteralEncoder(BlockEncodingSerde) - Constructor for class io.prestosql.sql.planner.LiteralEncoder
 
LiteralImplementationDependency - Class in io.prestosql.operator.annotations
 
LiteralImplementationDependency(String) - Constructor for class io.prestosql.operator.annotations.LiteralImplementationDependency
 
LiteralInterpreter - Class in io.prestosql.sql.planner
 
LiteralParameter - Annotation Type in io.prestosql.type
 
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
 
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
 
loadConfiguredEventListener() - Method in class io.prestosql.eventlistener.EventListenerManager
 
loadConstant(CallSiteBinder, Object, Class<?>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
loadConstant(Binding) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
loadPasswordAuthenticator() - Method in class io.prestosql.server.security.PasswordAuthenticatorManager
 
loadPlugins() - Method in class io.prestosql.server.PluginManager
 
loadProperties(File) - Static method in class io.prestosql.util.PropertiesUtil
 
loadSystemAccessControl() - Method in class io.prestosql.security.AccessControlManager
 
local(List<? extends LocalProperty<Symbol>>) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Builder
 
LocalCostEstimate - Class in io.prestosql.cost
Represents inherent cost of some plan node, not including cost of its sources.
LocalExchange - Class in io.prestosql.operator.exchange
 
LocalExchange(int, int, PartitioningHandle, List<? extends Type>, List<Integer>, Optional<Integer>, DataSize) - 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) - 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, BlockEncodingSerde, PagesIndex.Factory, JoinCompiler, LookupJoinOperators, OrderingCompiler) - 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(Session) - Constructor for class io.prestosql.testing.LocalQueryRunner
 
LocalQueryRunner(Session, FeaturesConfig) - Constructor for class io.prestosql.testing.LocalQueryRunner
 
LocalQueryRunner(Session, FeaturesConfig, NodeSpillConfig, boolean, boolean) - Constructor for class io.prestosql.testing.LocalQueryRunner
 
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(ConnectorSession) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
localTimestamp(ConnectorSession) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
localUserMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
locate(HostAddress) - Method in class io.prestosql.execution.scheduler.FlatNetworkTopology
 
locate(HostAddress) - Method in class io.prestosql.execution.scheduler.LegacyNetworkTopology
 
locate(HostAddress) - Method in interface io.prestosql.execution.scheduler.NetworkTopology
 
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 class io.prestosql.execution.scheduler.SimpleNodeSelector
 
lockDownNodes() - Method in interface io.prestosql.execution.scheduler.SplitPlacementPolicy
 
lockDownNodes() - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
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
 
logicalExpressionSignature(LogicalBinaryExpression.Operator) - Static method in class io.prestosql.sql.relational.Signatures
 
LogicalPlanner - Class in io.prestosql.sql.planner
 
LogicalPlanner(Session, List<PlanOptimizer>, PlanNodeIdAllocator, Metadata, TypeAnalyzer, StatsCalculator, CostCalculator, WarningCollector) - Constructor for class io.prestosql.sql.planner.LogicalPlanner
 
LogicalPlanner(Session, List<PlanOptimizer>, PlanSanityChecker, PlanNodeIdAllocator, Metadata, TypeAnalyzer, StatsCalculator, CostCalculator, WarningCollector) - Constructor for class io.prestosql.sql.planner.LogicalPlanner
 
LogicalPlanner.Stage - Enum in io.prestosql.sql.planner
 
LongAndBlockPositionValueState - Interface in io.prestosql.operator.aggregation.minmaxby
 
LongAndDoubleState - Interface in io.prestosql.operator.aggregation.state
 
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
 
longArrayMinMax(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMinMaxUtils
 
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
 
LongLongState - Interface in io.prestosql.operator.aggregation.minmaxby
 
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
 
longToLongCast(Slice, long, long, long, long) - Static method in class io.prestosql.type.DecimalToDecimalCasts
 
longToShortCast(Slice, long, long, long, long) - Static method in class io.prestosql.type.DecimalToDecimalCasts
 
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
 
lookupAllAtOnce(PartitionedLookupSourceFactory) - Static method in class io.prestosql.operator.JoinBridgeManager
 
lookupCodecFromMarker(byte) - Static method in enum io.prestosql.execution.buffer.PageCompression
 
LookupJoinOperator - Class in io.prestosql.operator
 
LookupJoinOperator(OperatorContext, List<Type>, List<Type>, LookupJoinOperators.JoinType, LookupSourceFactory, JoinProbe.JoinProbeFactory, Runnable, OptionalInt, HashGenerator, PartitioningSpillerFactory) - Constructor for class io.prestosql.operator.LookupJoinOperator
 
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, 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) - 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
 
LowMemoryKillerPolicy() - Constructor for class io.prestosql.memory.MemoryManagerConfig.LowMemoryKillerPolicy
 

M

main(String[]) - Static method in class io.prestosql.server.PrestoServer
 
main(String[]) - Static method in class io.prestosql.util.GenerateTimeZoneIndex
 
makeClassName(String, Optional<String>) - Static method in class io.prestosql.util.CompilerUtils
 
makeClassName(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
 
ManagedQueryExecution - Interface in io.prestosql.execution
 
mangleOperatorName(OperatorType) - Static method in class io.prestosql.metadata.FunctionRegistry
 
mangleOperatorName(String) - Static method in class io.prestosql.metadata.FunctionRegistry
 
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(Function<T, R>) - Method in interface io.prestosql.operator.WorkProcessor
 
map(Scope, CachedInstanceBinder, Type, Type, Variable, String, ScalarFunctionImplementation) - 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(Scope, CallSiteBinder, BytecodeExpression, Type, Type, Function<BytecodeExpression, BytecodeExpression>) - Static method in class io.prestosql.sql.gen.ArrayGeneratorUtils
 
map(Symbol) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(Expression) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(AggregationNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(AggregationNode, PlanNode, PlanNodeIdAllocator) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(TopNNode, PlanNode, PlanNodeId) - 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(StatisticsWriterNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(TableFinishNode, PlanNode) - Method in class io.prestosql.sql.planner.optimizations.SymbolMapper
 
map(Function<T, T2>) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor
 
MAP - Static variable in class io.prestosql.type.MapParametricType
 
MAP_AGG - Static variable in class io.prestosql.operator.aggregation.MapAggregationFunction
 
MAP_CONCAT_FUNCTION - Static variable in class io.prestosql.operator.scalar.MapConcatFunction
 
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_HASH_CODE - Static variable in class io.prestosql.operator.scalar.MapHashCodeOperator
 
MAP_TO_JSON - Static variable in class io.prestosql.operator.scalar.MapToJsonCast
 
MAP_TO_MAP_CAST - Static variable in class io.prestosql.operator.scalar.MapToMapCast
 
MAP_TRANSFORM_KEY_FUNCTION - Static variable in class io.prestosql.operator.scalar.MapTransformKeyFunction
 
MAP_TRANSFORM_VALUE_FUNCTION - Static variable in class io.prestosql.operator.scalar.MapTransformValueFunction
 
MAP_UNION - Static variable in class io.prestosql.operator.aggregation.MapUnionAggregation
 
MAP_ZIP_WITH_FUNCTION - Static variable in class io.prestosql.operator.scalar.MapZipWithFunction
 
MapAggregationFunction - Class in io.prestosql.operator.aggregation
 
MapAggregationFunction() - Constructor for class io.prestosql.operator.aggregation.MapAggregationFunction
 
mapCardinality(Block) - Static method in class io.prestosql.operator.scalar.MapCardinalityFunction
 
MapCardinalityFunction - Class in io.prestosql.operator.scalar
 
mapCast(MethodHandle, MethodHandle, Type, ConnectorSession, Block) - Static method in class io.prestosql.operator.scalar.MapToMapCast
 
mapConcat(MapType, Object, Block[]) - Static method in class io.prestosql.operator.scalar.MapConcatFunction
 
MapConcatFunction - Class in io.prestosql.operator.scalar
 
MapConstructor - Class in io.prestosql.operator.scalar
 
MapConstructor() - Constructor for class io.prestosql.operator.scalar.MapConstructor
 
MapConstructor.State - Class in io.prestosql.operator.scalar
 
MapDistinctFromOperator - 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
 
MapEqualOperator - Class in io.prestosql.operator.scalar
 
MapFilterFunction - Class in io.prestosql.operator.scalar
 
mapFromEntries(RowType, Block) - Method in class io.prestosql.operator.scalar.MapEntriesFunction
 
mapFromEntries(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
 
MapGenericEquality - Class in io.prestosql.operator.scalar
 
MapGenericEquality.EqualityPredicate - Interface in io.prestosql.operator.scalar
 
MapHashCodeOperator - Class in io.prestosql.operator.scalar
 
MapIndeterminateOperator - Class in io.prestosql.operator.scalar
 
MapKeys - Class in io.prestosql.operator.scalar
 
MapNotEqualOperator - 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(List<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
 
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() - Constructor for class io.prestosql.operator.scalar.MapToMapCast
 
MapTransformKeyFunction - Class in io.prestosql.operator.scalar
 
MapTransformValueFunction - Class in io.prestosql.operator.scalar
 
MapUnionAggregation - Class in io.prestosql.operator.aggregation
 
MapUnionAggregation() - Constructor for class io.prestosql.operator.aggregation.MapUnionAggregation
 
MapUnnester - Class in io.prestosql.operator
 
MapUnnester(Type, Type) - Constructor for class io.prestosql.operator.MapUnnester
 
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>, JoinCompiler, UpdateMemory) - Constructor for class io.prestosql.operator.MarkDistinctHash
 
MarkDistinctHash(Session, List<Type>, int[], Optional<Integer>, int, JoinCompiler, 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) - 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) - Constructor for class io.prestosql.operator.MarkDistinctOperator.MarkDistinctOperatorFactory
 
markDistinctRows(Page) - Method in class io.prestosql.operator.MarkDistinctHash
 
match(SelectionCriteria) - Method in class io.prestosql.execution.resourcegroups.LegacyResourceGroupConfigurationManager
 
match(String, String) - Method in class io.prestosql.security.CatalogAccessControlRule
 
match(String, String) - Method in class io.prestosql.security.PrincipalUserMatchRule
 
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.
matches(QualifiedObjectName) - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
matches() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
matches(TestingAccessControlManager.TestingPrivilege) - Method in class io.prestosql.testing.TestingAccessControlManager.TestingPrivilege
 
matches(Slice) - Method in class io.prestosql.type.Re2JRegexp
 
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
 
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_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_BY_N_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.minmaxby.MaxByNAggregationFunction
 
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_N_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.MaxNAggregationFunction
 
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() - Constructor for class io.prestosql.operator.aggregation.minmaxby.MaxByNAggregationFunction
 
maxCombine(Type, BlockPositionState, BlockPositionState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
MaxDataSizeForStats - Class in io.prestosql.operator.aggregation
 
maxInput(Type, BlockPositionState, Block, int) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
MaxNAggregationFunction - Class in io.prestosql.operator.aggregation
 
MaxNAggregationFunction() - Constructor for class io.prestosql.operator.aggregation.MaxNAggregationFunction
 
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
 
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(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 - Class 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(SqlTaskIoStats) - Method in class io.prestosql.execution.SqlTaskIoStats
 
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 - Static variable in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
merge(MultimapAggregationState) - Method in interface io.prestosql.operator.aggregation.multimapagg.MultimapAggregationState
 
merge(DoubleHistogramAggregation.State, DoubleHistogramAggregation.State) - Static method in class io.prestosql.operator.aggregation.RealHistogramAggregation
 
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(Optional<T>, Optional<T>) - Static method in interface io.prestosql.util.Mergeable
 
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
 
MergeFilters - Class in io.prestosql.sql.planner.iterative.rule
 
MergeFilters() - 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) - Constructor for class io.prestosql.operator.MergeHashSort
 
MergeHyperLogLogAggregation - Class in io.prestosql.operator.aggregation
 
MergeLimits - Class in io.prestosql.sql.planner.iterative.rule
 
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
 
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
 
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<R>) - Method in class io.prestosql.memory.TraversingQueryContextVisitor
 
mergeResults(List<Void>) - Method in class io.prestosql.memory.VoidTraversingQueryContextVisitor
 
MergeSetDigestAggregation - Class in io.prestosql.type.setdigest
 
mergeSorted(Iterable<WorkProcessor<T>>, Comparator<T>) - Static method in interface io.prestosql.operator.WorkProcessor
 
MergeSortedPages - Class in io.prestosql.util
 
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.PageWithPosition - Class in io.prestosql.util
 
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) - Constructor for class io.prestosql.operator.aggregation.builder.MergingHashAggregationBuilder
 
MergingPageOutput - 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.
MergingPageOutput(Iterable<? extends Type>, long, int) - Constructor for class io.prestosql.operator.project.MergingPageOutput
 
MergingPageOutput(Iterable<? extends Type>, long, int, int) - Constructor for class io.prestosql.operator.project.MergingPageOutput
 
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
 
Metadata - Interface in io.prestosql.metadata
 
MetadataBasedSystemTablesProvider - Class in io.prestosql.connector.system
 
MetadataBasedSystemTablesProvider(Metadata, String) - Constructor for class io.prestosql.connector.system.MetadataBasedSystemTablesProvider
 
metadataDelete(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
Delete the provide table layout
metadataDelete(Session, TableHandle) - Method in class io.prestosql.metadata.MetadataManager
 
MetadataDeleteNode - Class in io.prestosql.sql.planner.plan
 
MetadataDeleteNode(PlanNodeId, TableWriterNode.DeleteHandle, Symbol) - Constructor for class io.prestosql.sql.planner.plan.MetadataDeleteNode
 
MetadataDeleteOperator - Class in io.prestosql.operator
 
MetadataDeleteOperator(OperatorContext, Metadata, Session, TableHandle) - Constructor for class io.prestosql.operator.MetadataDeleteOperator
 
MetadataDeleteOperator.MetadataDeleteOperatorFactory - Class in io.prestosql.operator
 
MetadataDeleteOperatorFactory(int, PlanNodeId, Metadata, Session, TableHandle) - Constructor for class io.prestosql.operator.MetadataDeleteOperator.MetadataDeleteOperatorFactory
 
MetadataDeleteOptimizer - Class in io.prestosql.sql.planner.optimizations
Converts delete followed immediately by table scan to a special metadata-only delete node
MetadataDeleteOptimizer(Metadata) - Constructor for class io.prestosql.sql.planner.optimizations.MetadataDeleteOptimizer
 
MetadataListing - Class in io.prestosql.metadata
 
MetadataManager - Class in io.prestosql.metadata
 
MetadataManager(FeaturesConfig, TypeManager, BlockEncodingSerde, SessionPropertyManager, SchemaPropertyManager, TablePropertyManager, ColumnPropertyManager, AnalyzePropertyManager, TransactionManager) - Constructor for class io.prestosql.metadata.MetadataManager
 
MetadataManager(FeaturesConfig, TypeManager, JsonCodec<ViewDefinition>, BlockEncodingSerde, SessionPropertyManager, SchemaPropertyManager, TablePropertyManager, ColumnPropertyManager, AnalyzePropertyManager, TransactionManager) - 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.SchemaMetadataBuilder - 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() - Method in class io.prestosql.metadata.FunctionInvoker
 
methodHandle(Class<?>, String, Class<?>...) - Static method in class io.prestosql.util.Reflection
Returns a MethodHandle corresponding to the specified method.
methodHandle(StandardErrorCode, Method) - 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
 
millisecondFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
millisecondFromTime(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
millisecondFromTimestamp(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
millisecondFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
millisecondFromTimeWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
min(double...) - Static method in class io.prestosql.util.MoreMath
 
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
 
MIN_BY_N_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.minmaxby.MinByNAggregationFunction
 
MIN_N_AGGREGATION - Static variable in class io.prestosql.operator.aggregation.MinNAggregationFunction
 
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() - Constructor for class io.prestosql.operator.aggregation.minmaxby.MinByNAggregationFunction
 
minCombine(Type, BlockPositionState, BlockPositionState) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
minInput(Type, BlockPositionState, Block, int) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
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(BlockComparator, Type, Type) - Constructor for class io.prestosql.operator.aggregation.minmaxby.MinMaxByNStateSerializer
 
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(BlockComparator, Type) - Constructor for class io.prestosql.operator.aggregation.state.MinMaxNStateSerializer
 
MinNAggregationFunction - Class in io.prestosql.operator.aggregation
 
MinNAggregationFunction() - Constructor for class io.prestosql.operator.aggregation.MinNAggregationFunction
 
minuteFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
minuteFromTime(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
minuteFromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
minuteFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
minuteFromTimeWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
missingAttributeException(Expression, QualifiedName) - Static method in class io.prestosql.sql.analyzer.SemanticExceptions
 
missingAttributeException(Expression) - Static method in class io.prestosql.sql.analyzer.SemanticExceptions
Deprecated.
mod(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
mod(double, double) - 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
 
modulo24Hour(ISOChronology, long) - Static method in class io.prestosql.type.DateTimeOperators
 
modulo24Hour(long) - Static method in class io.prestosql.type.DateTimeOperators
 
modulus(long, long) - Static method in class io.prestosql.type.BigintOperators
 
modulus(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
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
 
monthFromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
monthFromTimestampWithTimeZone(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, UpdateMemory) - Constructor for class io.prestosql.operator.MultiChannelGroupByHash
 
MultilevelSplitQueue - Class in io.prestosql.execution.executor
 
MultilevelSplitQueue(TaskManagerConfig) - Constructor for class io.prestosql.execution.executor.MultilevelSplitQueue
 
MultilevelSplitQueue(double) - Constructor for class io.prestosql.execution.executor.MultilevelSplitQueue
 
MultimapAggGroupImplementation - Enum in io.prestosql.operator.aggregation.multimapagg
 
MultimapAggregationFunction - Class in io.prestosql.operator.aggregation.multimapagg
 
MultimapAggregationFunction(MultimapAggGroupImplementation) - 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, MultimapAggGroupImplementation) - 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, 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
 
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(long, long) - Static method in class io.prestosql.type.BigintOperators
 
multiply(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
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
 

N

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(String) - Method in class io.prestosql.metadata.SignatureBuilder
 
NAME - Static variable in class io.prestosql.operator.aggregation.histogram.Histogram
 
name() - Method in class io.prestosql.operator.aggregation.InternalAggregationFunction
 
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.security.AllowAllSystemAccessControl
 
NAME - Static variable in class io.prestosql.security.FileBasedSystemAccessControl
 
NAME - Static variable in class io.prestosql.security.ReadOnlySystemAccessControl
 
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
 
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.AssignUniqueIdOperator
 
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.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.FilterAndProjectOperator
 
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.HashSemiJoinOperator
 
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.MetadataDeleteOperator
 
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.project.MergingPageOutput
 
needsInput() - Method in class io.prestosql.operator.RowNumberOperator
 
needsInput() - Method in class io.prestosql.operator.ScanFilterAndProjectOperator
 
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.StreamingAggregationOperator
 
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.UnnestOperator
 
needsInput() - Method in class io.prestosql.operator.ValuesOperator
 
needsInput() - Method in class io.prestosql.operator.WindowOperator
 
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(long) - Static method in class io.prestosql.type.BigintOperators
 
negate(long) - Static method in class io.prestosql.type.DecimalOperators.Negation
 
negate(Slice) - Static method in class io.prestosql.type.DecimalOperators.Negation
 
negate(double) - Static method in class io.prestosql.type.DoubleOperators
 
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
 
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>) - 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
 
NetworkLocationCache - Class in io.prestosql.execution.scheduler
 
NetworkLocationCache(NetworkTopology) - Constructor for class io.prestosql.execution.scheduler.NetworkLocationCache
 
NetworkTopology - Interface in io.prestosql.execution.scheduler
Implementations of this interface must be thread safe.
NetworkTopologyType() - Constructor for class io.prestosql.execution.scheduler.NodeSchedulerConfig.NetworkTopologyType
 
newAggregateSystemMemoryContext() - Method in class io.prestosql.operator.OperatorContext
 
newHashSymbol() - Method in class io.prestosql.sql.planner.SymbolAllocator
 
newHyperLogLog() - Static method in class io.prestosql.operator.aggregation.ApproximateSetAggregation
 
newInstance(PlanNodeId, TableHandle, List<Symbol>, Map<Symbol, ColumnHandle>) - Static method in class io.prestosql.sql.planner.plan.TableScanNode
 
newInstance(Slice) - Static method in class io.prestosql.type.setdigest.SetDigest
 
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) - Static method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
Obtains a SourceScheduler suitable for use in FixedSourcePartitionedScheduler.
newSourcePartitionedSchedulerAsStageScheduler(SqlStageExecution, PlanNodeId, SplitSource, SplitPlacementPolicy, int) - Static method in class io.prestosql.execution.scheduler.SourcePartitionedScheduler
Obtains an instance of SourcePartitionedScheduler suitable for use as a stage scheduler.
newSymbol(Symbol) - 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
 
newSymbol(Expression, Type) - Method in class io.prestosql.sql.planner.SymbolAllocator
 
newSymbol(Expression, Type, String) - Method in class io.prestosql.sql.planner.SymbolAllocator
 
newSymbol(Field) - Method in class io.prestosql.sql.planner.SymbolAllocator
 
NewTableLayout - Class in io.prestosql.metadata
 
NewTableLayout(ConnectorId, 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>) - Method in class io.prestosql.operator.window.AbstractWindowFunctionSupplier
Create window function instance using the supplied arguments.
newWindowFunction(List<Integer>) - 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
 
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_MORE_POSITIONS - Static variable in interface io.prestosql.operator.index.IndexedData
 
NoChannelGroupByHash - Class in io.prestosql.operator
 
NoChannelGroupByHash() - Constructor for class io.prestosql.operator.NoChannelGroupByHash
 
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, Node>, SetMultimap<InetAddress, Node>, SetMultimap<NetworkLocation, Node>, 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) - Constructor for class io.prestosql.sql.planner.NodePartitioningManager
 
NodePartitionMap - Class in io.prestosql.sql.planner
 
NodePartitionMap(List<Node>, ToIntFunction<Split>) - Constructor for class io.prestosql.sql.planner.NodePartitionMap
 
NodePartitionMap(List<Node>, int[], 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>, 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(NetworkTopology, InternalNodeManager, NodeSchedulerConfig, NodeTaskMap) - Constructor for class io.prestosql.execution.scheduler.NodeScheduler
 
NodeScheduler(NetworkLocationCache, NetworkTopology, InternalNodeManager, NodeSchedulerConfig, NodeTaskMap) - 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.NetworkTopologyType - Class in io.prestosql.execution.scheduler
 
NodeSchedulerExporter - Class in io.prestosql.execution.scheduler
 
NodeSchedulerExporter(NodeScheduler, MBeanExporter) - Constructor for class io.prestosql.execution.scheduler.NodeSchedulerExporter
 
NodeSelector - 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(Lifespan) - Method in class io.prestosql.operator.DriverFactory
 
noMoreDrivers() - 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.AssignUniqueIdOperator.AssignUniqueIdOperatorFactory
 
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.EnforceSingleRowOperator.EnforceSingleRowOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.exchange.LocalExchangeSinkOperator.LocalExchangeSinkOperatorFactory
 
noMoreOperators(Lifespan) - 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.FilterAndProjectOperator.FilterAndProjectOperatorFactory
 
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.HashSemiJoinOperator.HashSemiJoinOperatorFactory
 
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(Lifespan) - Method in class io.prestosql.operator.LookupJoinOperatorFactory
 
noMoreOperators(Lifespan) - Method in class io.prestosql.operator.LookupOuterOperator.LookupOuterOperatorFactory
 
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.MetadataDeleteOperator.MetadataDeleteOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.NestedLoopBuildOperator.NestedLoopBuildOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.NestedLoopJoinOperator.NestedLoopJoinOperatorFactory
 
noMoreOperators(Lifespan) - 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(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() - 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.StreamingAggregationOperator.StreamingAggregationOperatorFactory
 
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.TopNOperator.TopNOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.TopNRowNumberOperator.TopNRowNumberOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.operator.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.testing.NullOutputOperator.NullOutputOperatorFactory
 
noMoreOperators() - Method in class io.prestosql.testing.PageConsumerOperator.PageConsumerOperatorFactory
 
noMoreProbeOperators() - Method in class io.prestosql.operator.PagesSpatialIndexFactory
Called by SpatialJoinOperatorFactory to indicate that all SpatialJoinOperator have been created.
noMoreSinkFactories() - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeFactory
 
noMoreSinkFactories() - Method in class io.prestosql.operator.exchange.LocalExchange.LocalExchangeSinkFactory
 
noMoreSplits(PlanNodeId) - Method in interface io.prestosql.execution.RemoteTask
 
noMoreSplits(PlanNodeId, Lifespan) - Method in interface io.prestosql.execution.RemoteTask
 
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 class io.prestosql.operator.ScanFilterAndProjectOperator
 
noMoreSplits() - Method in interface io.prestosql.operator.SourceOperator
 
noMoreSplits() - Method in class io.prestosql.operator.TableScanOperator
 
noMoreSplits(PlanNodeId) - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
noMoreSplits(PlanNodeId, Lifespan) - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
NONE - Static variable in class io.prestosql.memory.MemoryManagerConfig.LowMemoryKillerPolicy
 
none() - Static method in class io.prestosql.sql.planner.optimizations.LocalProperties
 
NoneLowMemoryKiller - Class in io.prestosql.memory
 
NoneLowMemoryKiller() - Constructor for class io.prestosql.memory.NoneLowMemoryKiller
 
nonInferrableConjuncts(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(PlanNodeStatsEstimate, TypeProvider) - Method in class io.prestosql.cost.StatsNormalizer
 
normalize(PlanNodeStatsEstimate, Collection<Symbol>, TypeProvider) - Method in class io.prestosql.cost.StatsNormalizer
 
normalize(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
normalize(Expression) - Static method in class io.prestosql.sql.ExpressionUtils
 
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
noSpill() - Static method in class io.prestosql.operator.LookupJoinOperator.SpillInfoSnapshot
 
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
 
notEqual(MethodHandle, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayNotEqualOperator
 
notEqual(Slice, Slice) - Static method in class io.prestosql.operator.scalar.JsonOperators
 
notEqual(MethodHandle, MethodHandle, MethodHandle, Type, Type, Block, Block) - Static method in class io.prestosql.operator.scalar.MapNotEqualOperator
 
notEqual(RowType, List<MethodHandle>, Block, Block) - Static method in class io.prestosql.operator.scalar.RowNotEqualOperator
 
notEqual(long, long) - Static method in class io.prestosql.type.BigintOperators
 
notEqual(boolean, boolean) - Static method in class io.prestosql.type.BooleanOperators
 
notEqual(Slice, Slice) - Static method in class io.prestosql.type.CharOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.ColorOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.DateOperators
 
notEqual(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.IntegerOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.IntervalDayTimeOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.IntervalYearMonthOperators
 
notEqual(Slice, Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.RealOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.SmallintOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.TimeOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.TimestampOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
notEqual(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
notEqual(boolean, boolean) - Static method in class io.prestosql.type.UnknownOperators
 
notEqual(Slice, Slice) - Static method in class io.prestosql.type.VarbinaryOperators
 
notEqual(Slice, Slice) - Static method in class io.prestosql.type.VarcharOperators
 
notSignature() - Static method in class io.prestosql.sql.relational.Signatures
 
notSupportedException(Node, String) - Static method in class io.prestosql.sql.analyzer.SemanticExceptions
 
nowInMillis() - Method in class io.prestosql.execution.QueryIdGenerator
 
NthValueFunction - Class in io.prestosql.operator.window
 
NthValueFunction(List<Integer>) - 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 - Static variable in class io.prestosql.sql.relational.Signatures
 
NULL_VALUE - Static variable in interface io.prestosql.operator.aggregation.state.TriStateBooleanState
 
NullabilityAnalyzer - Class in io.prestosql.sql.planner
 
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.ChoiceBuilder
 
NullIfCodeGenerator - Class in io.prestosql.sql.gen
 
NullIfCodeGenerator() - Constructor for class io.prestosql.sql.gen.NullIfCodeGenerator
 
nullIfSignature(Type, Type, Type) - Static method in class io.prestosql.sql.relational.Signatures
 
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
 
numAggregatedQueuedQueries() - Method in class io.prestosql.server.ResourceGroupInfo
Deprecated.
numAggregatedRunningQueries() - Method in class io.prestosql.server.ResourceGroupInfo
Deprecated.
number() - Method in class io.prestosql.operator.PartitionedConsumption.Partition
 
NUMBER_OF_BUCKETS - Static variable in interface io.prestosql.operator.aggregation.state.HyperLogLogState
 
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

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
 
objectSubscript(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
of(double, double, double) - Static method in class io.prestosql.cost.LocalCostEstimate
 
of(T...) - Static method in class io.prestosql.operator.ParametricImplementationsGroup
 
of(T...) - Static method in interface io.prestosql.operator.WorkProcessor
 
of(Node) - Static method in class io.prestosql.sql.analyzer.RelationId
Creates RelationId equal to any RelationId created from exactly the same source.
of() - Static method in class io.prestosql.sql.planner.plan.Assignments
 
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
 
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.
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.
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
 
Operator - Interface in io.prestosql.operator
 
OperatorContext - Class in io.prestosql.operator
Only OperatorContext.getOperatorStats() and revocable-memory-related operations are ThreadSafe
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, TypeSignature, List<TypeSignature>, Optional<InvocationConvention>) - 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 TypeSignature>) - Constructor for exception io.prestosql.metadata.OperatorNotFoundException
 
OperatorNotFoundException(OperatorType, List<? extends TypeSignature>, 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, 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(SymbolResolver) - Method in class io.prestosql.sql.planner.ExpressionInterpreter
 
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.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.ImplementIntersectAndExceptAsUnion
 
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.MetadataDeleteOptimizer
 
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.SetFlatteningOptimizer
 
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.TransformQuantifiedComparisonApplyToLateralJoin
 
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(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
 
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(Expression...) - Static method in class io.prestosql.sql.ExpressionUtils
 
or(Collection<Expression>) - Static method in class io.prestosql.sql.ExpressionUtils
 
or(boolean, boolean) - Static method in class io.prestosql.sql.gen.CompilerOperations
 
OrCodeGenerator - Class in io.prestosql.sql.gen
 
OrCodeGenerator() - Constructor for class io.prestosql.sql.gen.OrCodeGenerator
 
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() - 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 - Class in io.prestosql.execution
 
Output(ConnectorId, String, String) - Constructor for class io.prestosql.execution.Output
 
output(ArrayType, MinMaxNState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
output(DigestAndPercentileState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
output(DigestAndPercentileArrayState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileArrayAggregations
 
output(DigestAndPercentileState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
output(DigestAndPercentileArrayState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileArrayAggregations
 
output(DigestAndPercentileState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
output(DigestAndPercentileArrayState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileArrayAggregations
 
output(Type, ArrayAggregationState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
output(LongAndDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.AverageAggregations
 
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(TriStateBooleanState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.BooleanAndAggregation
 
output(TriStateBooleanState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.BooleanOrAggregation
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
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(DoubleHistogramAggregation.State, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DoubleHistogramAggregation
 
output(NullableDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.DoubleSumAggregation
 
output(LongAndDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.GeometricMeanAggregations
 
output(Type, HistogramState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.histogram.Histogram
 
output(LongAndDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondAverageAggregation
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondSumAggregation
 
output(LongAndDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthAverageAggregation
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthSumAggregation
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.LongSumAggregation
 
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(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.MaxDataSizeForStats
 
output(HyperLogLogState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.MergeHyperLogLogAggregation
 
output(QuantileDigestStateSerializer, QuantileDigestState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
output(ArrayType, MinMaxByNState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
output(Type, Type, MultimapAggregationState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
output(LongState, DoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
output(LongAndDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealGeometricMeanAggregations
 
output(DoubleHistogramAggregation.State, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealHistogramAggregation
 
output(NullableDoubleState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.RealSumAggregation
 
output(NullableLongState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.SumDataSizeForStats
 
output() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
output(SetDigestState, BlockBuilder) - Static method in class io.prestosql.type.setdigest.BuildSetDigestAggregation
 
output(SetDigestState, BlockBuilder) - Static method in class io.prestosql.type.setdigest.MergeSetDigestAggregation
 
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
 
OutputExtractor - Class in io.prestosql.sql.planner
 
OutputExtractor() - Constructor for class io.prestosql.sql.planner.OutputExtractor
 
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(ConnectorId, ConnectorTransactionHandle, ConnectorOutputTableHandle) - Constructor for class io.prestosql.metadata.OutputTableHandle
 
OutputTableHandleJacksonModule - Class in io.prestosql.metadata
 
OutputTableHandleJacksonModule(HandleResolver) - Constructor for class io.prestosql.metadata.OutputTableHandleJacksonModule
 
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(int) - Constructor for class io.prestosql.operator.index.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
 
PageCompression - Enum 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, CompilerConfig) - Constructor for class io.prestosql.sql.gen.PageFunctionCompiler
 
PageFunctionCompiler(Metadata, int) - Constructor for class io.prestosql.sql.gen.PageFunctionCompiler
 
PageProcessor - Class in io.prestosql.operator.project
 
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
 
PageProcessor(Optional<PageFilter>, List<? extends PageProjection>) - 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
 
PageResponseHandler() - Constructor for class io.prestosql.operator.HttpPageBufferClient.PageResponseHandler
 
pages() - Method in class io.prestosql.operator.exchange.LocalExchangeSource
 
pages() - Method in class io.prestosql.operator.ExchangeClient
 
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
 
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() - 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>) - Constructor for class io.prestosql.execution.buffer.PagesSerde
 
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(String) - Constructor for exception io.prestosql.operator.PageTransportErrorException
 
PageTransportErrorException(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
 
PageWithPositionComparator - Interface in io.prestosql.operator
 
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(List<Expression>) - Constructor for class io.prestosql.sql.planner.ParameterRewriter
 
ParameterRewriter(List<Expression>, Analysis) - Constructor for class io.prestosql.sql.planner.ParameterRewriter
 
ParametricAggregation - Class in io.prestosql.operator.aggregation
 
ParametricAggregation(Signature, AggregationHeader, ParametricImplementationsGroup<AggregationImplementation>) - 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>) - 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(String) - Static method in class io.prestosql.server.JavaVersion
 
PARSE_DECIMAL_LITERALS_AS_DOUBLE - Static variable in class io.prestosql.SystemSessionProperties
 
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, AnnotatedElement) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
parseDescription(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, Method, Method, Optional<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
 
parseLiteralParameters(Method) - Static method in class io.prestosql.operator.annotations.FunctionsParserHelper
 
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
 
parseSignatureArgumentsTypes(Method) - Static method in class io.prestosql.operator.aggregation.AggregationImplementation.Parser
 
parseTimeLiteral(String) - Static method in class io.prestosql.util.DateTimeUtils
Parse a string (optionally containing a zone) as a value of either TIME or TIME WITH TIME ZONE type.
parseTimeLiteral(TimeZoneKey, String) - Static method in class io.prestosql.util.DateTimeUtils
Deprecated.
applicable in legacy timestamp semantics only
parseTimestampLiteral(String) - Static method in class io.prestosql.util.DateTimeUtils
Parse a string (optionally containing a zone) as a value of either TIMESTAMP or TIMESTAMP WITH TIME ZONE type.
parseTimestampLiteral(TimeZoneKey, String) - Static method in class io.prestosql.util.DateTimeUtils
Deprecated.
applicable in legacy timestamp semantics only
parseTimestampWithoutTimeZone(String) - Static method in class io.prestosql.util.DateTimeUtils
Parse a string (optionally containing a zone) as a value of TIMESTAMP type.
parseTimestampWithoutTimeZone(TimeZoneKey, String) - Static method in class io.prestosql.util.DateTimeUtils
Deprecated.
applicable in legacy timestamp semantics only
parseTimestampWithTimeZone(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.
parseTimeWithoutTimeZone(String) - Static method in class io.prestosql.util.DateTimeUtils
Parse a string (without a zone) as a value of TIME type.
parseTimeWithoutTimeZone(TimeZoneKey, String) - Static method in class io.prestosql.util.DateTimeUtils
Deprecated.
applicable in legacy timestamp semantics only
parseTimeWithTimeZone(String) - Static method in class io.prestosql.util.DateTimeUtils
Parse a string containing a zone as a value of TIME WITH TIME ZONE type.
parseYearMonthInterval(String, IntervalLiteral.IntervalField, Optional<IntervalLiteral.IntervalField>) - Static method in class io.prestosql.util.DateTimeUtils
 
ParsingUtil - Class in io.prestosql.sql
 
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
 
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.
PartitionedConsumption<T> - Class in io.prestosql.operator
 
PartitionedConsumption(int, Iterable<Integer>, IntFunction<ListenableFuture<T>>, IntConsumer) - Constructor for class io.prestosql.operator.PartitionedConsumption
 
PartitionedConsumption(int, ListenableFuture<?>, Iterable<Integer>, IntFunction<ListenableFuture<T>>, IntConsumer) - Constructor for class io.prestosql.operator.PartitionedConsumption
 
PartitionedConsumption.Partition<T> - Class in io.prestosql.operator
 
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
 
partitionedExchange(PlanNodeId, ExchangeNode.Scope, PlanNode, PartitioningScheme) - 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, Map<Symbol, Integer>, boolean) - 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<ConnectorId>, Optional<ConnectorTransactionHandle>, ConnectorPartitioningHandle) - Constructor for class io.prestosql.sql.planner.PartitioningHandle
 
PartitioningHandleJacksonModule - Class in io.prestosql.metadata
 
PartitioningHandleJacksonModule(HandleResolver) - Constructor for class io.prestosql.metadata.PartitioningHandleJacksonModule
 
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) - Constructor for class io.prestosql.server.security.PasswordAuthenticator
 
PasswordAuthenticatorManager - Class in io.prestosql.server.security
 
PasswordAuthenticatorManager() - Constructor for class io.prestosql.server.security.PasswordAuthenticatorManager
 
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.Exchange - Class in io.prestosql.sql.planner.plan
 
Patterns.Join - Class in io.prestosql.sql.planner.plan
 
Patterns.LateralJoin - 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.TopN - Class in io.prestosql.sql.planner.plan
 
Patterns.Values - Class in io.prestosql.sql.planner.plan
 
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
 
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, 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(SubPlan, Session) - Method in class io.prestosql.sql.planner.DistributedExecutionPlanner
 
plan(TaskContext, PlanNode, TypeProvider, PartitioningScheme, StageExecutionDescriptor, List<PlanNodeId>, OutputBuffer) - Method in class io.prestosql.sql.planner.LocalExecutionPlanner
 
plan(TaskContext, StageExecutionDescriptor, PlanNode, List<Symbol>, TypeProvider, List<PlanNodeId>, OutputFactory) - 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 - 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
 
PlanCostEstimate - Class in io.prestosql.cost
 
PlanCostEstimate(double, double, double, double) - 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
 
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(PlanNodeIdAllocator, 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
 
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, TypeAnalyzer, FeaturesConfig, NodeSchedulerConfig, InternalNodeManager, TaskManagerConfig, MBeanExporter, SplitManager, PageSourceManager, StatsCalculator, CostCalculator, CostCalculator, CostComparator, TaskCountEstimator) - Constructor for class io.prestosql.sql.planner.PlanOptimizers
 
PlanOptimizers(Metadata, TypeAnalyzer, FeaturesConfig, TaskManagerConfig, boolean, MBeanExporter, SplitManager, PageSourceManager, StatsCalculator, CostCalculator, CostCalculator, CostComparator, TaskCountEstimator) - 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, Metadata, ResourceGroupManager<?>, AccessControlManager, PasswordAuthenticatorManager, EventListenerManager, BlockEncodingManager, SessionPropertyDefaults, TypeRegistry) - 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.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(PagesHashStrategy, int, int) - Method in class io.prestosql.operator.PagesIndex
 
positionEqualsPosition(int, int, int, int) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
positionEqualsPosition(Type, Block, int, Block, int) - Static method in class io.prestosql.type.TypeUtils
 
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, int[]) - Method in interface io.prestosql.operator.PagesHashStrategy
Compares the hashed columns in this PagesHashStrategy to the hashed columns in the Page.
positionEqualsRow(PagesHashStrategy, int, int, Page) - Method in class io.prestosql.operator.PagesIndex
 
positionEqualsRow(int, int, int, Page) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
positionEqualsRow(int, int, int, Page, int[]) - Method in class io.prestosql.operator.SimplePagesHashStrategy
 
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
 
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
 
PreconditionRules - Class in io.prestosql.sql.planner.iterative.rule
 
PredicatePushDown - Class in io.prestosql.sql.planner.optimizations
 
PredicatePushDown(Metadata, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.optimizations.PredicatePushDown
 
preemptQuery(QueryId, String) - Method in class io.prestosql.server.QueryResource
 
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, FunctionRegistry) - Static method in class io.prestosql.sql.gen.LambdaBytecodeGenerator
 
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>) - Constructor for class io.prestosql.execution.QueryPreparer.PreparedQuery
 
prepareFinal() - Method in interface io.prestosql.operator.aggregation.GroupedAccumulator
 
prepareQuery(Session, String) - Method in class io.prestosql.execution.QueryPreparer
 
prepareQuery(Session, Statement) - Method in class io.prestosql.execution.QueryPreparer
 
PrepareTask - Class in io.prestosql.execution
 
PrepareTask(SqlParser) - Constructor for class io.prestosql.execution.PrepareTask
 
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
 
prependElement(Type, long, Block) - Static method in class io.prestosql.operator.scalar.ArrayConcatUtils
 
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
 
PRESTO_PAGES - Static variable in class io.prestosql.PrestoMediaTypes
 
PRESTO_PAGES_TYPE - Static variable in class io.prestosql.PrestoMediaTypes
 
PrestoMediaTypes - Class in io.prestosql
 
PrestoNode - Class in io.prestosql.metadata
A node is a server in a cluster than can process queries.
PrestoNode(String, URI, NodeVersion, boolean) - Constructor for class io.prestosql.metadata.PrestoNode
 
PrestoServer - Class in io.prestosql.server
 
PrestoServer() - Constructor for class io.prestosql.server.PrestoServer
 
PrestoServer(SqlParserOptions) - Constructor for class io.prestosql.server.PrestoServer
 
PRIME64 - Static variable in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
primitiveLongLong(Slice, Slice, MethodHandle) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
primitiveShortShort(long, long, MethodHandle) - Static method in class io.prestosql.type.DecimalInequalityOperators
 
PrincipalUserMatchRule - Class in io.prestosql.security
 
PrincipalUserMatchRule(Pattern, Optional<Pattern>, Optional<String>, boolean) - Constructor for class io.prestosql.security.PrincipalUserMatchRule
 
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
 
printTimestampWithoutTimeZone(long) - Static method in class io.prestosql.util.DateTimeUtils
 
printTimestampWithoutTimeZone(TimeZoneKey, long) - Static method in class io.prestosql.util.DateTimeUtils
Deprecated.
applicable in legacy timestamp semantics only
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 - 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
 
priority - Variable in class io.prestosql.execution.executor.TaskHandle
 
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
 
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.
probeOperatorFinished() - Method in class io.prestosql.operator.PagesSpatialIndexFactory
Called by SpatialJoinOperator on completion to signal that spatial index is no longer needed.
probeOuterJoin(int, PlanNodeId, JoinBridgeManager<? extends LookupSourceFactory>, List<Type>, List<Integer>, OptionalInt, Optional<List<Integer>>, OptionalInt, PartitioningSpillerFactory) - 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(TypeManager) - 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(Iterable<QueryExecution>, Supplier<List<BasicQueryInfo>>) - Method in class io.prestosql.memory.ClusterMemoryManager
 
process() - Method in class io.prestosql.operator.CompletedWork
 
process() - Method in class io.prestosql.operator.Driver
 
process(ConnectorSession, DriverYieldSignal, RecordCursor, PageBuilder) - Method in interface io.prestosql.operator.project.CursorProcessor
 
process(ConnectorSession, DriverYieldSignal, LocalMemoryContext, Page) - Method in class io.prestosql.operator.project.PageProcessor
 
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(Optional<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
 
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
 
processQueuedQueries() - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup.RootInternalResourceGroup
 
processRow(BlockBuilder, int, int, int, int) - Method in class io.prestosql.operator.window.AggregateWindowFunction
 
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, 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, 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
 
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
 
project() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
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
 
PropertiesUtil - Class in io.prestosql.util
 
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
 
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() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneCountAggregationOverScalar
 
PruneCrossJoinColumns - Class in io.prestosql.sql.planner.iterative.rule
Cross joins don't support output symbol selection, so push the project-off through the node.
PruneCrossJoinColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneCrossJoinColumns
 
PruneFilterColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneFilterColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneFilterColumns
 
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.execution.DataDefinitionExecution
 
pruneInfo() - Method in class io.prestosql.execution.FailedQueryExecution
 
pruneInfo() - Method in interface io.prestosql.execution.QueryTracker.TrackedQuery
 
pruneInfo() - Method in class io.prestosql.execution.SqlQueryExecution
 
PruneJoinChildrenColumns - Class in io.prestosql.sql.planner.iterative.rule
Non-Cross 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
Non-cross 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
 
PruneOrderByInAggregation - Class in io.prestosql.sql.planner.iterative.rule
 
PruneOrderByInAggregation(FunctionRegistry) - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneOrderByInAggregation
 
PruneOutputColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneOutputColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneOutputColumns
 
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
 
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
 
PruneTableScanColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneTableScanColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneTableScanColumns
 
PruneTopNColumns - Class in io.prestosql.sql.planner.iterative.rule
 
PruneTopNColumns() - Constructor for class io.prestosql.sql.planner.iterative.rule.PruneTopNColumns
 
PruneUnreferencedOutputs - Class in io.prestosql.sql.planner.optimizations
Removes all computation that does is not referenced transitively from the root of the plan
PruneUnreferencedOutputs() - 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
 
PUSH_AGGREGATION_THROUGH_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
 
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
 
pushDownNegations(Expression) - Static method in class io.prestosql.sql.planner.iterative.rule.PushDownNegationsExpressionRewriter
 
PushDownNegationsExpressionRewriter - Class in io.prestosql.sql.planner.iterative.rule
 
pushDownProjectOff(PlanNodeIdAllocator, N, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.ProjectOffPushDownRule
 
pushDownProjectOff(PlanNodeIdAllocator, AggregationNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneAggregationColumns
 
pushDownProjectOff(PlanNodeIdAllocator, JoinNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneCrossJoinColumns
 
pushDownProjectOff(PlanNodeIdAllocator, FilterNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneFilterColumns
 
pushDownProjectOff(PlanNodeIdAllocator, IndexSourceNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneIndexSourceColumns
 
pushDownProjectOff(PlanNodeIdAllocator, JoinNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneJoinColumns
 
pushDownProjectOff(PlanNodeIdAllocator, LimitNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneLimitColumns
 
pushDownProjectOff(PlanNodeIdAllocator, MarkDistinctNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneMarkDistinctColumns
 
pushDownProjectOff(PlanNodeIdAllocator, ProjectNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneProjectColumns
 
pushDownProjectOff(PlanNodeIdAllocator, SemiJoinNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneSemiJoinColumns
 
pushDownProjectOff(PlanNodeIdAllocator, TableScanNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneTableScanColumns
 
pushDownProjectOff(PlanNodeIdAllocator, TopNNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneTopNColumns
 
pushDownProjectOff(PlanNodeIdAllocator, ValuesNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneValuesColumns
 
pushDownProjectOff(PlanNodeIdAllocator, WindowNode, Set<Symbol>) - Method in class io.prestosql.sql.planner.iterative.rule.PruneWindowColumns
 
pushFilterIntoTableScan(TableScanNode, Expression, boolean, Session, TypeProvider, PlanNodeIdAllocator, Metadata, 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
 
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
 
PushPartialAggregationThroughExchange - Class in io.prestosql.sql.planner.iterative.rule
 
PushPartialAggregationThroughExchange(FunctionRegistry) - 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, TypeAnalyzer) - Constructor for class io.prestosql.sql.planner.iterative.rule.PushPredicateIntoTableScan
 
PushProjectionThroughExchange - Class in io.prestosql.sql.planner.iterative.rule
Transforms:
PushProjectionThroughExchange() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushProjectionThroughExchange
 
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
 
PushTableWriteThroughUnion - Class in io.prestosql.sql.planner.iterative.rule
 
PushTableWriteThroughUnion() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushTableWriteThroughUnion
 
PushTopNThroughUnion - Class in io.prestosql.sql.planner.iterative.rule
 
PushTopNThroughUnion() - Constructor for class io.prestosql.sql.planner.iterative.rule.PushTopNThroughUnion
 
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<Symbol, 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
 

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
 
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
 
quarterFromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
quarterFromTimestampWithTimeZone(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_CONFIG - Static variable in class io.prestosql.memory.NodeMemoryConfig
 
QUERY_MAX_RUN_TIME - 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_CONFIG - Static variable in class io.prestosql.memory.NodeMemoryConfig
 
QUERY_PRIORITY - Static variable in class io.prestosql.SystemSessionProperties
 
QUERY_STATE_LOG - Static variable in class io.prestosql.execution.QueryStateMachine
 
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.
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, AccessControl, SqlParser, StatsCalculator, CostCalculator, Map<Class<? extends Statement>, DataDefinitionTask<?>>) - Constructor for class io.prestosql.sql.analyzer.QueryExplainer
 
QueryExplainer(List<PlanOptimizer>, PlanFragmenter, Metadata, AccessControl, SqlParser, StatsCalculator, CostCalculator, Map<Class<? extends Statement>, DataDefinitionTask<?>>) - Constructor for class io.prestosql.sql.analyzer.QueryExplainer
 
queryFinished(QueryInfo) - Method in class io.prestosql.execution.SqlQueryManagerStats
 
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, 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>, boolean, Optional<ResourceGroupId>) - 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
 
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
 
queryQueued() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
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(QueryManager) - Constructor for class io.prestosql.server.QueryResource
 
QueryRunner - Interface in io.prestosql.testing
 
QueryRunner.MaterializedResultWithPlan - Class in io.prestosql.testing
 
queryRunnerWithFakeNodeCountForStats(Session, int) - Static method in class io.prestosql.testing.LocalQueryRunner
 
queryRunnerWithInitialTransaction(Session) - Static method in class io.prestosql.testing.LocalQueryRunner
 
QuerySessionSupplier - Class in io.prestosql.server
 
QuerySessionSupplier(TransactionManager, AccessControl, SessionPropertyManager, SqlEnvironmentConfig) - Constructor for class io.prestosql.server.QuerySessionSupplier
 
queryStarted() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
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(QueryManager, ResourceGroupManager<?>) - 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, boolean, Duration, Duration, Duration, boolean, Set<BlockedReason>, DataSize, long, DataSize, long, DataSize, long, DataSize, long, DataSize, long, DataSize, List<StageGcStatistics>, List<OperatorStats>) - Constructor for class io.prestosql.execution.QueryStats
 
queryStopped() - Method in class io.prestosql.execution.SqlQueryManagerStats
 
QuerySystemTable - Class in io.prestosql.connector.system
 
QuerySystemTable(QueryManager) - 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
 
queuedLeafSplits - Variable in class io.prestosql.execution.executor.TaskHandle
 

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
 
randomInteger(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
randomizedNodes(NodeMap, boolean, Set<Node>) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
randomSmallint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
randomTinyint(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
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
 
RawSliceSerializer - Class in io.prestosql.type
 
RawSliceSerializer() - Constructor for class io.prestosql.type.RawSliceSerializer
 
RE2J_REGEXP - Static variable in class io.prestosql.type.Re2JRegexpType
 
Re2JCastToRegexpFunction - Class in io.prestosql.operator.scalar
 
re2jPattern - Variable in class io.prestosql.type.Re2JRegexp
 
re2jPatternWithoutDotStartPrefix - Variable in class io.prestosql.type.Re2JRegexp
 
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() - Constructor for class io.prestosql.type.Re2JRegexpType
 
read(Block, int, long) - Method in interface io.prestosql.operator.aggregation.histogram.HistogramValueReader
 
READ_BLOCK - 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(SliceInput) - Method in class io.prestosql.block.BlockEncodingManager
 
readBlock(BlockEncodingSerde, Slice) - Static method in class io.prestosql.block.BlockSerdeUtil
 
readBlock(BlockEncodingSerde, SliceInput) - Static method in class io.prestosql.block.BlockSerdeUtil
 
readCommitted() - Method in class io.prestosql.transaction.TransactionBuilder
 
readOnly() - Method in class io.prestosql.transaction.TransactionBuilder
 
ReadOnlySystemAccessControl - Class in io.prestosql.security
 
ReadOnlySystemAccessControl() - Constructor for class io.prestosql.security.ReadOnlySystemAccessControl
 
ReadOnlySystemAccessControl.Factory - Class in io.prestosql.security
 
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
 
RealDistinctFromOperator() - Constructor for class io.prestosql.type.RealOperators.RealDistinctFromOperator
 
RealGeometricMeanAggregations - Class in io.prestosql.operator.aggregation
 
RealHistogramAggregation - Class in io.prestosql.operator.aggregation
 
RealOperators - Class in io.prestosql.type
 
RealOperators.RealDistinctFromOperator - 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
 
record(long, boolean) - Method in class io.prestosql.sql.planner.iterative.RuleStats
 
record(long) - Method in class io.prestosql.sql.planner.optimizations.OptimizerStats
 
record(PlanOptimizer, long) - Method in class io.prestosql.sql.planner.OptimizerStatsRecorder
 
record(Rule<?>, long, boolean) - Method in class io.prestosql.sql.planner.RuleStatsRecorder
 
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
 
recordFailure(Exception) - Method in class io.prestosql.failureDetector.HeartbeatFailureDetector.Stats
 
recordFailure() - Method in class io.prestosql.sql.planner.iterative.RuleStats
 
recordFailure() - Method in class io.prestosql.sql.planner.optimizations.OptimizerStats
 
recordFailure(PlanOptimizer) - Method in class io.prestosql.sql.planner.OptimizerStatsRecorder
 
recordFailure(Rule<?>) - Method in class io.prestosql.sql.planner.RuleStatsRecorder
 
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 class io.prestosql.execution.DataDefinitionExecution
 
recordHeartbeat() - Method in class io.prestosql.execution.FailedQueryExecution
 
recordHeartbeat() - Method in interface io.prestosql.execution.QueryExecution
 
recordHeartbeat(QueryId) - Method in interface io.prestosql.execution.QueryManager
Updates the client heartbeat time, to prevent the query from be automatically purged.
recordHeartbeat() - Method in class io.prestosql.execution.QueryStateMachine
 
recordHeartbeat() - Method in class io.prestosql.execution.SqlQueryExecution
 
recordHeartbeat(QueryId) - Method in class io.prestosql.execution.SqlQueryManager
 
recordHeartbeat() - Method in class io.prestosql.execution.SqlTask
 
recordIndexJoinLookup() - Method in class io.prestosql.operator.index.IndexJoinLookupStats
 
recordIntermediateSplit(PrioritizedSplitRunner) - Method in class io.prestosql.execution.executor.TaskHandle
 
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
 
redirectIndexHtml(String, UriInfo) - Method in class io.prestosql.server.WebUiResource
 
REDISTRIBUTE_WRITES - Static variable in class io.prestosql.SystemSessionProperties
 
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
 
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(String, Type, List<? extends Type>, Class<T>) - Constructor for class io.prestosql.operator.window.ReflectionWindowFunctionSupplier
 
ReflectionWindowFunctionSupplier(Signature, Class<T>) - Constructor for class io.prestosql.operator.window.ReflectionWindowFunctionSupplier
 
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
 
RegexLibrary - Enum in io.prestosql.sql.analyzer
 
regexpExtract(Slice, Regex) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpExtract(Slice, Regex, 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, Regex) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpExtractAll(Slice, Regex, 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, Regex) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpLike(Slice, Re2JRegexp) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
regexpReplace(Slice, Regex) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpReplace(Slice, Regex, Slice) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpReplace(Slice, Regex, 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, Regex) - Static method in class io.prestosql.operator.scalar.JoniRegexpFunctions
 
regexpSplit(Slice, Re2JRegexp) - Static method in class io.prestosql.operator.scalar.Re2JRegexpFunctions
 
register(Set<Rule<?>>) - Method in class io.prestosql.sql.planner.iterative.RuleIndex.Builder
 
register(Rule<?>) - Method in class io.prestosql.sql.planner.iterative.RuleIndex.Builder
 
register(PlanOptimizer) - Method in class io.prestosql.sql.planner.OptimizerStatsRecorder
 
register(C) - Method in class io.prestosql.util.AutoCloseableCloser
 
registerAll(Collection<Rule<?>>) - Method in class io.prestosql.sql.planner.RuleStatsRecorder
 
registerCatalog(Catalog) - Method in class io.prestosql.metadata.CatalogManager
 
registerNamedQuery(Table, Query) - Method in class io.prestosql.sql.analyzer.Analysis
 
registerTable(Table, TableHandle) - 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
 
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_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(Node, 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, List<PlanFragmentId>, List<Symbol>, Optional<OrderingScheme>, ExchangeNode.Type) - Constructor for class io.prestosql.sql.planner.plan.RemoteSourceNode
 
RemoteSourceNode(PlanNodeId, 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 - Class in io.prestosql.metadata
 
RemoteTransactionHandle() - Constructor for class io.prestosql.metadata.RemoteTransactionHandle
 
remove(PrioritizedSplitRunner) - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
remove(MethodHandle, Type, Block, long) - 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, boolean) - Method in class io.prestosql.operator.scalar.ArrayRemoveFunction
 
remove(MethodHandle, Type, Block, Object) - Method in class io.prestosql.operator.scalar.ArrayRemoveFunction
 
removeAll(Collection<PrioritizedSplitRunner>) - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
removeAll() - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
removeCatalog(String) - Method in class io.prestosql.metadata.CatalogManager
 
removeCatalogAccessControl(ConnectorId) - Method in class io.prestosql.security.AccessControlManager
 
removeConnectorPageSinkProvider(ConnectorId) - Method in class io.prestosql.split.PageSinkManager
 
removeConnectorPageSourceProvider(ConnectorId) - Method in class io.prestosql.split.PageSourceManager
 
removeConnectorSessionProperties(ConnectorId) - Method in class io.prestosql.metadata.SessionPropertyManager
 
removeConnectorSplitManager(ConnectorId) - Method in class io.prestosql.split.SplitManager
 
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(ConnectorId) - Method in class io.prestosql.index.IndexManager
 
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(ConnectorId) - Method in class io.prestosql.sql.planner.NodePartitioningManager
 
removePreparedStatement(String) - Method in class io.prestosql.execution.QueryStateMachine
 
removeProcedures(ConnectorId) - Method in class io.prestosql.metadata.ProcedureRegistry
 
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
 
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
 
RemoveUnreferencedScalarLateralNodes - Class in io.prestosql.sql.planner.iterative.rule
 
RemoveUnreferencedScalarLateralNodes() - Constructor for class io.prestosql.sql.planner.iterative.rule.RemoveUnreferencedScalarLateralNodes
 
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
 
render(Slice, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
render(long, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
render(double, long) - Static method in class io.prestosql.operator.scalar.ColorFunctions
 
render(boolean) - 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
 
REORDER_JOINS - Static variable in class io.prestosql.SystemSessionProperties
 
ReorderJoins - Class in io.prestosql.sql.planner.iterative.rule
 
ReorderJoins(CostComparator) - Constructor for class io.prestosql.sql.planner.iterative.rule.ReorderJoins
 
repeat(Boolean, long) - Static method in class io.prestosql.operator.scalar.RepeatFunction
 
repeat(Type, Object, 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, Slice, long) - Static method in class io.prestosql.operator.scalar.RepeatFunction
 
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
 
repeatableRead() - Method in class io.prestosql.transaction.TransactionBuilder
 
RepeatFunction - Class in io.prestosql.operator.scalar
 
replace(Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
replace(Slice, Slice, Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
replace(int, PlanNode, String) - Method in class io.prestosql.sql.planner.iterative.Memo
 
replace(Slice, Slice) - Method in class io.prestosql.type.Re2JRegexp
 
replaceAll(PlanNode) - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
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(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.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.LateralJoinNode
 
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.MetadataDeleteNode
 
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.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
 
replaceFirst(PlanNode) - Method in class io.prestosql.sql.planner.optimizations.PlanNodeSearcher
 
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
 
reserve(QueryId, String, long) - Method in class io.prestosql.memory.MemoryPool
Reserves the given number of bytes.
reserve(long) - Method in class io.prestosql.spiller.SpillSpaceTracker
Reserves the given number of bytes to spill.
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(WindowIndex) - Method in class io.prestosql.operator.window.AggregateWindowFunction
 
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
 
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
 
resetYieldForTesting() - Method in class io.prestosql.operator.DriverYieldSignal
 
resolve(ConnectorId, SchemaTableName) - Method in class io.prestosql.metadata.ProcedureRegistry
 
resolve(BoundVariables, TypeManager, FunctionRegistry) - Method in interface io.prestosql.operator.annotations.ImplementationDependency
 
resolve(BoundVariables, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.annotations.LiteralImplementationDependency
 
resolve(BoundVariables, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.annotations.ScalarImplementationDependency
 
resolve(BoundVariables, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.annotations.TypeImplementationDependency
 
resolve(String) - Method in class io.prestosql.server.testing.TestingPrestoServer
 
resolve(PlanNode) - Method in interface io.prestosql.sql.planner.iterative.Lookup
Deprecated.
resolve(GroupReference) - Method in class io.prestosql.sql.planner.iterative.Memo
 
ResolvedField - Class in io.prestosql.sql.analyzer
 
ResolvedField(Scope, Field, int, int, boolean) - Constructor for class io.prestosql.sql.analyzer.ResolvedField
 
ResolvedIndex - Class in io.prestosql.metadata
 
ResolvedIndex(ConnectorId, ConnectorTransactionHandle, ConnectorResolvedIndex) - Constructor for class io.prestosql.metadata.ResolvedIndex
 
resolveField(Expression, QualifiedName) - Method in class io.prestosql.sql.analyzer.Scope
 
resolveFieldEqualOperators(RowType, FunctionRegistry) - Static method in class io.prestosql.operator.scalar.RowEqualOperator
 
resolveFields(QualifiedName) - Method in class io.prestosql.sql.analyzer.RelationType
Gets the index of all columns matching the specified name
resolveFieldsWithPrefix(Optional<QualifiedName>) - Method in class io.prestosql.sql.analyzer.RelationType
This method is used for SELECT * or x.* queries
resolveFunction(QualifiedName, List<TypeSignatureProvider>) - Method in class io.prestosql.metadata.FunctionRegistry
 
resolveFunction(FunctionCall, List<TypeSignatureProvider>, FunctionRegistry) - Static method in class io.prestosql.sql.analyzer.ExpressionAnalyzer
 
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 class io.prestosql.metadata.FunctionRegistry
 
resolveOperator(OperatorType, List<? extends Type>) - Method in class io.prestosql.type.TypeRegistry
 
resolveType(TypeSignature, TypeManager) - Static method in class io.prestosql.type.TypeUtils
 
resolveTypes(List<TypeSignature>, TypeManager) - Static method in class io.prestosql.type.TypeUtils
 
RESOURCE_OVERCOMMIT - Static variable in class io.prestosql.SystemSessionProperties
 
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, int, int, int, List<ResourceGroupInfo>, 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
 
responseSize(long) - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
Result(RowExpression, InputChannels) - Constructor for class io.prestosql.operator.project.PageFieldsToInputParametersRewriter.Result
 
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
 
returnType(TypeSignature) - Method in class io.prestosql.metadata.SignatureBuilder
 
reverse(Type, Block) - Method in class io.prestosql.operator.scalar.ArrayReverseFunction
 
reverse(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
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
 
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(Expression, Map<NodeRef<Expression>, Type>) - Static method in class io.prestosql.sql.planner.DesugarAtTimeZoneRewriter
 
rewrite(Expression, Session, Metadata, TypeAnalyzer, SymbolAllocator) - Static method in class io.prestosql.sql.planner.DesugarAtTimeZoneRewriter
 
rewrite(Expression) - Static method in class io.prestosql.sql.planner.DesugarTryExpressionRewriter
 
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(ExpressionRewriter<C>) - Method in class io.prestosql.sql.planner.plan.Assignments
 
rewrite(Function<Expression, Expression>) - Method in class io.prestosql.sql.planner.plan.Assignments
 
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(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(Session, Metadata, SqlParser, Optional<QueryExplainer>, Statement, List<Expression>, AccessControl, WarningCollector) - Method in class io.prestosql.sql.rewrite.ShowStatsRewrite
 
rewrite(Session, Metadata, SqlParser, Optional<QueryExplainer>, Statement, List<Expression>, AccessControl, WarningCollector) - Static method in class io.prestosql.sql.rewrite.StatementRewrite
 
rewriteExpression(Expression, Predicate<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.
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
 
rewriteExpressionAllowNonDeterministic(Expression, Predicate<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.
rewriteGroupingOperation(GroupingOperation, List<Set<Integer>>, Map<NodeRef<Expression>, FieldId>, 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
 
rewriteScalarAggregation(LateralJoinNode, AggregationNode) - Method in class io.prestosql.sql.planner.optimizations.ScalarAggregationToJoinRewriter
 
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
 
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
 
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
 
RootInternalResourceGroup(String, BiConsumer<InternalResourceGroup, Boolean>, Executor) - Constructor for class io.prestosql.execution.resourcegroups.InternalResourceGroup.RootInternalResourceGroup
 
round(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
round(long, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
round(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
round(double, long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
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
 
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 - Static variable in class io.prestosql.sql.relational.Signatures
 
ROW_COUNT_CHANNEL - Static variable in class io.prestosql.operator.TableWriterOperator
 
ROW_DISTINCT_FROM - Static variable in class io.prestosql.operator.scalar.RowDistinctFromOperator
 
ROW_EQUAL - Static variable in class io.prestosql.operator.scalar.RowEqualOperator
 
ROW_GREATER_THAN - Static variable in class io.prestosql.operator.scalar.RowGreaterThanOperator
 
ROW_GREATER_THAN_OR_EQUAL - Static variable in class io.prestosql.operator.scalar.RowGreaterThanOrEqualOperator
 
ROW_HASH_CODE - Static variable in class io.prestosql.operator.scalar.RowHashCodeOperator
 
ROW_INDETERMINATE - Static variable in class io.prestosql.operator.scalar.RowIndeterminateOperator
 
ROW_LESS_THAN - Static variable in class io.prestosql.operator.scalar.RowLessThanOperator
 
ROW_LESS_THAN_OR_EQUAL - Static variable in class io.prestosql.operator.scalar.RowLessThanOrEqualOperator
 
ROW_NOT_EQUAL - Static variable in class io.prestosql.operator.scalar.RowNotEqualOperator
 
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
 
RowComparator - Class in io.prestosql.operator
 
RowComparator(List<Type>, List<Integer>, List<SortOrder>) - Constructor for class io.prestosql.operator.RowComparator
 
RowComparisonOperator - Class in io.prestosql.operator.scalar
 
RowComparisonOperator(OperatorType) - Constructor for class io.prestosql.operator.scalar.RowComparisonOperator
 
RowConstructorCodeGenerator - Class in io.prestosql.sql.gen
 
RowConstructorCodeGenerator() - Constructor for class io.prestosql.sql.gen.RowConstructorCodeGenerator
 
rowConstructorSignature(Type, List<Type>) - Static method in class io.prestosql.sql.relational.Signatures
 
RowDistinctFromOperator - Class in io.prestosql.operator.scalar
 
RowEqualOperator - Class in io.prestosql.operator.scalar
 
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
 
RowGreaterThanOperator - Class in io.prestosql.operator.scalar
 
RowGreaterThanOrEqualOperator - Class in io.prestosql.operator.scalar
 
RowHashCodeOperator - Class in io.prestosql.operator.scalar
 
RowIndeterminateOperator - Class in io.prestosql.operator.scalar
 
RowLessThanOperator - Class in io.prestosql.operator.scalar
 
RowLessThanOrEqualOperator - Class in io.prestosql.operator.scalar
 
RowNotEqualOperator - Class in io.prestosql.operator.scalar
 
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>, 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) - 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) - 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
 
rows() - Static method in class io.prestosql.sql.planner.plan.Patterns.Values
 
rows(List<MaterializedRow>) - Method in class io.prestosql.testing.MaterializedResult.Builder
 
rows(Object[][]) - 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.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.DesugarAtTimeZone
 
rules() - Method in class io.prestosql.sql.planner.iterative.rule.DesugarLambdaExpression
 
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
 
run(ManagedQueryExecution) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
run() - Method in class io.prestosql.server.PrestoServer
 
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
 
sanityCheck() - Method in class io.prestosql.sql.planner.SubPlan
 
saturatedFloorCastToFloat(double) - Static method in class io.prestosql.type.DoubleOperators
 
saturatedFloorCastToInteger(long) - Static method in class io.prestosql.type.BigintOperators
 
saturatedFloorCastToInteger(double) - Static method in class io.prestosql.type.DoubleOperators
 
saturatedFloorCastToSmallint(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.IntegerOperators
 
saturatedFloorCastToSmallint(long) - Static method in class io.prestosql.type.RealOperators
 
saturatedFloorCastToTinyint(long) - Static method in class io.prestosql.type.BigintOperators
 
saturatedFloorCastToTinyint(double) - Static method in class io.prestosql.type.DoubleOperators
 
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
 
ScalarAggregationToJoinRewriter - Class in io.prestosql.sql.planner.optimizations
 
ScalarAggregationToJoinRewriter(FunctionRegistry, SymbolAllocator, PlanNodeIdAllocator, Lookup) - Constructor for class io.prestosql.sql.planner.optimizations.ScalarAggregationToJoinRewriter
 
ScalarFromAnnotationsParser - Class in io.prestosql.operator.scalar.annotations
 
ScalarFunctionImplementation - Class in io.prestosql.operator.scalar
 
ScalarFunctionImplementation(boolean, List<ScalarFunctionImplementation.ArgumentProperty>, MethodHandle, boolean) - Constructor for class io.prestosql.operator.scalar.ScalarFunctionImplementation
 
ScalarFunctionImplementation(boolean, List<ScalarFunctionImplementation.ArgumentProperty>, MethodHandle, Optional<MethodHandle>, boolean) - Constructor for class io.prestosql.operator.scalar.ScalarFunctionImplementation
 
ScalarFunctionImplementation(List<ScalarFunctionImplementation.ScalarImplementationChoice>, boolean) - Constructor for class io.prestosql.operator.scalar.ScalarFunctionImplementation
Creates a ScalarFunctionImplementation consisting of one or more choices.
ScalarFunctionImplementation.ArgumentProperty - Class in io.prestosql.operator.scalar
 
ScalarFunctionImplementation.ArgumentType - Enum in io.prestosql.operator.scalar
 
ScalarFunctionImplementation.NullConvention - Enum in io.prestosql.operator.scalar
 
ScalarFunctionImplementation.ScalarImplementationChoice - Class 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(boolean, List<ScalarFunctionImplementation.ArgumentProperty>, MethodHandle, Optional<MethodHandle>) - Constructor for class io.prestosql.operator.scalar.ScalarFunctionImplementation.ScalarImplementationChoice
 
ScalarImplementationDependency - Class in io.prestosql.operator.annotations
 
ScalarImplementationDependency(Signature, Optional<InvocationConvention>) - 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) - 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
 
ScanFilterAndProjectOperator - Class in io.prestosql.operator
 
ScanFilterAndProjectOperator(OperatorContext, PlanNodeId, PageSourceProvider, CursorProcessor, PageProcessor, Iterable<ColumnHandle>, Iterable<Type>, MergingPageOutput) - Constructor for class io.prestosql.operator.ScanFilterAndProjectOperator
 
ScanFilterAndProjectOperator.ScanFilterAndProjectOperatorFactory - Class in io.prestosql.operator
 
ScanFilterAndProjectOperatorFactory(int, PlanNodeId, PlanNodeId, PageSourceProvider, Supplier<CursorProcessor>, Supplier<PageProcessor>, Iterable<ColumnHandle>, 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(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
 
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.
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(Node, Multimap<PlanNodeId, Split>, Multimap<PlanNodeId, Lifespan>) - Method in class io.prestosql.execution.SqlStageExecution
 
scheduleTask(Node, int, OptionalInt) - Method in interface io.prestosql.execution.scheduler.FixedCountScheduler.TaskScheduler
 
scheduleTask(Node, int, OptionalInt) - Method in class io.prestosql.execution.SqlStageExecution
 
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
 
SchemaMetadataBuilder() - Constructor for class io.prestosql.metadata.MetadataUtil.SchemaMetadataBuilder
 
schemaMetadataBuilder() - Static method in class io.prestosql.metadata.MetadataUtil.SchemaMetadataBuilder
 
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
 
Scope - Class in io.prestosql.sql.analyzer
 
scope() - Static method in class io.prestosql.sql.planner.plan.Patterns.Exchange
 
Scope.Builder - Class in io.prestosql.sql.analyzer
 
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
secondFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
secondFromTime(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
secondFromTimestamp(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
secondFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
secondFromTimeWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
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
 
SecurityConfig.AuthenticationType - Enum in io.prestosql.server.security
 
selectCurrentNode() - Method in interface io.prestosql.execution.scheduler.NodeSelector
 
selectCurrentNode() - Method in class io.prestosql.execution.scheduler.SimpleNodeSelector
 
selectCurrentNode() - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
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
 
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<Node>) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
selectRandomNodes(int) - Method in interface io.prestosql.execution.scheduler.NodeSelector
 
selectRandomNodes(int, Set<Node>) - Method in interface io.prestosql.execution.scheduler.NodeSelector
 
selectRandomNodes(int, Set<Node>) - Method in class io.prestosql.execution.scheduler.SimpleNodeSelector
 
selectRandomNodes(int, Set<Node>) - Method in class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
SemanticErrorCode - Enum in io.prestosql.sql.analyzer
 
SemanticException - Exception in io.prestosql.sql.analyzer
 
SemanticException(SemanticErrorCode, Node, String, Object...) - Constructor for exception io.prestosql.sql.analyzer.SemanticException
 
SemanticExceptions - Class in io.prestosql.sql.analyzer
 
semiJoin() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
SemiJoinNode - Class in io.prestosql.sql.planner.plan
 
SemiJoinNode(PlanNodeId, PlanNode, PlanNode, Symbol, Symbol, Symbol, Optional<Symbol>, Optional<Symbol>, Optional<SemiJoinNode.DistributionType>) - 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
 
sequence(long, long, long) - Static method in class io.prestosql.operator.scalar.SequenceFunction
 
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
 
sequenceTimestampDayToSecond(long, long, long) - Static method in class io.prestosql.operator.scalar.SequenceFunction
 
sequenceTimestampYearToMonth(ConnectorSession, long, long, long) - Static method in class io.prestosql.operator.scalar.SequenceFunction
 
serializable() - Method in class io.prestosql.transaction.TransactionBuilder
 
Serialization - Class in io.prestosql.sql
 
Serialization.ExpressionDeserializer - Class in io.prestosql.sql
 
Serialization.ExpressionSerializer - Class in io.prestosql.sql
 
Serialization.FunctionCallDeserializer - Class in io.prestosql.sql
 
serialize(Block, JsonGenerator, SerializerProvider) - Method in class io.prestosql.block.BlockJsonSerde.Serializer
 
serialize(Page) - Method in class io.prestosql.execution.buffer.PagesSerde
 
serialize(ArrayAggregationState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationStateSerializer
 
serialize(BlockBuilder) - Method in class io.prestosql.operator.aggregation.histogram.GroupedTypedHistogram
 
serialize(HistogramState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.histogram.HistogramStateSerializer
 
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(T, BlockBuilder) - Method in class io.prestosql.operator.aggregation.minmaxby.KeyAndBlockPositionValueStateSerializer
 
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() - Method in class io.prestosql.operator.aggregation.NumericHistogram
 
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(DigestAndPercentileArrayState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateSerializer
 
serialize(DigestAndPercentileState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateSerializer
 
serialize(DoubleHistogramAggregation.State, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.DoubleHistogramStateSerializer
 
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(QuantileDigestState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.QuantileDigestStateSerializer
 
serialize(TriStateBooleanState, BlockBuilder) - Method in class io.prestosql.operator.aggregation.state.TriStateBooleanStateSerializer
 
serialize(BlockBuilder) - Method in class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
serialize(Slice, JsonGenerator, SerializerProvider) - Method in class io.prestosql.server.SliceSerializer
 
serialize(ColumnStatisticMetadata, JsonGenerator, SerializerProvider) - Method in class io.prestosql.sql.planner.plan.StatisticAggregationsDescriptor.ColumnStatisticMetadataKeySerializer
 
serialize(Expression, JsonGenerator, SerializerProvider) - Method in class io.prestosql.sql.Serialization.ExpressionSerializer
 
serialize(Slice, JsonGenerator, SerializerProvider) - Method in class io.prestosql.type.RawSliceSerializer
 
serialize() - Method in class io.prestosql.type.setdigest.SetDigest
 
serialize(SetDigestState, BlockBuilder) - Method in class io.prestosql.type.setdigest.SetDigestStateSerializer
 
SerializedPage - Class in io.prestosql.execution.buffer
 
SerializedPage(Slice, PageCompression, int, int) - Constructor for class io.prestosql.execution.buffer.SerializedPage
 
Serializer(BlockEncodingSerde) - Constructor for class io.prestosql.block.BlockJsonSerde.Serializer
 
serializeSessionProperty(Type, Object) - Static method in class io.prestosql.metadata.SessionPropertyManager
 
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(SqlParserOptions) - 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
 
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, long, Map<String, String>, Map<ConnectorId, 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, Optional<String>, Optional<String>, Optional<String>, Optional<String>, SqlPath, Optional<String>, TimeZoneKey, Locale, Optional<String>, Optional<String>, Optional<String>, Set<String>, Set<String>, ResourceEstimates, long, Map<String, String>, Map<ConnectorId, 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(T) - Method in class io.prestosql.execution.StateMachine
Sets the state.
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(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_DIGEST - Static variable in class io.prestosql.type.setdigest.SetDigestType
 
setAcknowledgePages(boolean) - Method in class io.prestosql.operator.ExchangeClientConfig
 
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
 
setArrayAggGroupImplementation(ArrayAggGroupImplementation) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setAuthenticationTypes(List<SecurityConfig.AuthenticationType>) - Method in class io.prestosql.server.security.SecurityConfig
 
setAuthenticationTypes(String) - Method in class io.prestosql.server.security.SecurityConfig
 
setAverageRowSize(double) - Method in class io.prestosql.cost.SymbolStatsEstimate.Builder
 
setBlock(Block) - Method in interface io.prestosql.operator.aggregation.state.BlockPositionState
 
setBlock(Block) - Method in interface io.prestosql.operator.aggregation.state.BlockState
 
setBlock(Block) - Method in class io.prestosql.operator.ArrayOfRowsUnnester
 
setBlock(Block) - Method in class io.prestosql.operator.ArrayUnnester
 
setBlock(Block) - Method in class io.prestosql.operator.MapUnnester
 
setBlock(Block) - Method in interface io.prestosql.operator.Unnester
 
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) - 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) - 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.
setClientCapabilities(Set<String>) - Method in class io.prestosql.Session.SessionBuilder
 
setClientInfo(String) - Method in class io.prestosql.Session.SessionBuilder
 
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
 
setColocatedJoinsEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setColumn(Field, ColumnHandle) - Method in class io.prestosql.sql.analyzer.Analysis
 
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
 
setConfiguredEventListener(String, Map<String, String>) - Method in class io.prestosql.eventlistener.EventListenerManager
 
setContext(TaskContext) - Method in class io.prestosql.operator.index.IndexLoader
 
setCoordinator(boolean) - Method in class io.prestosql.server.ServerConfig
 
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
 
setCreateTableAsSelectNoOp(boolean) - Method in class io.prestosql.sql.analyzer.Analysis
 
setCreateTableAsSelectWithData(boolean) - Method in class io.prestosql.sql.analyzer.Analysis
 
setCreateTableColumnAliases(List<Identifier>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setCreateTableComment(Optional<String>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setCreateTableDestination(QualifiedObjectName) - Method in class io.prestosql.sql.analyzer.Analysis
 
setCreateTableProperties(Map<String, Expression>) - Method in class io.prestosql.sql.analyzer.Analysis
 
setDefaultFilterFactorEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setDictionaryAggregation(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setDigest(QuantileDigest) - Method in interface io.prestosql.operator.aggregation.state.DigestAndPercentileArrayState
 
setDigest(QuantileDigest) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.GroupedDigestAndPercentileArrayState
 
setDigest(QuantileDigest) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.SingleDigestAndPercentileArrayState
 
setDigest(QuantileDigest) - Method in interface io.prestosql.operator.aggregation.state.DigestAndPercentileState
 
setDigest(QuantileDigest) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.GroupedDigestAndPercentileState
 
setDigest(QuantileDigest) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.SingleDigestAndPercentileState
 
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
 
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
 
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
 
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
 
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
 
setEnableForcedExchangeBelowGroupId(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setEnableIntermediateAggregations(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setEnableStatsCalculator(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setEnhancedErrorReporting(boolean) - Method in class io.prestosql.server.ServerConfig
 
setExchangeCompressionEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setExecutionTime(Duration) - Method in class io.prestosql.Session.ResourceEstimateBuilder
 
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
 
setFastInequalityJoins(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setFilterAndProjectMinOutputPageRowCount(int) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setFilterAndProjectMinOutputPageSize(DataSize) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setFirst(Block) - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockAndBlockPositionValueState
 
setFirst(Block) - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockBooleanState
 
setFirst(Block) - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockDoubleState
 
setFirst(Block) - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockLongState
 
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(Slice) - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceAndBlockPositionValueState
 
setFirst(Slice) - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceBooleanState
 
setFirst(Slice) - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceDoubleState
 
setFirst(Slice) - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceLongState
 
setFirstNull(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.TwoNullableValueState
 
SetFlatteningOptimizer - Class in io.prestosql.sql.planner.optimizations
 
SetFlatteningOptimizer() - Constructor for class io.prestosql.sql.planner.optimizations.SetFlatteningOptimizer
 
setForceSingleNodeOutput(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setFunctionRegistry(FunctionRegistry) - Method in class io.prestosql.type.TypeRegistry
 
setGracePeriod(Duration) - Method in class io.prestosql.server.ServerConfig
 
setGroupByExpressions(QuerySpecification, List<Expression>) - Method in class io.prestosql.sql.analyzer.Analysis
 
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
 
setHistogramGroupImplementation(HistogramGroupImplementation) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
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(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.
setIgnoreStatsCalculatorFailures(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
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
 
setInitializationRequiredWorkers(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setInitializationTimeout(Duration) - 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
 
setInsert(Analysis.Insert) - Method in class io.prestosql.sql.analyzer.Analysis
 
setInstalledPluginsDir(File) - Method in class io.prestosql.server.PluginManagerConfig
 
setIterativeOptimizerEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setIterativeOptimizerTimeout(Duration) - 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
 
setKerberosConfig(File) - Method in class io.prestosql.server.security.KerberosConfig
 
setKerberosEnabled(boolean) - Method in class io.prestosql.server.InternalCommunicationConfig
 
setKerberosUseCanonicalHostname(boolean) - Method in class io.prestosql.server.InternalCommunicationConfig
 
setKeyFile(String) - Method in class io.prestosql.server.security.JsonWebTokenConfig
 
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
 
setLegacyTimestamp(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setLevelTimeMultiplier(BigDecimal) - Method in class io.prestosql.execution.TaskManagerConfig
 
setLocale(Locale) - Method in class io.prestosql.Session.SessionBuilder
 
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
 
setLongVariable(String, Long) - Method in class io.prestosql.metadata.BoundVariables.Builder
 
setLowMemoryKillerPolicy(String) - 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(List<String>) - Method in class io.prestosql.server.PluginManagerConfig
 
setMavenRemoteRepository(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
 
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
 
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(VersionedMemoryPoolId) - Method in class io.prestosql.execution.DataDefinitionExecution
 
setMemoryPool(VersionedMemoryPoolId) - Method in class io.prestosql.execution.FailedQueryExecution
 
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
 
setMemoryPool(MemoryPool) - Method in class io.prestosql.memory.QueryContext
 
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
 
setMultimapAggGroupImplementation(MultimapAggGroupImplementation) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setNetworkCostWeight(double) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setNetworkTopology(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
 
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
 
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
 
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
 
setOutputExpressions(Node, List<Expression>) - Method in class io.prestosql.sql.analyzer.Analysis
 
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.DigestAndPercentileState
 
setPercentile(double) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.GroupedDigestAndPercentileState
 
setPercentile(double) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.SingleDigestAndPercentileState
 
setPercentiles(List<Double>) - Method in interface io.prestosql.operator.aggregation.state.DigestAndPercentileArrayState
 
setPercentiles(List<Double>) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.GroupedDigestAndPercentileArrayState
 
setPercentiles(List<Double>) - Method in class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.SingleDigestAndPercentileArrayState
 
setPerOperatorCpuTimerEnabled(boolean) - Method in class io.prestosql.execution.TaskManagerConfig
 
setPlugins(List<String>) - Method in class io.prestosql.server.PluginManagerConfig
 
setPlugins(String) - Method in class io.prestosql.server.PluginManagerConfig
 
setPosition(int) - Method in interface io.prestosql.operator.aggregation.state.BlockPositionState
 
setPreferPartialAggregation(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setPreloadedWarnings(int) - Method in class io.prestosql.testing.TestingWarningCollectorConfig
 
setPrestoVersion(String) - Method in class io.prestosql.server.ServerConfig
 
setPrincipalHostname(String) - Method in class io.prestosql.server.security.KerberosConfig
 
setPushAggregationThroughJoin(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
 
setQueryMaxSpillPerNode(DataSize) - Method in class io.prestosql.spiller.NodeSpillConfig
 
setQueryMaxSpillSize(DataSize) - Method in class io.prestosql.testing.TestingTaskContext.Builder
 
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
 
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.PasswordAuthenticatorManager
 
setRequiredAudience(String) - Method in class io.prestosql.server.security.JsonWebTokenConfig
 
setRequiredIssuer(String) - Method in class io.prestosql.server.security.JsonWebTokenConfig
 
setRequiredWorkers(int) - Method in class io.prestosql.execution.QueryManagerConfig
 
setRequiredWorkersMaxWait(Duration) - Method in class io.prestosql.execution.QueryManagerConfig
 
setReservedPoolEnabled(boolean) - Method in class io.prestosql.memory.NodeMemoryConfig
 
setResourceEstimates(ResourceEstimates) - Method in class io.prestosql.Session.SessionBuilder
 
setResourceOvercommit() - Method in class io.prestosql.memory.QueryContext
 
SetRoleTask - Class in io.prestosql.execution
 
SetRoleTask() - Constructor for class io.prestosql.execution.SetRoleTask
 
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
 
setScope(Node, Scope) - Method in class io.prestosql.sql.analyzer.Analysis
 
setSecond(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockBooleanState
 
setSecond(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockDoubleState
 
setSecond(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.BlockLongState
 
setSecond(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanBooleanState
 
setSecond(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanDoubleState
 
setSecond(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.BooleanLongState
 
setSecond(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleBooleanState
 
setSecond(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleDoubleState
 
setSecond(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.DoubleLongState
 
setSecond(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.LongBooleanState
 
setSecond(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.LongDoubleState
 
setSecond(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.LongLongState
 
setSecond(boolean) - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceBooleanState
 
setSecond(double) - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceDoubleState
 
setSecond(long) - Method in interface io.prestosql.operator.aggregation.minmaxby.SliceLongState
 
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
 
setServiceName(String) - Method in class io.prestosql.server.security.KerberosConfig
 
SetSessionTask - Class in io.prestosql.execution
 
SetSessionTask() - Constructor for class io.prestosql.execution.SetSessionTask
 
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
 
setShareIndexLoading(boolean) - Method in class io.prestosql.execution.TaskManagerConfig
 
setSinkMaxBufferSize(DataSize) - Method in class io.prestosql.execution.TaskManagerConfig
 
setSlice(Slice) - Method in interface io.prestosql.operator.aggregation.state.SliceState
 
setSoftConcurrencyLimit(int) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setSoftCpuLimit(Duration) - Method in class io.prestosql.execution.resourcegroups.InternalResourceGroup
 
setSoftMemoryLimit(DataSize) - 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
 
setSpillEnabled(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
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
 
setStartedTransactionId(TransactionId) - Method in class io.prestosql.execution.QueryStateMachine
 
setStartTime(long) - Method in class io.prestosql.Session.SessionBuilder
 
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
 
setSystemProperty(String, String) - Method in class io.prestosql.Session.SessionBuilder
Sets a system property for the session.
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
 
setTimeZoneKey(TimeZoneKey) - Method in class io.prestosql.Session.SessionBuilder
 
setTraceToken(Optional<String>) - Method in class io.prestosql.Session.SessionBuilder
 
setTransactionId(TransactionId) - Method in class io.prestosql.Session.SessionBuilder
 
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
 
setTypeVariable(String, Type) - Method in class io.prestosql.metadata.BoundVariables.Builder
 
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.ServerSecurityModule
 
setup(Binder) - Method in class io.prestosql.server.ServerMainModule
 
setUpdateType(String) - Method in class io.prestosql.execution.QueryStateMachine
 
setUpdateType(String) - Method in class io.prestosql.sql.analyzer.Analysis
 
setUseMarkDistinct(boolean) - Method in class io.prestosql.sql.analyzer.FeaturesConfig
 
setUserAgent(String) - Method in class io.prestosql.Session.SessionBuilder
 
setVariableArity(boolean) - Method in class io.prestosql.metadata.SignatureBuilder
 
setWarmupInterval(Duration) - Method in class io.prestosql.failureDetector.FailureDetectorConfig
 
setWhere(Node, Expression) - Method in class io.prestosql.sql.analyzer.Analysis
 
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
 
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
 
shortToLongCast(long, long, long, long, long) - Static method in class io.prestosql.type.DecimalToDecimalCasts
 
shortToShortCast(long, long, long, long, long, long, long) - Static method in class io.prestosql.type.DecimalToDecimalCasts
 
shouldPushAggregationThroughJoin(Session) - Static method in class io.prestosql.SystemSessionProperties
 
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.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
 
sign(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
sign(double) - 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, FunctionKind, List<TypeVariableConstraint>, List<LongVariableConstraint>, TypeSignature, List<TypeSignature>, boolean) - Constructor for class io.prestosql.metadata.Signature
 
Signature(String, FunctionKind, TypeSignature, TypeSignature...) - Constructor for class io.prestosql.metadata.Signature
 
Signature(String, FunctionKind, TypeSignature, List<TypeSignature>) - 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(TypeManager, Signature, boolean) - Constructor for class io.prestosql.metadata.SignatureBinder
 
SignatureBuilder - Class in io.prestosql.metadata
 
SignatureBuilder() - Constructor for class io.prestosql.metadata.SignatureBuilder
 
Signatures - Class in io.prestosql.sql.relational
 
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
 
SimpleFilterProjectSemiJoinStatsRule - Class in io.prestosql.cost
It is not yet proven whether this heuristic is any better or worse.
SimpleFilterProjectSemiJoinStatsRule(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
 
SimpleNodeSelector - Class in io.prestosql.execution.scheduler
 
SimpleNodeSelector(InternalNodeManager, NodeTaskMap, boolean, Supplier<NodeMap>, int, int, int) - Constructor for class io.prestosql.execution.scheduler.SimpleNodeSelector
 
SimplePagesHashStrategy - Class in io.prestosql.operator
 
SimplePagesHashStrategy(List<Type>, List<Integer>, List<List<Block>>, List<Integer>, OptionalInt, Optional<Integer>, FunctionRegistry) - Constructor for class io.prestosql.operator.SimplePagesHashStrategy
 
SimplePagesIndexComparator - Class in io.prestosql.operator
 
SimplePagesIndexComparator(List<Type>, List<Integer>, List<SortOrder>) - Constructor for class io.prestosql.operator.SimplePagesIndexComparator
 
SimplePageWithPositionComparator - Class in io.prestosql.operator
 
SimplePageWithPositionComparator(List<Type>, List<Integer>, List<SortOrder>) - 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() - 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_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
 
SingleDigestAndPercentileArrayState() - Constructor for class io.prestosql.operator.aggregation.state.DigestAndPercentileArrayStateFactory.SingleDigestAndPercentileArrayState
 
SingleDigestAndPercentileState() - Constructor for class io.prestosql.operator.aggregation.state.DigestAndPercentileStateFactory.SingleDigestAndPercentileState
 
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, int) - Constructor for class io.prestosql.operator.aggregation.histogram.SingleHistogramState
 
SingleHyperLogLogState() - Constructor for class io.prestosql.operator.aggregation.state.HyperLogLogStateFactory.SingleHyperLogLogState
 
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
 
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
 
SingleTypedHistogram - Class in io.prestosql.operator.aggregation.histogram
 
SingleTypedHistogram(Type, int) - Constructor for class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
SingleTypedHistogram(Block, Type, int) - Constructor for class io.prestosql.operator.aggregation.histogram.SingleTypedHistogram
 
size() - Method in class io.prestosql.execution.buffer.BufferResult
 
size() - Method in class io.prestosql.execution.executor.MultilevelSplitQueue
 
SIZE - Static variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowAndLongStateFactory.SingleLongDecimalWithOverflowAndLongState
 
SIZE - Static variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
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.gen.CacheStatsMBean
 
size() - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
size() - Method in class io.prestosql.sql.planner.plan.Assignments
 
skewness(CentralMomentsState, BlockBuilder) - Static method in class io.prestosql.operator.aggregation.CentralMomentsAggregation
 
slice(Type, Block, long, long) - Static method in class io.prestosql.operator.scalar.ArraySliceFunction
 
SliceAndBlockPositionValueState - Interface in io.prestosql.operator.aggregation.minmaxby
 
sliceArrayMax(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMaxFunction
 
sliceArrayMin(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMinFunction
 
sliceArrayMinMax(MethodHandle, Type, Block) - Static method in class io.prestosql.operator.scalar.ArrayMinMaxUtils
 
SliceBooleanState - Interface in io.prestosql.operator.aggregation.minmaxby
 
SliceDeserializer - Class in io.prestosql.server
 
SliceDeserializer() - Constructor for class io.prestosql.server.SliceDeserializer
 
SliceDoubleState - Interface in io.prestosql.operator.aggregation.minmaxby
 
sliceElementAt(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArrayElementAtFunction
 
SliceLongState - Interface in io.prestosql.operator.aggregation.minmaxby
 
SliceSerializer - Class in io.prestosql.server
 
SliceSerializer() - Constructor for class io.prestosql.server.SliceSerializer
 
SliceState - Interface in io.prestosql.operator.aggregation.state
 
sliceSubscript(Type, Block, long) - Static method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
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
 
SmallintDistinctFromOperator() - Constructor for class io.prestosql.type.SmallintOperators.SmallintDistinctFromOperator
 
SmallintOperators - Class in io.prestosql.type
 
SmallintOperators.SmallintDistinctFromOperator - 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(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
 
sort(PagesIndex, int, int) - Method in class io.prestosql.operator.PagesIndexOrdering
 
sort(MethodHandle, 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() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
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.
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) - Constructor for class io.prestosql.sql.planner.plan.SortNode
 
sortObject(Type, Block, ArraySortComparatorFunction.ComparatorBlockLambda) - Method in class io.prestosql.operator.scalar.ArraySortComparatorFunction
 
sortSlice(Type, Block, ArraySortComparatorFunction.ComparatorSliceLambda) - 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
 
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
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) - 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
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.metadata.SqlAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.metadata.SqlScalarFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.AbstractMinMaxAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.AbstractMinMaxNAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.ArbitraryAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.arrayagg.ArrayAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.ChecksumAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.CountColumn
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.DecimalAverageAggregation
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.DecimalSumAggregation
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.histogram.Histogram
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.MapAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.MapUnionAggregation
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.MergeQuantileDigestFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxBy
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.minmaxby.AbstractMinMaxByNAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.multimapagg.MultimapAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.ParametricAggregation
 
specialize(BoundVariables, int, TypeManager) - Method in class io.prestosql.operator.aggregation.ParametricAggregation
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.QuantileDigestAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.RealAverageAggregation
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.aggregation.ReduceAggregationFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.AbstractGreatestLeast
 
specialize(Signature, BoundVariables, TypeManager, FunctionRegistry, boolean) - Method in class io.prestosql.operator.scalar.annotations.ParametricScalarImplementation
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ApplyFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArrayConcatFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArrayConstructor
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArrayFlattenFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArrayJoin.ArrayJoinWithNullReplacement
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArrayJoin
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArrayReduceFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArraySubscriptOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArrayToArrayCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArrayToElementConcatFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArrayToJsonCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ArrayTransformFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.CastFromUnknownOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ConcatFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ElementToArrayConcatFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.IdentityCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.InvokeFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.JsonStringToArrayCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.JsonStringToMapCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.JsonStringToRowCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.JsonToArrayCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.JsonToMapCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.JsonToRowCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapConcatFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapConstructor
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapElementAtFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapFilterFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapHashCodeOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapToJsonCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapToMapCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapTransformKeyFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapTransformValueFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.MapZipWithFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ParametricScalar
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.Re2JCastToRegexpFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowDistinctFromOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowEqualOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowGreaterThanOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowGreaterThanOrEqualOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowHashCodeOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowIndeterminateOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowLessThanOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowLessThanOrEqualOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowNotEqualOperator
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowToJsonCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.RowToRowCast
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.TryCastFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ZipFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.scalar.ZipWithFunction
 
specialize(BoundVariables, int, TypeManager, FunctionRegistry) - Method in class io.prestosql.operator.window.SqlWindowFunction
 
SpecializedFunctionKey - Class in io.prestosql.metadata
 
SpecializedFunctionKey(SqlFunction, BoundVariables, int) - Constructor for class io.prestosql.metadata.SpecializedFunctionKey
 
Specification(List<Symbol>, Optional<OrderingScheme>) - Constructor for class io.prestosql.sql.planner.plan.WindowNode.Specification
 
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(Page) - Method in interface io.prestosql.spiller.SingleStreamSpiller
Initiate spilling of single page.
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) - Constructor for class io.prestosql.operator.aggregation.builder.SpillableHashAggregationBuilder
 
SpillContext - Interface in io.prestosql.operator
 
spillEpoch() - Method in interface io.prestosql.operator.LookupSourceProvider.LookupSourceLease
 
Spiller - Interface in io.prestosql.spiller
 
SpillerFactory - Interface in io.prestosql.spiller
 
SpillerStats - Class in io.prestosql.spiller
 
SpillerStats() - Constructor for class io.prestosql.spiller.SpillerStats
 
SpillInfoSnapshot(boolean, long, IntPredicate) - Constructor for class io.prestosql.operator.LookupJoinOperator.SpillInfoSnapshot
 
SpillSpaceTracker - Class in io.prestosql.spiller
 
SpillSpaceTracker(DataSize) - Constructor for class io.prestosql.spiller.SpillSpaceTracker
 
Split - Class in io.prestosql.metadata
 
Split(ConnectorId, ConnectorTransactionHandle, ConnectorSplit) - Constructor for class io.prestosql.metadata.Split
 
Split(ConnectorId, ConnectorTransactionHandle, ConnectorSplit, Lifespan) - Constructor for class io.prestosql.metadata.Split
 
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(Slice) - Method in class io.prestosql.type.Re2JRegexp
 
SPLIT_CONCURRENCY_ADJUSTMENT_INTERVAL - Static variable in class io.prestosql.SystemSessionProperties
 
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
 
SplitJacksonModule - Class in io.prestosql.metadata
 
SplitJacksonModule(HandleResolver) - Constructor for class io.prestosql.metadata.SplitJacksonModule
 
SplitManager - Class in io.prestosql.split
 
SplitManager(QueryManagerConfig, Metadata) - Constructor for class io.prestosql.split.SplitManager
 
SplitMonitor - Class in io.prestosql.event
 
SplitMonitor(EventListenerManager, ObjectMapper) - Constructor for class io.prestosql.event.SplitMonitor
 
SplitOperatorInfo - Class in io.prestosql.operator
 
SplitOperatorInfo(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<Node, 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(String, List<TypeVariableConstraint>, List<LongVariableConstraint>, TypeSignature, List<TypeSignature>) - Constructor for class io.prestosql.metadata.SqlAggregationFunction
 
SqlAggregationFunction(String, List<TypeVariableConstraint>, List<LongVariableConstraint>, TypeSignature, List<TypeSignature>, FunctionKind) - Constructor for class io.prestosql.metadata.SqlAggregationFunction
 
SqlAggregationFunction(Signature, boolean) - Constructor for class io.prestosql.metadata.SqlAggregationFunction
 
SqlEnvironmentConfig - Class in io.prestosql.sql
 
SqlEnvironmentConfig() - Constructor for class io.prestosql.sql.SqlEnvironmentConfig
 
SqlFormatterUtil - Class in io.prestosql.sql
 
SqlFunction - Interface in io.prestosql.metadata
 
SqlIntervalDayTime - Class in io.prestosql.type
 
SqlIntervalDayTime(long) - Constructor for class io.prestosql.type.SqlIntervalDayTime
 
SqlIntervalDayTime(int, int, int, int, int) - 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>) - 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(QueryPreparer, EmbedVersion, NodeSchedulerConfig, QueryManagerConfig, SqlEnvironmentConfig, QueryMonitor, ResourceGroupManager<?>, ClusterMemoryManager, LocationFactory, TransactionManager, AccessControl, QueryIdGenerator, SessionSupplier, SessionPropertyDefaults, ClusterSizeMonitor, Map<Class<? extends Statement>, QueryExecution.QueryExecutionFactory<?>>, WarningCollectorFactory) - Constructor for class io.prestosql.execution.SqlQueryManager
 
SqlQueryManagerStats - Class in io.prestosql.execution
 
SqlQueryManagerStats() - Constructor for class io.prestosql.execution.SqlQueryManagerStats
 
SqlQueryScheduler - Class in io.prestosql.execution.scheduler
 
SqlScalarFunction - Class in io.prestosql.metadata
 
SqlScalarFunction(Signature) - 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, Session) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimeOf(LocalTime, Session) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimestampOf(int, int, int, int, int, int, int, Session) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimestampOf(int, int, int, int, int, int, int, DateTimeZone, TimeZoneKey, ConnectorSession) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimestampOf(LocalDateTime) - Static method in class io.prestosql.testing.DateTimeTestingUtils
Constructs standard (non-legacy) TIMESTAMP value corresponding to argument
sqlTimestampOf(DateTime, Session) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
sqlTimestampOf(long, ConnectorSession) - Static method in class io.prestosql.testing.DateTimeTestingUtils
 
SqlToRowExpressionTranslator - Class in io.prestosql.sql.relational
 
SqlTypeBytecodeExpression - Class in io.prestosql.sql.gen
 
SqlWindowFunction - Class in io.prestosql.operator.window
 
SqlWindowFunction(WindowFunctionSupplier) - 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
 
StageExecutionDescriptor - Class in io.prestosql.operator
 
StageExecutionPlan - Class in io.prestosql.sql.planner
 
StageExecutionPlan(PlanFragment, Map<PlanNodeId, SplitSource>, List<StageExecutionPlan>) - Constructor for class io.prestosql.sql.planner.StageExecutionPlan
 
StageId - Class in io.prestosql.execution
 
StageId(String, int) - Constructor for class io.prestosql.execution.StageId
 
StageId(QueryId, int) - Constructor for class io.prestosql.execution.StageId
 
StageInfo - Class in io.prestosql.execution
 
StageInfo(StageId, StageState, URI, PlanFragment, List<Type>, StageStats, List<TaskInfo>, List<StageInfo>, ExecutionFailureInfo) - Constructor for class io.prestosql.execution.StageInfo
 
StageResource - Class in io.prestosql.server
 
StageResource(QueryManager) - Constructor for class io.prestosql.server.StageResource
 
StageScheduler - Interface in io.prestosql.execution.scheduler
 
StageState - Enum in io.prestosql.execution
 
StageStateMachine - Class in io.prestosql.execution
 
StageStateMachine(StageId, URI, Session, PlanFragment, 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, DataSize, long, DataSize, long, DataSize, long, DataSize, DataSize, long, DataSize, StageGcStatistics, List<OperatorStats>) - Constructor for class io.prestosql.execution.StageStats
 
StandardJoinFilterFunction - Class in io.prestosql.operator
 
StandardJoinFilterFunction(InternalJoinFilterFunction, LongArrayList, List<Page>) - Constructor for class io.prestosql.operator.StandardJoinFilterFunction
 
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.FailedQueryExecution
 
start() - Method in interface io.prestosql.execution.ManagedQueryExecution
 
start() - Method in class io.prestosql.execution.MemoryRevokingScheduler
 
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(int, int, Page) - Method in class io.prestosql.operator.ArrayPositionLinks
 
start() - Method in class io.prestosql.operator.PipelineContext
 
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() - 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.sql.gen.ExpressionProfiler
 
start() - Method in class io.prestosql.util.FinalizerService
 
STARTING_VERSION - Static variable in class io.prestosql.execution.TaskStatus
The first valid version that will be returned for a 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
 
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
 
StartTransactionTask - Class in io.prestosql.execution
 
StartTransactionTask() - Constructor for class io.prestosql.execution.StartTransactionTask
 
startupComplete() - Method in class io.prestosql.server.ServerInfoResource
 
State(MapType) - Constructor for class io.prestosql.operator.scalar.MapConstructor.State
 
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
 
StatementResource - Class in io.prestosql.server.protocol
 
StatementResource(QueryManager, SessionPropertyManager, ExchangeClientSupplier, BlockEncodingSerde, BoundedExecutor, ScheduledExecutorService) - Constructor for class io.prestosql.server.protocol.StatementResource
 
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
 
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 - Class in io.prestosql.cost
 
StatisticRange(double, double, double) - Constructor for class io.prestosql.cost.StatisticRange
 
statisticRange() - Method in class io.prestosql.cost.SymbolStatsEstimate
 
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
 
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.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.scheduler.NetworkLocationCache
 
stop() - Method in class io.prestosql.execution.scheduler.NodeScheduler
 
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.HttpRemoteTaskFactory
 
stop() - Method in class io.prestosql.server.protocol.StatementResource
 
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
 
streamBackdoorDeriveProperties(PlanNode, List<ActualProperties>, Metadata, 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
 
StreamingAggregationOperator(OperatorContext, List<Type>, List<Type>, List<Integer>, AggregationNode.Step, List<AccumulatorFactory>, JoinCompiler) - Constructor for class io.prestosql.operator.StreamingAggregationOperator
 
StreamingAggregationOperator.StreamingAggregationOperatorFactory - Class in io.prestosql.operator
 
StreamingAggregationOperatorFactory(int, PlanNodeId, List<Type>, List<Type>, List<Integer>, AggregationNode.Step, List<AccumulatorFactory>, JoinCompiler) - Constructor for class io.prestosql.operator.StreamingAggregationOperator.StreamingAggregationOperatorFactory
 
StreamingIndexedData - Class in io.prestosql.operator.index
 
StreamingIndexedData(List<Type>, List<Type>, 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
 
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
 
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<Void>, Executor) - Method in class io.prestosql.execution.resourcegroups.NoOpResourceGroupManager
 
submit(ManagedQueryExecution, SelectionContext<C>, Executor) - Method in interface io.prestosql.execution.resourcegroups.ResourceGroupManager
 
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.LateralJoin
 
subRange(int, int) - Method in class io.prestosql.operator.project.SelectedPositions
 
subscript(InterpretedFunctionInvoker, Type, Type, ConnectorSession, Block, boolean) - Static method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
subscript(InterpretedFunctionInvoker, Type, Type, ConnectorSession, Block, long) - Static method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
subscript(InterpretedFunctionInvoker, Type, Type, ConnectorSession, Block, double) - Static method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
subscript(InterpretedFunctionInvoker, Type, Type, ConnectorSession, Block, Slice) - Static method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
subscript(InterpretedFunctionInvoker, Type, Type, ConnectorSession, Block, Object) - Static method in class io.prestosql.operator.scalar.MapSubscriptOperator
 
subscriptSignature(Type, Type, Type) - Static method in class io.prestosql.sql.relational.Signatures
 
substr(Slice, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
substr(Slice, long, long) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
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
 
subtract(long, long) - Static method in class io.prestosql.type.BigintOperators
 
subtract(double, double) - Static method in class io.prestosql.type.DoubleOperators
 
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.TimeOperators
 
subtract(long, long) - Static method in class io.prestosql.type.TimestampOperators
 
subtract(long, long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
subtract(long, long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
subtract(long, long) - Static method in class io.prestosql.type.TinyintOperators
 
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(T) - Method in interface io.prestosql.server.remotetask.SimpleHttpResponseCallback
 
success(TaskInfo) - Method in class io.prestosql.server.remotetask.TaskInfoFetcher
 
sum(NullableDoubleState, double) - Static method in class io.prestosql.operator.aggregation.DoubleSumAggregation
 
sum(NullableLongState, long) - Static method in class io.prestosql.operator.aggregation.IntervalDayToSecondSumAggregation
 
sum(NullableLongState, long) - Static method in class io.prestosql.operator.aggregation.IntervalYearToMonthSumAggregation
 
sum(NullableLongState, long) - Static method in class io.prestosql.operator.aggregation.LongSumAggregation
 
sum(NullableDoubleState, long) - Static method in class io.prestosql.operator.aggregation.RealSumAggregation
 
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
 
SUPPORTED_PARAMETER_TYPES - Static variable in class io.prestosql.operator.aggregation.AggregationMetadata
 
supportsMetadataDelete(Session, TableHandle) - Method in interface io.prestosql.metadata.Metadata
 
supportsMetadataDelete(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 - Static variable in class io.prestosql.sql.relational.Signatures
 
SwitchCodeGenerator - Class in io.prestosql.sql.gen
 
SwitchCodeGenerator() - Constructor for class io.prestosql.sql.gen.SwitchCodeGenerator
 
switchSignature(Type) - Static method in class io.prestosql.sql.relational.Signatures
 
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 - Class in io.prestosql.sql.planner.optimizations
 
SymbolMapper(Map<Symbol, Symbol>) - Constructor for class io.prestosql.sql.planner.optimizations.SymbolMapper
 
SymbolMapper.Builder - Class in io.prestosql.sql.planner.optimizations
 
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.
SystemColumnHandle - Class in io.prestosql.connector.system
 
SystemColumnHandle(ConnectorId, String) - Constructor for class io.prestosql.connector.system.SystemColumnHandle
 
SystemConnector - Class in io.prestosql.connector.system
 
SystemConnector(ConnectorId, InternalNodeManager, Set<SystemTable>, Function<TransactionId, ConnectorTransactionHandle>) - Constructor for class io.prestosql.connector.system.SystemConnector
 
SystemConnector(ConnectorId, InternalNodeManager, SystemTablesProvider, 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
 
SystemConnectorSessionUtil - Class in io.prestosql.connector.system
 
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) - Constructor for class io.prestosql.SystemSessionProperties
 
SystemSplit - Class in io.prestosql.connector.system
 
SystemSplit(ConnectorId, SystemTableHandle, HostAddress, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.connector.system.SystemSplit
 
SystemSplit(ConnectorId, SystemTableHandle, 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(ConnectorId, String, String) - Constructor for class io.prestosql.connector.system.SystemTableHandle
 
SystemTableLayoutHandle - Class in io.prestosql.connector.system
 
SystemTableLayoutHandle(ConnectorId, SystemTableHandle, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.connector.system.SystemTableLayoutHandle
 
SystemTablesMetadata - Class in io.prestosql.connector.system
 
SystemTablesMetadata(ConnectorId, SystemTablesProvider) - Constructor for class io.prestosql.connector.system.SystemTablesMetadata
 
SystemTablesProvider - Interface in io.prestosql.connector.system
 
SystemTransactionHandle - Class in io.prestosql.connector.system
 
SystemTransactionHandle(ConnectorId, TransactionId, ConnectorTransactionHandle) - Constructor for class io.prestosql.connector.system.SystemTransactionHandle
 

T

table(ConnectorTableMetadata) - Method in class io.prestosql.metadata.MetadataUtil.SchemaMetadataBuilder
 
TABLE_APPLICABLE_ROLES - Static variable in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
TABLE_COLUMNS - Static variable in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
TABLE_ENABLED_ROLES - Static variable in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
TABLE_ROLES - Static variable in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
TABLE_SCHEMATA - Static variable in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
TABLE_TABLE_PRIVILEGES - Static variable in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
TABLE_TABLES - Static variable in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
TABLE_VIEWS - Static variable in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
TableColumnInfo(CatalogSchemaTableName, Set<IoPlanPrinter.ColumnConstraint>) - Constructor for class io.prestosql.sql.planner.planPrinter.IoPlanPrinter.IoPlan.TableColumnInfo
 
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(Optional<ConnectorOutputMetadata>, Duration, Duration) - Constructor for class io.prestosql.operator.TableFinishInfo
 
TableFinishInfo(JsonNode, boolean, 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(ConnectorId, ConnectorTableHandle, ConnectorTransactionHandle, Optional<ConnectorTableLayoutHandle>) - Constructor for class io.prestosql.metadata.TableHandle
 
TableHandleJacksonModule - Class in io.prestosql.metadata
 
TableHandleJacksonModule(HandleResolver) - Constructor for class io.prestosql.metadata.TableHandleJacksonModule
 
TableJdbcTable - Class in io.prestosql.connector.system.jdbc
 
TableJdbcTable(Metadata, AccessControl) - Constructor for class io.prestosql.connector.system.jdbc.TableJdbcTable
 
TableLayoutHandleJacksonModule - Class in io.prestosql.metadata
 
TableLayoutHandleJacksonModule(HandleResolver) - Constructor for class io.prestosql.metadata.TableLayoutHandleJacksonModule
 
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(ConnectorId, ConnectorTableMetadata) - Constructor for class io.prestosql.metadata.TableMetadata
 
tableMetadataBuilder(String, String) - Static method in class io.prestosql.metadata.MetadataUtil.TableMetadataBuilder
 
tableMetadataBuilder(SchemaTableName) - Static method in class io.prestosql.metadata.MetadataUtil.TableMetadataBuilder
 
TablePartitioning(PartitioningHandle, List<ColumnHandle>) - Constructor for class io.prestosql.metadata.TableProperties.TablePartitioning
 
TableProperties - Class in io.prestosql.metadata
 
TableProperties(ConnectorId, 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 - Static variable in class io.prestosql.connector.informationSchema.InformationSchemaMetadata
 
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>) - Constructor for class io.prestosql.sql.planner.plan.TableScanNode
 
TableScanNode(PlanNodeId, TableHandle, List<Symbol>, Map<Symbol, ColumnHandle>, TupleDomain<ColumnHandle>, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.sql.planner.plan.TableScanNode
 
TableScanOperator - Class in io.prestosql.operator
 
TableScanOperator(OperatorContext, PlanNodeId, PageSourceProvider, Iterable<ColumnHandle>) - Constructor for class io.prestosql.operator.TableScanOperator
 
TableScanOperator.TableScanOperatorFactory - Class in io.prestosql.operator
 
TableScanOperatorFactory(int, PlanNodeId, PageSourceProvider, Iterable<ColumnHandle>) - Constructor for class io.prestosql.operator.TableScanOperator.TableScanOperatorFactory
 
TableScanStatsRule - Class in io.prestosql.cost
 
TableScanStatsRule(Metadata, StatsNormalizer) - Constructor for class io.prestosql.cost.TableScanStatsRule
 
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>, Optional<PartitioningScheme>, Optional<StatisticAggregations>, Optional<StatisticAggregationsDescriptor<Symbol>>) - Constructor for class io.prestosql.sql.planner.plan.TableWriterNode
 
TableWriterNode.CreateHandle - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.CreateName - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.DeleteHandle - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.InsertHandle - Class in io.prestosql.sql.planner.plan
 
TableWriterNode.InsertReference - 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>, 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>, 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(TaskManagerConfig, EmbedVersion, MultilevelSplitQueue) - Constructor for class io.prestosql.execution.executor.TaskExecutor
 
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
 
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(String, int, int) - Constructor for class io.prestosql.execution.TaskId
 
TaskId(StageId, int) - Constructor for class io.prestosql.execution.TaskId
 
TaskId(String) - 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>, Set<Lifespan>, boolean) - Constructor for class io.prestosql.execution.TaskSource
 
TaskSource(PlanNodeId, Set<ScheduledSplit>, 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, 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) - 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
 
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
 
TESTING_CATALOG - Static variable in class io.prestosql.testing.TestingSession
 
TestingAccessControlManager - Class in io.prestosql.testing
 
TestingAccessControlManager(TransactionManager) - 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(List<PropertyMetadata<?>>) - Constructor for class io.prestosql.testing.TestingConnectorSession
 
TestingConnectorSession(String, Optional<String>, Optional<String>, TimeZoneKey, Locale, long, List<PropertyMetadata<?>>, Map<String, Object>, boolean) - Constructor for class io.prestosql.testing.TestingConnectorSession
 
TestingEnvironment - Class in io.prestosql.testing
 
TestingEventListenerManager - Class in io.prestosql.testing
 
TestingEventListenerManager() - Constructor for class io.prestosql.testing.TestingEventListenerManager
 
TestingFactory(boolean) - Constructor for class io.prestosql.operator.PagesIndex.TestingFactory
 
TestingHandle - Enum in io.prestosql.testing
 
TestingHandleResolver - Class in io.prestosql.testing
 
TestingHandleResolver() - Constructor for class io.prestosql.testing.TestingHandleResolver
 
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(String) - Constructor for class io.prestosql.testing.TestingNodeManager
 
TestingNodeManager(Node) - Constructor for class io.prestosql.testing.TestingNodeManager
 
TestingNodeManager(List<Node>) - Constructor for class io.prestosql.testing.TestingNodeManager
 
TestingNodeManager(Node, Collection<Node>) - Constructor for class io.prestosql.testing.TestingNodeManager
 
TestingNodeManager(String, Node, Collection<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() - Constructor for class io.prestosql.server.testing.TestingPrestoServer
 
TestingPrestoServer(List<Module>) - Constructor for class io.prestosql.server.testing.TestingPrestoServer
 
TestingPrestoServer(Map<String, String>) - Constructor for class io.prestosql.server.testing.TestingPrestoServer
 
TestingPrestoServer(boolean, Map<String, String>, String, URI, SqlParserOptions, List<Module>, Optional<Path>) - Constructor for class io.prestosql.server.testing.TestingPrestoServer
 
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
 
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
 
TestngUtils - Class in io.prestosql.testing
 
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, FunctionRegistry, Session, boolean) - Static method in class io.prestosql.sql.planner.planPrinter.PlanPrinter
 
textDistributedPlan(SubPlan, FunctionRegistry, Session, boolean) - Static method in class io.prestosql.sql.planner.planPrinter.PlanPrinter
 
textIoPlan(PlanNode, Metadata, Session) - Static method in class io.prestosql.sql.planner.planPrinter.IoPlanPrinter
 
textLogicalPlan(PlanNode, TypeProvider, FunctionRegistry, StatsAndCosts, Session, int) - Static method in class io.prestosql.sql.planner.planPrinter.PlanPrinter
 
textLogicalPlan(PlanNode, TypeProvider, FunctionRegistry, StatsAndCosts, Session, int, boolean) - Static method in class io.prestosql.sql.planner.planPrinter.PlanPrinter
 
textLogicalPlan(PlanNode, TypeProvider, Optional<StageExecutionDescriptor>, FunctionRegistry, StatsAndCosts, Session, Optional<Map<PlanNodeId, PlanNodeStats>>, 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
 
timeAtTimeZone(ConnectorSession, long, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
timeAtTimeZone(ConnectorSession, long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
TimeDistinctFromOperator() - Constructor for class io.prestosql.type.TimeOperators.TimeDistinctFromOperator
 
timeHasTimeZone(String) - Static method in class io.prestosql.util.DateTimeUtils
 
timeMinusIntervalDayToSecond(ConnectorSession, long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
timeMinusIntervalYearToMonth(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
TimeOperators - Class in io.prestosql.type
 
TimeOperators.TimeDistinctFromOperator - Class in io.prestosql.type
 
timePlusIntervalDayToSecond(ConnectorSession, long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
timePlusIntervalYearToMonth(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
timestampAtTimeZone(long, Slice) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
timestampAtTimeZone(long, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
TimestampDistinctFromOperator() - Constructor for class io.prestosql.type.TimestampOperators.TimestampDistinctFromOperator
 
timestampHasTimeZone(String) - Static method in class io.prestosql.util.DateTimeUtils
 
timestampMinusIntervalDayToSecond(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
timestampMinusIntervalYearToMonth(ConnectorSession, long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
TimestampOperators - Class in io.prestosql.type
 
TimestampOperators.TimestampDistinctFromOperator - Class in io.prestosql.type
 
timestampPlusIntervalDayToSecond(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
timestampPlusIntervalYearToMonth(ConnectorSession, long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
TimestampWithTimeZoneDistinctFromOperator() - Constructor for class io.prestosql.type.TimestampWithTimeZoneOperators.TimestampWithTimeZoneDistinctFromOperator
 
timestampWithTimeZoneMinusIntervalDayToSecond(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
timestampWithTimeZoneMinusIntervalYearToMonth(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
TimestampWithTimeZoneOperators - Class in io.prestosql.type
 
TimestampWithTimeZoneOperators.TimestampWithTimeZoneDistinctFromOperator - Class in io.prestosql.type
 
timestampWithTimeZonePlusIntervalDayToSecond(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
timestampWithTimeZonePlusIntervalYearToMonth(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
TimeWithTimeZoneDistinctFromOperator() - Constructor for class io.prestosql.type.TimeWithTimeZoneOperators.TimeWithTimeZoneDistinctFromOperator
 
timeWithTimeZoneMinusIntervalDayToSecond(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
timeWithTimeZoneMinusIntervalYearToMonth(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
TimeWithTimeZoneOperators - Class in io.prestosql.type
 
TimeWithTimeZoneOperators.TimeWithTimeZoneDistinctFromOperator - Class in io.prestosql.type
 
timeWithTimeZonePlusIntervalDayToSecond(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
timeWithTimeZonePlusIntervalYearToMonth(long, long) - Static method in class io.prestosql.type.DateTimeOperators
 
timeZoneHourFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
timeZoneMinuteFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
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
 
TinyintDistinctFromOperator() - Constructor for class io.prestosql.type.TinyintOperators.TinyintDistinctFromOperator
 
TinyintOperators - Class in io.prestosql.type
 
TinyintOperators.TinyintDistinctFromOperator - 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(ConnectorId) - Method in class io.prestosql.Session
 
toDataProvider() - Static method in class io.prestosql.testing.TestngUtils
 
toException() - Method in class io.prestosql.execution.ExecutionFailureInfo
 
toExpression(Object, Type) - Method in class io.prestosql.sql.planner.LiteralEncoder
 
toExpression() - Method in class io.prestosql.sql.planner.plan.JoinNode.EquiJoinClause
 
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, FunctionRegistry) - Static method in class io.prestosql.util.FastutilSetHelper
 
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
 
toISO8601FromDate(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
toISO8601FromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
toISO8601FromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
toJoinNodeType() - Method in enum io.prestosql.sql.planner.plan.LateralJoinNode.Type
 
toJson(JsonUtil.JsonGeneratorWriter, ConnectorSession, Block) - Static method in class io.prestosql.operator.scalar.ArrayToJsonCast
 
toJson(JsonUtil.ObjectKeyProvider, JsonUtil.JsonGeneratorWriter, ConnectorSession, Block) - Static method in class io.prestosql.operator.scalar.MapToJsonCast
 
toJson(List<JsonUtil.JsonGeneratorWriter>, ConnectorSession, Block) - Static method in class io.prestosql.operator.scalar.RowToJsonCast
 
toJson() - Method in class io.prestosql.sql.planner.planPrinter.PlanPrinter
 
toMap(MapType, JsonUtil.BlockBuilderAppender, 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.
TopNOperator(OperatorContext, List<Type>, int, List<Integer>, List<SortOrder>) - Constructor for class io.prestosql.operator.TopNOperator
 
TopNOperator.TopNOperatorFactory - Class in io.prestosql.operator
 
TopNOperatorFactory(int, PlanNodeId, List<? extends Type>, int, List<Integer>, List<SortOrder>) - Constructor for class io.prestosql.operator.TopNOperator.TopNOperatorFactory
 
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) - 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) - Constructor for class io.prestosql.operator.TopNRowNumberOperator.TopNRowNumberOperatorFactory
 
TopologyAwareNodeSelector - Class in io.prestosql.execution.scheduler
 
TopologyAwareNodeSelector(InternalNodeManager, NodeTaskMap, boolean, Supplier<NodeMap>, int, int, int, List<CounterStat>, List<String>, NetworkLocationCache) - Constructor for class io.prestosql.execution.scheduler.TopologyAwareNodeSelector
 
toPredicate(TupleDomain<Symbol>) - Method in class io.prestosql.sql.planner.DomainTranslator
 
toResponse(Throwable) - Method in class io.prestosql.server.ThrowableMapper
 
toRow(RowType, JsonUtil.BlockBuilderAppender[], Optional<Map<String, Integer>>, ConnectorSession, Slice) - Static method in class io.prestosql.operator.scalar.JsonToRowCast
 
toSession(ConnectorTransactionHandle, ConnectorSession) - Static method in class io.prestosql.connector.system.SystemConnectorSessionUtil
 
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
 
toStackTraceElement(String) - Static method in class io.prestosql.execution.ExecutionFailureInfo
 
toString() - Method in class io.prestosql.connector.ConnectorId
 
toString() - Method in class io.prestosql.connector.informationSchema.InformationSchemaColumnHandle
 
toString() - Method in class io.prestosql.connector.informationSchema.InformationSchemaSplit
 
toString() - Method in class io.prestosql.connector.informationSchema.InformationSchemaTableHandle
 
toString() - Method in class io.prestosql.connector.informationSchema.InformationSchemaTableLayoutHandle
 
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.SystemTableLayoutHandle
 
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.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.AnalyzeTableHandle
 
toString() - Method in class io.prestosql.metadata.BoundVariables
 
toString() - Method in class io.prestosql.metadata.Catalog
 
toString() - Method in class io.prestosql.metadata.CatalogMetadata
 
toString() - Method in class io.prestosql.metadata.IndexHandle
 
toString() - Method in class io.prestosql.metadata.InsertTableHandle
 
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.PrestoNode
 
toString() - Method in class io.prestosql.metadata.QualifiedObjectName
 
toString() - Method in class io.prestosql.metadata.QualifiedTablePrefix
 
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.metadata.ViewDefinition
 
toString() - Method in class io.prestosql.metadata.ViewDefinition.ViewColumn
 
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.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.server.BasicQueryInfo
 
toString() - Method in class io.prestosql.server.JavaVersion
 
toString() - Method in class io.prestosql.server.remotetask.HttpRemoteTask
 
toString() - Method in class io.prestosql.server.TaskUpdateRequest
 
toString() - Method in class io.prestosql.Session
 
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.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.gen.Binding
 
toString() - Method in class io.prestosql.sql.gen.CallSiteBinder
 
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.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.CreateHandle
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.CreateName
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.DeleteHandle
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertHandle
 
toString() - Method in class io.prestosql.sql.planner.plan.TableWriterNode.InsertReference
 
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.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.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.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.SqlIntervalDayTime
 
toString() - Method in class io.prestosql.type.SqlIntervalYearMonth
 
toSymbolReference() - Method in class io.prestosql.sql.planner.Symbol
 
toSystemColumnHandles(ConnectorId, ConnectorTableMetadata) - Static method in class io.prestosql.connector.system.SystemColumnHandle
 
TOTAL_RESERVATION - Static variable in class io.prestosql.memory.MemoryManagerConfig.LowMemoryKillerPolicy
 
TOTAL_RESERVATION_ON_BLOCKED_NODES - Static variable in class 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.
toText(boolean, int) - Method in class io.prestosql.sql.planner.planPrinter.PlanPrinter
 
toTypes(List<TypeSignatureProvider>, TypeManager) - Static method in class io.prestosql.metadata.FunctionRegistry
 
toTypes(List<? extends Type>, AggregationNode.Step, List<AccumulatorFactory>, Optional<Integer>) - Static method in class io.prestosql.operator.aggregation.builder.InMemoryHashAggregationBuilder
 
toUnixTime(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
toUnixTimeFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
toUtf8(Slice) - Static method in class io.prestosql.operator.scalar.StringFunctions
 
toWhenHasSplitQueueSpaceFuture(Set<Node>, List<RemoteTask>, int) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
toWhenHasSplitQueueSpaceFuture(List<RemoteTask>, int) - Static method in class io.prestosql.execution.scheduler.NodeScheduler
 
trace(PlanNode, Set<Symbol>) - Static method in class io.prestosql.sql.planner.optimizations.IndexJoinOptimizer.IndexKeyTracer
 
TrackingLookupSourceSupplier - Interface in io.prestosql.operator
 
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
 
TransactionHandleJacksonModule - Class in io.prestosql.metadata
 
TransactionHandleJacksonModule(HandleResolver) - Constructor for class io.prestosql.metadata.TransactionHandleJacksonModule
 
TransactionId - Class in io.prestosql.transaction
 
TransactionInfo - Class in io.prestosql.transaction
 
TransactionInfo(TransactionId, IsolationLevel, boolean, boolean, DateTime, Duration, List<ConnectorId>, Optional<ConnectorId>) - 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(TypeManager, TransactionManager) - Constructor for class io.prestosql.connector.system.TransactionsSystemTable
 
transform(WorkProcessor.Transformation<T, R>) - Method in interface io.prestosql.operator.WorkProcessor
TransformCorrelatedInPredicateToJoin - Class in io.prestosql.sql.planner.iterative.rule
Replaces correlated ApplyNode with InPredicate expression with SemiJoin
TransformCorrelatedInPredicateToJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin
 
TransformCorrelatedLateralJoinToJoin - Class in io.prestosql.sql.planner.iterative.rule
Tries to decorrelate subquery and rewrite it using normal join.
TransformCorrelatedLateralJoinToJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedLateralJoinToJoin
 
TransformCorrelatedScalarAggregationToJoin - Class in io.prestosql.sql.planner.iterative.rule
Scalar aggregation is aggregation with GROUP BY 'a constant' (or empty GROUP BY).
TransformCorrelatedScalarAggregationToJoin(FunctionRegistry) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformCorrelatedScalarAggregationToJoin
 
TransformCorrelatedScalarSubquery - Class in io.prestosql.sql.planner.iterative.rule
Scalar filter scan query is something like:
TransformCorrelatedScalarSubquery() - 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
 
TransformExistsApplyToLateralNode - Class in io.prestosql.sql.planner.iterative.rule
EXISTS is modeled as (if correlated predicates are equality comparisons):
TransformExistsApplyToLateralNode(FunctionRegistry) - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformExistsApplyToLateralNode
 
transformProcessor(Function<WorkProcessor<T>, WorkProcessor<R>>) - Method in interface io.prestosql.operator.WorkProcessor
 
TransformQuantifiedComparisonApplyToLateralJoin - Class in io.prestosql.sql.planner.optimizations
 
TransformQuantifiedComparisonApplyToLateralJoin(Metadata) - Constructor for class io.prestosql.sql.planner.optimizations.TransformQuantifiedComparisonApplyToLateralJoin
 
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
 
TransformUncorrelatedLateralToJoin - Class in io.prestosql.sql.planner.iterative.rule
 
TransformUncorrelatedLateralToJoin() - Constructor for class io.prestosql.sql.planner.iterative.rule.TransformUncorrelatedLateralToJoin
 
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
 
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
 
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(Function<Symbol, Optional<Symbol>>) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
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
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, Symbol>) - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
translate(Partitioning.Translator) - Method in class io.prestosql.sql.planner.Partitioning.ArgumentBinding
 
translate(Function<Symbol, Symbol>) - Method in class io.prestosql.sql.planner.Partitioning
 
translate(Partitioning.Translator) - Method in class io.prestosql.sql.planner.Partitioning
 
translate(Expression, FunctionKind, Map<NodeRef<Expression>, Type>, Map<Symbol, Integer>, FunctionRegistry, TypeManager, Session, boolean) - Static method in class io.prestosql.sql.relational.SqlToRowExpressionTranslator
 
translateOutputLayout(List<Symbol>) - Method in class io.prestosql.sql.planner.PartitioningScheme
 
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
 
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
 
truncate(double) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
truncate(long) - Static method in class io.prestosql.operator.scalar.MathFunctions
 
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, Slice) - Static method in class io.prestosql.operator.scalar.MathFunctions.Truncate
 
truncateLong(long, long, Slice, long) - Static method in class io.prestosql.operator.scalar.MathFunctions.TruncateN
 
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
 
truncateTime(ConnectorSession, Slice, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
truncateTimestamp(ConnectorSession, Slice, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
truncateTimestampWithTimezone(Slice, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
truncateTimeWithTimeZone(Slice, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
TRY - Static variable in class io.prestosql.sql.relational.Signatures
 
TRY_CAST - Static variable in class io.prestosql.operator.scalar.TryCastFunction
 
TRY_CAST - Static variable in class io.prestosql.sql.relational.Signatures
 
tryAddPage(Page) - Method in class io.prestosql.operator.index.IndexSnapshotBuilder
 
tryBlock(TryFunction.TryBlockLambda) - Static method in class io.prestosql.operator.scalar.TryFunction
 
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
 
tryCastSignature(Type, Type) - Static method in class io.prestosql.sql.relational.Signatures
 
tryDouble(TryFunction.TryDoubleLambda) - Static method in class io.prestosql.operator.scalar.TryFunction
 
TryFunction - Class in io.prestosql.operator.scalar
 
TryFunction.TryBlockLambda - Interface 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.TrySliceLambda - Interface in io.prestosql.operator.scalar
 
tryGetQuery(QueryId) - Method in class io.prestosql.execution.QueryTracker
 
tryGetScope(Node) - Method in class io.prestosql.sql.analyzer.Analysis
 
tryLong(TryFunction.TryLongLambda) - 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
 
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
 
trySignature(Type) - Static method in class io.prestosql.sql.relational.Signatures
 
trySlice(TryFunction.TrySliceLambda) - Static method in class io.prestosql.operator.scalar.TryFunction
 
TuplePageFilter - Class in io.prestosql.operator.index
Filters out rows that do not match the values from the specified tuple
TuplePageFilter(Page, List<Type>, 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.Join
 
TYPE_MANAGER - Static variable in class io.prestosql.testing.TestingEnvironment
 
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
 
typeConvert(Join.Type) - Static method in enum io.prestosql.sql.planner.plan.JoinNode.Type
 
TypeDeserializer - Class in io.prestosql.type
 
TypeDeserializer(TypeManager) - Constructor for class io.prestosql.type.TypeDeserializer
 
TypedHeap - Class in io.prestosql.operator.aggregation
 
TypedHeap(BlockComparator, 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(BlockComparator, Type, Type, int) - Constructor for class io.prestosql.operator.aggregation.TypedKeyValueHeap
 
TypedSet - Class in io.prestosql.operator.aggregation
 
TypedSet(Type, int, String) - Constructor for class io.prestosql.operator.aggregation.TypedSet
 
TypedSet(Type, BlockBuilder, int, String) - 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.FunctionRegistry
 
TypeImplementationDependency - Class in io.prestosql.operator.annotations
 
TypeImplementationDependency(String) - Constructor for class io.prestosql.operator.annotations.TypeImplementationDependency
 
typeof(Type, Object) - Static method in class io.prestosql.operator.scalar.TypeOfFunction
 
typeof(Type, Long) - Static method in class io.prestosql.operator.scalar.TypeOfFunction
 
typeof(Type, Double) - Static method in class io.prestosql.operator.scalar.TypeOfFunction
 
typeof(Type, Boolean) - Static method in class io.prestosql.operator.scalar.TypeOfFunction
 
TypeOfFunction - Class in io.prestosql.operator.scalar
 
TypeProvider - Class in io.prestosql.sql.planner
 
TypeRegistry - Class in io.prestosql.type
 
TypeRegistry() - Constructor for class io.prestosql.type.TypeRegistry
 
TypeRegistry(Set<Type>, FeaturesConfig) - Constructor for class io.prestosql.type.TypeRegistry
 
TypeRegistry.TypeCompatibility - Class in io.prestosql.type
 
TYPES - Static variable in class io.prestosql.operator.DeleteOperator
 
TYPES - Static variable in class io.prestosql.operator.MetadataDeleteOperator
 
TYPES - Static variable in class io.prestosql.operator.StatisticsWriterOperator
 
TYPES - Static variable in class io.prestosql.operator.TableFinishOperator
 
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
 
TypesJdbcTable - Class in io.prestosql.connector.system.jdbc
 
TypesJdbcTable(TypeManager) - 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) - 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
 
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)

E.g.,

Output[$0, $1] -> Project[$0 := $2, $1 := $3 * 100] -> Aggregate[$2, $3 := sum($4)] -> ...

gets rewritten as

Output[$2, $1] -> Project[$2, $1 := $3 * 100] -> Aggregate[$2, $3 := sum($4)] -> ...

UnaliasSymbolReferences() - Constructor for class io.prestosql.sql.planner.optimizations.UnaliasSymbolReferences
 
UnaryFunctionInterface - Interface in io.prestosql.sql.gen.lambda
 
unboxPrimitive(Class<?>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
unboxPrimitiveIfNecessary(Scope, Class<?>) - Static method in class io.prestosql.sql.gen.BytecodeUtils
 
unescapeLiteralLikePattern(Slice, Slice) - Static method in class io.prestosql.type.LikeFunctions
 
ungroupedExecution() - Static method in class io.prestosql.operator.StageExecutionDescriptor
 
union(Type, Block, Block) - Static method in class io.prestosql.operator.scalar.ArrayUnionFunction
 
union() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
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 - Static variable in class io.prestosql.type.UnknownType
 
UnknownDistinctFromOperator() - Constructor for class io.prestosql.type.UnknownOperators.UnknownDistinctFromOperator
 
UnknownOperators - Class in io.prestosql.type
 
UnknownOperators.UnknownDistinctFromOperator - Class in io.prestosql.type
 
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) - 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.FunctionRegistry
 
Unnester - Interface in io.prestosql.operator
 
UnnestNode - Class in io.prestosql.sql.planner.plan
 
UnnestNode(PlanNodeId, PlanNode, List<Symbol>, Map<Symbol, List<Symbol>>, Optional<Symbol>) - Constructor for class io.prestosql.sql.planner.plan.UnnestNode
 
UnnestOperator - Class in io.prestosql.operator
 
UnnestOperator(OperatorContext, List<Integer>, List<Type>, List<Integer>, List<Type>, boolean) - Constructor for class io.prestosql.operator.UnnestOperator
 
UnnestOperator.UnnestOperatorFactory - Class in io.prestosql.operator
 
UnnestOperatorFactory(int, PlanNodeId, List<Integer>, List<Type>, List<Integer>, List<Type>, boolean) - Constructor for class io.prestosql.operator.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
 
unregisterTableForView() - Method in class io.prestosql.sql.analyzer.Analysis
 
unscaledDecimal - Variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.SingleLongDecimalWithOverflowState
 
unscaledDecimals - Variable in class io.prestosql.operator.aggregation.state.LongDecimalWithOverflowStateFactory.GroupedLongDecimalWithOverflowState
 
unsupportedPartitioningSpillerFactory() - Static method in interface io.prestosql.spiller.PartitioningSpillerFactory
 
unsupportedSingleStreamSpillerFactory() - Static method in interface io.prestosql.spiller.SingleStreamSpillerFactory
 
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
 
update() - Method in interface io.prestosql.operator.UpdateMemory
Update memory reservation.
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
 
updateFailure() - Method in class io.prestosql.server.remotetask.RemoteTaskStats
 
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, long, long, long, long, long) - Method in class io.prestosql.execution.QueryStateMachine
 
updateMemoryUsage(long, long, long) - Method in class io.prestosql.execution.StageStateMachine
 
updateMemoryUsage(long) - Method in class io.prestosql.operator.exchange.LocalExchangeMemoryManager
 
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
 
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, Optional<PlanFragment>, List<TaskSource>, OutputBuffers, OptionalInt) - Method in class io.prestosql.execution.SqlTask
 
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.
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
 
UsedByGeneratedCode - Annotation Type in io.prestosql.annotation
Annotates a program element that is (only) used by generated code.
useMarkDistinct(Session) - Static method in class io.prestosql.SystemSessionProperties
 
userState - Variable in class io.prestosql.sql.gen.VarArgsToArrayAdapterGenerator.VarArgsToArrayAdapterState
User state created by provided user state factory
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
 

V

validate(PlanNode, Session, Metadata, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.NoDuplicatePlanNodeIdsChecker
 
validate(PlanNode, Session, Metadata, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.NoIdentifierLeftChecker
 
validate(PlanNode, Session, Metadata, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.NoSubqueryExpressionLeftChecker
 
validate(PlanNode, Session, Metadata, TypeAnalyzer, TypeProvider, WarningCollector) - Method in interface io.prestosql.sql.planner.sanity.PlanSanityChecker.Checker
 
validate(PlanNode, Session, Metadata, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.TypeValidator
 
validate(PlanNode, Session, Metadata, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.ValidateAggregationsWithDefaultValues
 
validate(PlanNode, Session, Metadata, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.ValidateDependenciesChecker
 
validate(PlanNode) - Static method in class io.prestosql.sql.planner.sanity.ValidateDependenciesChecker
 
validate(PlanNode, Session, Metadata, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.ValidateStreamingAggregations
 
validate(PlanNode, Session, Metadata, TypeAnalyzer, TypeProvider, WarningCollector) - Method in class io.prestosql.sql.planner.sanity.VerifyNoFilteredAggregations
 
validate(PlanNode, Session, Metadata, 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(ConnectorId, 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, 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, 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
 
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
 
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(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.PageCompression
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.ScheduleResult.BlockedReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class io.prestosql.execution.StageId
 
valueOf(List<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.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.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.aggregation.arrayagg.ArrayAggGroupImplementation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.aggregation.histogram.HistogramGroupImplementation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.aggregation.multimapagg.MultimapAggGroupImplementation
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(int) - Static method in enum io.prestosql.operator.scalar.ColorFunctions.SystemColor
 
valueOf(String) - Static method in enum io.prestosql.operator.scalar.ScalarFunctionImplementation.ArgumentType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.operator.scalar.ScalarFunctionImplementation.NullConvention
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.server.security.SecurityConfig.AuthenticationType
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.analyzer.SemanticErrorCode
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.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.LateralJoinNode.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.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
 
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.PageCompression
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.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.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.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.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.aggregation.arrayagg.ArrayAggGroupImplementation
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.histogram.HistogramGroupImplementation
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.multimapagg.MultimapAggGroupImplementation
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.scalar.ScalarFunctionImplementation.ArgumentType
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.ScalarFunctionImplementation.NullConvention
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.SecurityConfig.AuthenticationType
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.analyzer.SemanticErrorCode
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.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 enum io.prestosql.sql.planner.plan.LateralJoinNode.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() - Constructor for class io.prestosql.sql.planner.plan.Patterns.Values
 
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.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.
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, List<Symbol>, List<List<Expression>>) - Constructor for class io.prestosql.sql.planner.plan.ValuesNode
 
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(int, BlockBuilder) - Constructor for class io.prestosql.operator.aggregation.histogram.ValueStore
 
valueTypeArgumentProperty(ScalarFunctionImplementation.NullConvention) - Static method in class io.prestosql.operator.scalar.ScalarFunctionImplementation.ArgumentProperty
 
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
 
VarbinaryDistinctFromOperator() - Constructor for class io.prestosql.type.VarbinaryOperators.VarbinaryDistinctFromOperator
 
VarbinaryFunctions - Class in io.prestosql.operator.scalar
 
VarbinaryOperators - Class in io.prestosql.type
 
VarbinaryOperators.VarbinaryDistinctFromOperator - Class in io.prestosql.type
 
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
 
VarcharDistinctFromOperator() - Constructor for class io.prestosql.type.VarcharOperators.VarcharDistinctFromOperator
 
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, long) - Static method in class io.prestosql.operator.scalar.JsonFunctions
 
varcharJsonArrayContains(Slice, double) - 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
 
VarcharOperators.VarcharDistinctFromOperator - 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
 
varcharToVarcharCast(Long, Long, Slice) - Static method in class io.prestosql.operator.scalar.CharacterStringCasts
 
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
 
verifyComparableOrderableContract() - Method in interface io.prestosql.metadata.Metadata
 
verifyComparableOrderableContract() - Method in class io.prestosql.metadata.MetadataManager
 
verifyExpressionIsConstant(Set<NodeRef<Expression>>, Expression) - Static method in class io.prestosql.sql.analyzer.ConstantExpressionVerifier
 
verifyInitialMinimumWorkersRequirement() - Method in class io.prestosql.execution.ClusterSizeMonitor
 
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
 
verifyWeight(long) - Static method in class io.prestosql.operator.scalar.QuantileDigestFunctions
 
VersionedMemoryPoolId - Class in io.prestosql.memory
 
VersionedMemoryPoolId(MemoryPoolId, long) - Constructor for class io.prestosql.memory.VersionedMemoryPoolId
 
ViewAccessControl - Class in io.prestosql.security
 
ViewAccessControl(AccessControl) - Constructor for class io.prestosql.security.ViewAccessControl
 
ViewColumn(String, Type) - Constructor for class io.prestosql.metadata.ViewDefinition.ViewColumn
 
ViewDefinition - Class in io.prestosql.metadata
 
ViewDefinition(String, Optional<String>, Optional<String>, List<ViewDefinition.ViewColumn>, Optional<String>, boolean) - Constructor for class io.prestosql.metadata.ViewDefinition
 
ViewDefinition.ViewColumn - Class in io.prestosql.metadata
 
viewOf(Map<Symbol, Type>) - Static method in class io.prestosql.sql.planner.TypeProvider
 
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
 
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
 
visitFieldReference(FieldReference, Void) - Method in class io.prestosql.sql.planner.InputReferenceExtractor
 
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
 
visitLateralJoin(LateralJoinNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitLimit(LimitNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitMarkDistinct(MarkDistinctNode, C) - Method in class io.prestosql.sql.planner.plan.PlanVisitor
 
visitMetadataDelete(MetadataDeleteNode, 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, SimplePlanRewriter.RewriteContext<C>) - Method in class io.prestosql.sql.planner.plan.SimplePlanRewriter
 
visitPlan(PlanNode, C) - Method in class io.prestosql.sql.planner.SimplePlanVisitor
 
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
 
visitStatisticsWriterNode(StatisticsWriterNode, 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

waitForMinimumWorkers() - Method in class io.prestosql.execution.ClusterSizeMonitor
Returns a listener that completes when the minimum number of workers for the cluster has been met.
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
 
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
 
WebUiResource - Class in io.prestosql.server
 
WebUiResource() - Constructor for class io.prestosql.server.WebUiResource
 
weekFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
weekFromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
weekFromTimestampWithTimeZone(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(DigestAndPercentileState, double, long, double) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
weightedInput(DigestAndPercentileState, double, long, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileAggregations
 
weightedInput(DigestAndPercentileArrayState, double, long, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateDoublePercentileArrayAggregations
 
weightedInput(DigestAndPercentileState, long, long, double) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
weightedInput(DigestAndPercentileState, long, long, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileAggregations
 
weightedInput(DigestAndPercentileArrayState, long, long, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateLongPercentileArrayAggregations
 
weightedInput(DigestAndPercentileState, long, long, double) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
weightedInput(DigestAndPercentileState, long, long, double, double) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileAggregations
 
weightedInput(DigestAndPercentileArrayState, long, long, Block) - Static method in class io.prestosql.operator.aggregation.ApproximateRealPercentileArrayAggregations
 
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
 
whenSignature(Type) - Static method in class io.prestosql.sql.relational.Signatures
 
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
 
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(Class<? extends WindowFunction>) - Method in class io.prestosql.metadata.FunctionListBuilder
 
window(WindowFunctionSupplier, Type, FrameInfo, List<Integer>) - Static method in class io.prestosql.operator.WindowFunctionDefinition
 
window(WindowFunctionSupplier, Type, FrameInfo, Integer...) - Static method in class io.prestosql.operator.WindowFunctionDefinition
 
window() - Static method in class io.prestosql.sql.planner.plan.Patterns
 
WindowAnnotationsParser - Class in io.prestosql.operator.window
 
WindowFilterPushDown - Class in io.prestosql.sql.planner.optimizations
 
WindowFilterPushDown(Metadata) - 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.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) - 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) - Method in class io.prestosql.metadata.Signature
 
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
 
withAssignments(Map<Symbol, Expression>) - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
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
 
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
 
withDistributionType(JoinNode.DistributionType) - Method in class io.prestosql.sql.planner.plan.JoinNode
 
withDistributionType(SemiJoinNode.DistributionType) - Method in class io.prestosql.sql.planner.plan.SemiJoinNode
 
withExtraParameters(Function<PolymorphicScalarFunctionBuilder.SpecializeContext, List<Object>>) - Method in class io.prestosql.metadata.PolymorphicScalarFunctionBuilder.MethodsGroupBuilder
 
withFilter(Expression) - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
withFixedParallelism() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
withGroupedExecution(List<PlanNodeId>) - Method in class io.prestosql.sql.planner.PlanFragment
 
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
 
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
 
withOuterQueryParent(Scope) - Method in class io.prestosql.sql.analyzer.Scope.Builder
 
withoutPreference() - Method in class io.prestosql.sql.planner.optimizations.StreamPreferredProperties
 
withOwner(String) - Method in class io.prestosql.metadata.ViewDefinition
 
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
 
withRelationType(RelationId, RelationType) - Method in class io.prestosql.sql.analyzer.Scope.Builder
 
withReplicatedNulls(boolean) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties.Global
 
withReplicatedNulls(boolean) - Method in class io.prestosql.sql.planner.optimizations.ActualProperties
 
withRootId(PlanNodeId) - Method in class io.prestosql.sql.planner.optimizations.joins.JoinGraph
 
withSpillable(boolean) - Method in class io.prestosql.sql.planner.plan.JoinNode
 
withTaskStatus(TaskStatus) - Method in class io.prestosql.execution.TaskInfo
 
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
 
WorkerResource(InternalNodeManager, HttpClient) - Constructor for class io.prestosql.server.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.Transformation<T,R> - Interface in io.prestosql.operator
 
WorkProcessor.TransformationState<T> - Class 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(SliceOutput, Block) - Method in class io.prestosql.block.BlockEncodingManager
 
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, ConnectorSession) - 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.FunctionType
 
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
 
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, int, int) - Method in class io.prestosql.type.FunctionType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.type.IpAddressType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.type.IpAddressType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.type.JsonType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.type.JsonType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.type.setdigest.SetDigestType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.type.setdigest.SetDigestType
 
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(long) - Static method in class io.prestosql.type.BigintOperators
 
xxHash64(Slice) - Static method in class io.prestosql.type.CharOperators
 
xxHash64(long) - Static method in class io.prestosql.type.DateOperators
 
xxHash64(long) - Static method in class io.prestosql.type.DecimalOperators.XxHash64Operator
 
xxHash64(Slice) - Static method in class io.prestosql.type.DecimalOperators.XxHash64Operator
 
xxHash64(double) - Static method in class io.prestosql.type.DoubleOperators
 
xxHash64(long) - Static method in class io.prestosql.type.IntegerOperators
 
xxHash64(Slice) - Static method in class io.prestosql.type.IpAddressOperators
 
xxHash64(long) - Static method in class io.prestosql.type.RealOperators
 
xxHash64(long) - Static method in class io.prestosql.type.SmallintOperators
 
xxHash64(long) - Static method in class io.prestosql.type.TimeOperators
 
xxHash64(long) - Static method in class io.prestosql.type.TimestampOperators
 
xxHash64(long) - Static method in class io.prestosql.type.TimestampWithTimeZoneOperators
 
xxHash64(long) - Static method in class io.prestosql.type.TimeWithTimeZoneOperators
 
xxHash64(long) - Static method in class io.prestosql.type.TinyintOperators
 
xxHash64(Slice) - Static method in class io.prestosql.type.VarbinaryOperators
 
xxHash64(Slice) - Static method in class io.prestosql.type.VarcharOperators
 
XxHash64Operator() - Constructor for class io.prestosql.type.DecimalOperators.XxHash64Operator
 

Y

yearFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
yearFromInterval(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
yearFromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
yearFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
yearOfWeekFromDate(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
yearOfWeekFromTimestamp(ConnectorSession, long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
yearOfWeekFromTimestampWithTimeZone(long) - Static method in class io.prestosql.operator.scalar.DateTimeFunctions
 
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.
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
 
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 _ 
Skip navigation links

Copyright © 2012–2019. All rights reserved.