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

$

$notSpecified() - Method in annotation type io.prestosql.spi.function.Convention
 

A

ABANDONED_QUERY - io.prestosql.spi.StandardErrorCode
 
ABANDONED_TASK - io.prestosql.spi.StandardErrorCode
 
abort() - Method in interface io.prestosql.spi.connector.ConnectorPageSink
 
abort() - Method in interface io.prestosql.spi.connector.UpdatablePageSource
 
above(Type, Object) - Static method in class io.prestosql.spi.predicate.Marker
 
ABOVE - io.prestosql.spi.predicate.Marker.Bound
 
AbstractArrayBlock - Class in io.prestosql.spi.block
 
AbstractArrayBlock() - Constructor for class io.prestosql.spi.block.AbstractArrayBlock
 
AbstractArrayBlock.ArrayBlockFunction<T> - Interface in io.prestosql.spi.block
 
AbstractIntType - Class in io.prestosql.spi.type
 
AbstractIntType(TypeSignature) - Constructor for class io.prestosql.spi.type.AbstractIntType
 
AbstractLongType - Class in io.prestosql.spi.type
 
AbstractLongType(TypeSignature) - Constructor for class io.prestosql.spi.type.AbstractLongType
 
AbstractMapBlock - Class in io.prestosql.spi.block
 
AbstractMapBlock(MapType) - Constructor for class io.prestosql.spi.block.AbstractMapBlock
 
AbstractRowBlock - Class in io.prestosql.spi.block
 
AbstractRowBlock(int) - Constructor for class io.prestosql.spi.block.AbstractRowBlock
 
AbstractSingleArrayBlock - Class in io.prestosql.spi.block
 
AbstractSingleArrayBlock(int) - Constructor for class io.prestosql.spi.block.AbstractSingleArrayBlock
 
AbstractSingleMapBlock - Class in io.prestosql.spi.block
 
AbstractSingleMapBlock() - Constructor for class io.prestosql.spi.block.AbstractSingleMapBlock
 
AbstractSingleRowBlock - Class in io.prestosql.spi.block
 
AbstractSingleRowBlock(int) - Constructor for class io.prestosql.spi.block.AbstractSingleRowBlock
 
AbstractType - Class in io.prestosql.spi.type
 
AbstractType(TypeSignature, Class<?>) - Constructor for class io.prestosql.spi.type.AbstractType
 
AbstractVariableWidthBlock - Class in io.prestosql.spi.block
 
AbstractVariableWidthBlock() - Constructor for class io.prestosql.spi.block.AbstractVariableWidthBlock
 
AbstractVariableWidthType - Class in io.prestosql.spi.type
 
AbstractVariableWidthType(TypeSignature, Class<?>) - Constructor for class io.prestosql.spi.type.AbstractVariableWidthType
 
AccessDeniedException - Exception in io.prestosql.spi.security
 
AccessDeniedException(String) - Constructor for exception io.prestosql.spi.security.AccessDeniedException
 
AccumulatorState - Interface in io.prestosql.spi.function
 
AccumulatorStateFactory<T> - Interface in io.prestosql.spi.function
 
AccumulatorStateMetadata - Annotation Type in io.prestosql.spi.function
 
AccumulatorStateSerializer<T> - Interface in io.prestosql.spi.function
 
add(Slice, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
add(Slice, Slice, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
ADD - io.prestosql.spi.function.OperatorType
 
addBytes(int) - Method in class io.prestosql.spi.block.BlockBuilderStatus
 
addChangeListener(MemoryPoolId, Consumer<MemoryPoolInfo>) - Method in interface io.prestosql.spi.memory.ClusterMemoryPoolManager
 
addColumn(ConnectorSession, ConnectorTableHandle, ColumnMetadata) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Add the specified column
addColumnStatistic(ColumnStatisticMetadata, Block) - Method in class io.prestosql.spi.statistics.ComputedStatistics.Builder
 
addRow(Object...) - Method in class io.prestosql.spi.connector.InMemoryRecordSet.Builder
 
addTableStatistic(TableStatisticType, Block) - Method in class io.prestosql.spi.statistics.ComputedStatistics.Builder
 
addWithOverflow(Slice, Slice, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
Instead of throwing overflow exception, this function returns: 0 when there was no overflow +1 when there was overflow -1 when there was underflow
ADMINISTRATIVELY_KILLED - io.prestosql.spi.StandardErrorCode
 
ADMINISTRATIVELY_PREEMPTED - io.prestosql.spi.StandardErrorCode
 
advanceNextPosition() - Method in interface io.prestosql.spi.connector.RecordCursor
 
AggregateFunction - Class in io.prestosql.spi.connector
 
AggregateFunction(String, Type, List<ConnectorExpression>, List<SortItem>, boolean, Optional<ConnectorExpression>) - Constructor for class io.prestosql.spi.connector.AggregateFunction
 
AggregationApplicationResult<T> - Class in io.prestosql.spi.connector
 
AggregationApplicationResult(T, List<ConnectorExpression>, List<Assignment>, Map<ColumnHandle, ColumnHandle>) - Constructor for class io.prestosql.spi.connector.AggregationApplicationResult
 
AggregationFunction - Annotation Type in io.prestosql.spi.function
 
AggregationState - Annotation Type in io.prestosql.spi.function
 
AggregationStateSerializerFactory - Annotation Type in io.prestosql.spi.function
 
alias() - Method in annotation type io.prestosql.spi.function.AggregationFunction
 
alias() - Method in annotation type io.prestosql.spi.function.ScalarFunction
 
all() - Static method in class io.prestosql.spi.predicate.TupleDomain
 
all(Type) - Static method in class io.prestosql.spi.predicate.Domain
 
all(Type) - Static method in class io.prestosql.spi.predicate.Range
 
all(Type) - Static method in interface io.prestosql.spi.predicate.ValueSet
 
ALL - io.prestosql.spi.security.SelectedRole.Type
 
ALL_COORDINATORS - io.prestosql.spi.connector.SystemTable.Distribution
 
ALL_NODES - io.prestosql.spi.connector.SystemTable.Distribution
 
AllOrNone - Interface in io.prestosql.spi.predicate
 
AllOrNoneValueSet - Class in io.prestosql.spi.predicate
Set that either includes all values, or excludes all values.
AllOrNoneValueSet(Type, boolean) - Constructor for class io.prestosql.spi.predicate.AllOrNoneValueSet
 
ALREADY_EXISTS - io.prestosql.spi.StandardErrorCode
 
alwaysFalse() - Static method in class io.prestosql.spi.connector.Constraint
 
alwaysTrue() - Static method in class io.prestosql.spi.connector.Constraint
 
AMBIGUOUS_FUNCTION_CALL - io.prestosql.spi.StandardErrorCode
 
AMBIGUOUS_FUNCTION_IMPLEMENTATION - io.prestosql.spi.StandardErrorCode
 
AMBIGUOUS_NAME - io.prestosql.spi.StandardErrorCode
 
ANALYZE - io.prestosql.spi.resourcegroups.QueryType
 
anonymous(List<Type>) - Static method in class io.prestosql.spi.type.RowType
 
anonymousField(TypeSignature) - Static method in class io.prestosql.spi.type.TypeSignatureParameter
 
anonymousRow(Type...) - Static method in class io.prestosql.spi.type.RowType
 
appendColumn(Block) - Method in class io.prestosql.spi.Page
 
appendNull() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
appendNull() - Method in interface io.prestosql.spi.block.BlockBuilder
Appends a null value to the block.
appendNull() - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
appendNull() - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
appendNull() - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
appendNull() - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
appendNull() - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
appendNull() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
appendNull() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
appendNull() - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
appendNull() - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
appendNull() - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
appendNull() - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
appendNull() - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
appendPage(Page) - Method in interface io.prestosql.spi.connector.ConnectorPageSink
Returns a future that will be completed when the page sink can accept more pages.
appendStructure(Block) - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
appendStructure(Block) - Method in interface io.prestosql.spi.block.BlockBuilder
Append a struct to the block and close the entry.
appendStructure(Block) - Method in class io.prestosql.spi.block.MapBlockBuilder
 
appendStructure(Block) - Method in class io.prestosql.spi.block.RowBlockBuilder
 
appendStructure(Block) - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
appendStructure(Block) - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
appendStructure(Block) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
appendStructureInternal(Block, int) - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
appendStructureInternal(Block, int) - Method in interface io.prestosql.spi.block.BlockBuilder
Do not use this interface outside block package.
appendStructureInternal(Block, int) - Method in class io.prestosql.spi.block.MapBlockBuilder
 
appendStructureInternal(Block, int) - Method in class io.prestosql.spi.block.RowBlockBuilder
 
appendStructureInternal(Block, int) - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
appendStructureInternal(Block, int) - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
appendStructureInternal(Block, int) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
appendTo(int, int, BlockBuilder) - Method in interface io.prestosql.spi.function.WindowIndex
Outputs a value from the index.
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.AbstractIntType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.AbstractLongType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.ArrayType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.BooleanType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.CharType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.DoubleType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.HyperLogLogType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.LongTimestampType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.MapType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.P4HyperLogLogType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.QuantileDigestType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.RowType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.ShortTimestampType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.SmallintType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.TinyintType
 
appendTo(Block, int, BlockBuilder) - Method in interface io.prestosql.spi.type.Type
Append the value at position in block to blockBuilder.
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.VarbinaryType
 
appendTo(Block, int, BlockBuilder) - Method in class io.prestosql.spi.type.VarcharType
 
apply(AbstractArrayBlock.ArrayBlockFunction<T>, int) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
apply(Block, int, int) - Method in interface io.prestosql.spi.block.AbstractArrayBlock.ArrayBlockFunction
 
applyAggregation(ConnectorSession, ConnectorTableHandle, List<AggregateFunction>, Map<String, ColumnHandle>, List<List<ColumnHandle>>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Attempt to push down the aggregates into the table.
applyDelete(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Attempt to push down a delete operation into the connector.
applyFilter(ConnectorSession, ConnectorTableHandle, Constraint) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Attempt to push down the provided constraint into the table.
applyLimit(ConnectorSession, ConnectorTableHandle, long) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Attempt to push down the provided limit into the table.
applyProjection(ConnectorSession, ConnectorTableHandle, List<ConnectorExpression>, Map<String, ColumnHandle>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Attempt to push down the provided projections into the table.
applySample(ConnectorSession, ConnectorTableHandle, SampleType, double) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Attempt to push down the sampling into the table.
Argument(String, Type) - Constructor for class io.prestosql.spi.procedure.Procedure.Argument
 
Argument(String, Type, boolean, Object) - Constructor for class io.prestosql.spi.procedure.Procedure.Argument
 
arguments() - Method in annotation type io.prestosql.spi.function.Convention
 
argumentTypes() - Method in annotation type io.prestosql.spi.function.FunctionDependency
 
argumentTypes() - Method in annotation type io.prestosql.spi.function.OperatorDependency
 
argumentTypes() - Method in annotation type io.prestosql.spi.function.WindowFunctionSignature
 
ARRAY - Static variable in class io.prestosql.spi.type.StandardTypes
 
ARRAY_NULL_ELEMENT_MSG - Static variable in class io.prestosql.spi.type.ArrayType
 
ArrayBlock - Class in io.prestosql.spi.block
 
ArrayBlockBuilder - Class in io.prestosql.spi.block
 
ArrayBlockBuilder(BlockBuilder, BlockBuilderStatus, int) - Constructor for class io.prestosql.spi.block.ArrayBlockBuilder
Caller of this constructor is responsible for making sure `valuesBlock` is constructed with the same `blockBuilderStatus` as the one in the argument
ArrayBlockBuilder(Type, BlockBuilderStatus, int) - Constructor for class io.prestosql.spi.block.ArrayBlockBuilder
 
ArrayBlockBuilder(Type, BlockBuilderStatus, int, int) - Constructor for class io.prestosql.spi.block.ArrayBlockBuilder
 
ArrayBlockEncoding - Class in io.prestosql.spi.block
 
ArrayBlockEncoding() - Constructor for class io.prestosql.spi.block.ArrayBlockEncoding
 
arrayType(TypeSignature) - Static method in class io.prestosql.spi.type.TypeSignature
 
arrayType(TypeSignatureParameter) - Static method in class io.prestosql.spi.type.TypeSignature
 
ArrayType - Class in io.prestosql.spi.type
 
ArrayType(Type) - Constructor for class io.prestosql.spi.type.ArrayType
 
asBlock() - Method in class io.prestosql.spi.predicate.NullableValue
 
ASC_NULLS_FIRST - io.prestosql.spi.block.SortOrder
 
ASC_NULLS_FIRST - io.prestosql.spi.connector.SortOrder
 
ASC_NULLS_LAST - io.prestosql.spi.block.SortOrder
 
ASC_NULLS_LAST - io.prestosql.spi.connector.SortOrder
 
asNull(Type) - Static method in class io.prestosql.spi.predicate.NullableValue
 
Assignment - Class in io.prestosql.spi.connector
 
Assignment(String, ColumnHandle, Type) - Constructor for class io.prestosql.spi.connector.Assignment
 
authenticate(List<X509Certificate>) - Method in interface io.prestosql.spi.security.CertificateAuthenticator
Authenticate and extract principal from client certificate.
AUTOCOMMIT_WRITE_CONFLICT - io.prestosql.spi.StandardErrorCode
 

B

BasicPrincipal - Class in io.prestosql.spi.security
 
BasicPrincipal(String) - Constructor for class io.prestosql.spi.security.BasicPrincipal
 
beginBlockEntry() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
beginBlockEntry() - Method in interface io.prestosql.spi.block.BlockBuilder
Return a writer to the current entry.
beginBlockEntry() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
beginBlockEntry() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
beginBlockEntry() - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
beginBlockEntry() - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
beginBlockEntry() - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
beginCreateTable(ConnectorSession, ConnectorTableMetadata, Optional<ConnectorNewTableLayout>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Begin the atomic creation of a table with data.
beginDelete(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Begin delete query
beginInsert(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
beginInsert(ConnectorSession, ConnectorTableHandle, List<ColumnHandle>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Begin insert query
beginQuery(ConnectorSession) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Start a query.
beginStatisticsCollection(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Begin statistics collection
beginTransaction(IsolationLevel, boolean) - Method in interface io.prestosql.spi.connector.Connector
 
below(Type, Object) - Static method in class io.prestosql.spi.predicate.Marker
 
BELOW - io.prestosql.spi.predicate.Marker.Bound
 
BERNOULLI - io.prestosql.spi.connector.SampleType
 
BIGINT - Static variable in class io.prestosql.spi.type.BigintType
 
BIGINT - Static variable in class io.prestosql.spi.type.StandardTypes
 
bigIntegerTenToNth(int) - Static method in class io.prestosql.spi.type.Decimals
 
BigintType - Class in io.prestosql.spi.type
 
BING_TILE - Static variable in class io.prestosql.spi.type.StandardTypes
 
Block - Interface in io.prestosql.spi.block
 
BLOCK_POSITION - io.prestosql.spi.function.InvocationConvention.InvocationArgumentConvention
Argument is passed a Block followed by the integer position in the block.
BlockBuilder - Interface in io.prestosql.spi.block
 
BlockBuilderStatus - Class in io.prestosql.spi.block
 
BlockEncoding - Interface in io.prestosql.spi.block
 
BlockEncodingSerde - Interface in io.prestosql.spi.block
 
BlockIndex - Annotation Type in io.prestosql.spi.function
 
BlockPosition - Annotation Type in io.prestosql.spi.function
 
BOOLEAN - Static variable in class io.prestosql.spi.type.BooleanType
 
BOOLEAN - Static variable in class io.prestosql.spi.type.StandardTypes
 
booleanProperty(String, String, Boolean, boolean) - Static method in class io.prestosql.spi.session.PropertyMetadata
 
BooleanType - Class in io.prestosql.spi.type
 
BOXED_NULLABLE - io.prestosql.spi.function.InvocationConvention.InvocationArgumentConvention
Argument is always an object type.
BucketFunction - Interface in io.prestosql.spi.connector
 
build() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
build() - Method in interface io.prestosql.spi.block.BlockBuilder
Builds the block.
build() - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
build() - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
build() - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
build() - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
build() - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
build() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
build() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
build() - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
build() - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
build() - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
build() - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
build() - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
build() - Method in class io.prestosql.spi.connector.ColumnMetadata.Builder
 
build() - Method in class io.prestosql.spi.connector.InMemoryRecordSet.Builder
 
build() - Method in class io.prestosql.spi.PageBuilder
 
build() - Method in class io.prestosql.spi.security.ConnectorIdentity.Builder
 
build() - Method in class io.prestosql.spi.security.Identity.Builder
 
build() - Method in class io.prestosql.spi.statistics.ColumnStatistics.Builder
 
build() - Method in class io.prestosql.spi.statistics.ComputedStatistics.Builder
 
build() - Method in class io.prestosql.spi.statistics.TableStatistics.Builder
 
builder() - Static method in class io.prestosql.spi.connector.ColumnMetadata
 
builder() - Static method in class io.prestosql.spi.statistics.ColumnStatistics
 
builder() - Static method in class io.prestosql.spi.statistics.TableStatistics
 
builder(ConnectorTableMetadata) - Static method in class io.prestosql.spi.connector.InMemoryRecordSet
 
builder(Collection<Type>) - Static method in class io.prestosql.spi.connector.InMemoryRecordSet
 
builder(List<ColumnMetadata>) - Static method in class io.prestosql.spi.connector.InMemoryRecordSet
 
builder(List<String>, List<Block>) - Static method in class io.prestosql.spi.statistics.ComputedStatistics
 
Builder() - Constructor for class io.prestosql.spi.statistics.ColumnStatistics.Builder
 
Builder() - Constructor for class io.prestosql.spi.statistics.TableStatistics.Builder
 
Builder(String) - Constructor for class io.prestosql.spi.security.Identity.Builder
 
builderFrom(ColumnMetadata) - Static method in class io.prestosql.spi.connector.ColumnMetadata
 
ByteArrayBlock - Class in io.prestosql.spi.block
 
ByteArrayBlock(int, Optional<boolean[]>, byte[]) - Constructor for class io.prestosql.spi.block.ByteArrayBlock
 
ByteArrayBlockBuilder - Class in io.prestosql.spi.block
 
ByteArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.prestosql.spi.block.ByteArrayBlockBuilder
 
ByteArrayBlockEncoding - Class in io.prestosql.spi.block
 
ByteArrayBlockEncoding() - Constructor for class io.prestosql.spi.block.ByteArrayBlockEncoding
 
byteCount(Slice, int, int, int) - Static method in class io.prestosql.spi.type.Varchars
Get the byte count of a given {@param slice} with in range {@param offset} to {@param offset} + {@param length} for at most {@param codePointCount} many code points
byteCountWithoutTrailingSpace(Slice, int, int) - Static method in class io.prestosql.spi.type.Chars
 
byteCountWithoutTrailingSpace(Slice, int, int, int) - Static method in class io.prestosql.spi.type.Chars
 
bytesCompare(int, int, int, Slice, int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
bytesCompare(int, int, int, Slice, int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
bytesCompare(int, int, int, Slice, int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
bytesCompare(int, int, int, Slice, int, int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
bytesCompare(int, int, int, Slice, int, int) - Method in interface io.prestosql.spi.block.Block
Compares the byte sequences at offset in the value at position to the byte sequence at otherOffset in otherSlice.
bytesCompare(int, int, int, Slice, int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
bytesCompare(int, int, int, Slice, int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
bytesCompare(int, int, int, Slice, int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
bytesEqual(int, int, Slice, int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
bytesEqual(int, int, Slice, int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
bytesEqual(int, int, Slice, int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
bytesEqual(int, int, Slice, int, int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
bytesEqual(int, int, Slice, int, int) - Method in interface io.prestosql.spi.block.Block
Is the byte sequences at offset in the value at position equal to the byte sequence at otherOffset in otherSlice.
bytesEqual(int, int, Slice, int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
bytesEqual(int, int, Slice, int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
bytesEqual(int, int, Slice, int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 

C

CAN_QUEUE - io.prestosql.spi.resourcegroups.ResourceGroupState
 
CAN_RUN - io.prestosql.spi.resourcegroups.ResourceGroupState
 
CAST - io.prestosql.spi.function.OperatorType
 
CastDependency - Annotation Type in io.prestosql.spi.function
 
CATALOG_NOT_FOUND - io.prestosql.spi.StandardErrorCode
 
CatalogSchemaName - Class in io.prestosql.spi.connector
 
CatalogSchemaName(String, String) - Constructor for class io.prestosql.spi.connector.CatalogSchemaName
 
CatalogSchemaRoutineName - Class in io.prestosql.spi.connector
 
CatalogSchemaRoutineName(String, SchemaRoutineName) - Constructor for class io.prestosql.spi.connector.CatalogSchemaRoutineName
 
CatalogSchemaRoutineName(String, String, String) - Constructor for class io.prestosql.spi.connector.CatalogSchemaRoutineName
 
CatalogSchemaTableName - Class in io.prestosql.spi.connector
 
CatalogSchemaTableName(String, SchemaTableName) - Constructor for class io.prestosql.spi.connector.CatalogSchemaTableName
 
CatalogSchemaTableName(String, String, String) - Constructor for class io.prestosql.spi.connector.CatalogSchemaTableName
 
CertificateAuthenticator - Interface in io.prestosql.spi.security
 
CertificateAuthenticatorFactory - Interface in io.prestosql.spi.security
 
CHAR - Static variable in class io.prestosql.spi.type.StandardTypes
 
Chars - Class in io.prestosql.spi.type
 
CharType - Class in io.prestosql.spi.type
 
checkCanAccessCatalog(SystemSecurityContext, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to access the specified catalog
checkCanAddColumn(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to add columns to the specified table in this catalog.
checkCanAddColumn(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to add columns to the specified table in a catalog.
checkCanCreateRole(ConnectorSecurityContext, String, Optional<PrestoPrincipal>) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
 
checkCanCreateSchema(ConnectorSecurityContext, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to create the specified schema in this catalog.
checkCanCreateSchema(SystemSecurityContext, CatalogSchemaName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to create the specified schema in a catalog.
checkCanCreateTable(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to create the specified table in this catalog.
checkCanCreateTable(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to create the specified table in a catalog.
checkCanCreateView(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to create the specified view in this catalog.
checkCanCreateView(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to create the specified view in a catalog.
checkCanCreateViewWithSelectFromColumns(ConnectorSecurityContext, SchemaTableName, Set<String>) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to create a view that selects from the specified columns in a relation.
checkCanCreateViewWithSelectFromColumns(SystemSecurityContext, CatalogSchemaTableName, Set<String>) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to create a view that selects from the specified columns in a relation.
checkCanDeleteFromTable(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to delete from the specified table in this catalog.
checkCanDeleteFromTable(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to delete from the specified table in a catalog.
checkCanDropColumn(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to drop columns from the specified table in this catalog.
checkCanDropColumn(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to drop columns from the specified table in a catalog.
checkCanDropRole(ConnectorSecurityContext, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
 
checkCanDropSchema(ConnectorSecurityContext, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to drop the specified schema in this catalog.
checkCanDropSchema(SystemSecurityContext, CatalogSchemaName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to drop the specified schema in a catalog.
checkCanDropTable(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to drop the specified table in this catalog.
checkCanDropTable(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to drop the specified table in a catalog.
checkCanDropView(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to drop the specified view in this catalog.
checkCanDropView(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to drop the specified view in a catalog.
checkCanExecuteFunction(SystemSecurityContext, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to execute the specified function
checkCanExecuteProcedure(ConnectorSecurityContext, SchemaRoutineName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
 
checkCanExecuteProcedure(SystemSecurityContext, CatalogSchemaRoutineName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to execute the specified procedure
checkCanExecuteQuery(SystemSecurityContext) - Method in interface io.prestosql.spi.security.SystemAccessControl
Checks if identity can execute a query.
checkCanGrantExecuteFunctionPrivilege(SystemSecurityContext, String, PrestoPrincipal, boolean) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to grant an access to the function execution to grantee.
checkCanGrantRoles(ConnectorSecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
 
checkCanGrantTablePrivilege(ConnectorSecurityContext, Privilege, SchemaTableName, PrestoPrincipal, boolean) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to grant to any other user the specified privilege on the specified table.
checkCanGrantTablePrivilege(SystemSecurityContext, Privilege, CatalogSchemaTableName, PrestoPrincipal, boolean) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to grant the specified privilege to the grantee on the specified table.
checkCanImpersonateUser(SystemSecurityContext, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if the identity is allowed impersonate the specified user.
checkCanInsertIntoTable(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to insert into the specified table in this catalog.
checkCanInsertIntoTable(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to insert into the specified table in a catalog.
checkCanKillQueryOwnedBy(SystemSecurityContext, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
Checks if identity can kill a query owned by the specified user.
checkCanRenameColumn(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to rename a column in the specified table in this catalog.
checkCanRenameColumn(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to rename a column in the specified table in a catalog.
checkCanRenameSchema(ConnectorSecurityContext, String, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to rename the specified schema in this catalog.
checkCanRenameSchema(SystemSecurityContext, CatalogSchemaName, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to rename the specified schema in a catalog.
checkCanRenameTable(ConnectorSecurityContext, SchemaTableName, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to rename the specified table in this catalog.
checkCanRenameTable(SystemSecurityContext, CatalogSchemaTableName, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to rename the specified table in a catalog.
checkCanRenameView(ConnectorSecurityContext, SchemaTableName, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to rename the specified view in this catalog.
checkCanRenameView(SystemSecurityContext, CatalogSchemaTableName, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to rename the specified view in a catalog.
checkCanRevokeRoles(ConnectorSecurityContext, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
 
checkCanRevokeTablePrivilege(ConnectorSecurityContext, Privilege, SchemaTableName, PrestoPrincipal, boolean) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to revoke the specified privilege on the specified table from any user.
checkCanRevokeTablePrivilege(SystemSecurityContext, Privilege, CatalogSchemaTableName, PrestoPrincipal, boolean) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to revoke the specified privilege on the specified table from the revokee.
checkCanSelectFromColumns(ConnectorSecurityContext, SchemaTableName, Set<String>) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to select from the specified columns in a relation.
checkCanSelectFromColumns(SystemSecurityContext, CatalogSchemaTableName, Set<String>) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to select from the specified columns in a relation.
checkCanSetCatalogSessionProperty(ConnectorSecurityContext, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to set the specified property in this catalog.
checkCanSetCatalogSessionProperty(SystemSecurityContext, String, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to set the specified property in a catalog.
checkCanSetRole(ConnectorSecurityContext, String, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
 
checkCanSetSchemaAuthorization(ConnectorSecurityContext, String, PrestoPrincipal) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to change the specified schema's user/role.
checkCanSetSchemaAuthorization(SystemSecurityContext, CatalogSchemaName, PrestoPrincipal) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to change the specified schema's user/role.
checkCanSetSystemSessionProperty(SystemSecurityContext, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to set the specified system property.
checkCanSetTableComment(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to comment the specified table in this catalog.
checkCanSetTableComment(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to comment the specified table in a catalog.
checkCanSetUser(Optional<Principal>, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
checkCanShowColumns(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to show columns of tables by executing SHOW COLUMNS, DESCRIBE etc.
checkCanShowColumns(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to show columns of tables by executing SHOW COLUMNS, DESCRIBE etc.
checkCanShowCreateSchema(ConnectorSecurityContext, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to execute SHOW CREATE SCHEMA.
checkCanShowCreateSchema(SystemSecurityContext, CatalogSchemaName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to execute SHOW CREATE SCHEMA.
checkCanShowCreateTable(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to execute SHOW CREATE TABLE or SHOW CREATE VIEW.
checkCanShowCreateTable(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to execute SHOW CREATE TABLE or SHOW CREATE VIEW.
checkCanShowCurrentRoles(ConnectorSecurityContext, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to show current roles on the specified catalog.
checkCanShowRoleAuthorizationDescriptors(ConnectorSecurityContext, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to show role authorization descriptors (i.e.
checkCanShowRoleGrants(ConnectorSecurityContext, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to show its own role grants on the specified catalog.
checkCanShowRoles(ConnectorSecurityContext, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to show roles on the specified catalog.
checkCanShowRoles(SystemSecurityContext, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to show roles on the specified catalog.
checkCanShowSchemas(ConnectorSecurityContext) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to execute SHOW SCHEMAS in a catalog.
checkCanShowSchemas(SystemSecurityContext, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to execute SHOW SCHEMAS in a catalog.
checkCanShowTables(ConnectorSecurityContext, String) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Check if identity is allowed to show metadata of tables by executing SHOW TABLES, SHOW GRANTS etc.
checkCanShowTables(SystemSecurityContext, CatalogSchemaName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Check if identity is allowed to show metadata of tables by executing SHOW TABLES, SHOW GRANTS etc.
checkCanViewQueryOwnedBy(SystemSecurityContext, String) - Method in interface io.prestosql.spi.security.SystemAccessControl
Checks if identity can view a query owned by the specified user.
checkConnectorSupports(IsolationLevel, IsolationLevel) - Static method in enum io.prestosql.spi.transaction.IsolationLevel
 
checkOverflow(BigInteger) - Static method in class io.prestosql.spi.type.Decimals
 
checkReadablePosition(int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
cleanupQuery(ConnectorSession) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Cleanup after a query.
close() - Method in class io.prestosql.spi.classloader.ThreadContextClassLoader
 
close() - Method in interface io.prestosql.spi.connector.ConnectorPageSource
Immediately finishes this page source.
close() - Method in interface io.prestosql.spi.connector.ConnectorSplitSource
 
close() - Method in class io.prestosql.spi.connector.EmptyPageSource
 
close() - Method in class io.prestosql.spi.connector.FixedPageSource
 
close() - Method in class io.prestosql.spi.connector.FixedSplitSource
 
close() - Method in interface io.prestosql.spi.connector.RecordCursor
 
close() - Method in class io.prestosql.spi.connector.RecordPageSource
 
closeEntry() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
closeEntry() - Method in interface io.prestosql.spi.block.BlockBuilder
Write a byte to the current entry;
closeEntry() - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
closeEntry() - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
closeEntry() - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
closeEntry() - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
closeEntry() - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
closeEntry() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
closeEntry() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
closeEntry() - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
closeEntry() - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
closeEntry() - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
closeEntry() - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
closeEntry() - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
closeEntryStrict() - Method in class io.prestosql.spi.block.MapBlockBuilder
This method will check duplicate keys and close entry.
CLUSTER_OUT_OF_MEMORY - io.prestosql.spi.StandardErrorCode
 
ClusterMemoryPoolManager - Interface in io.prestosql.spi.memory
 
COLUMN_ALREADY_EXISTS - io.prestosql.spi.StandardErrorCode
 
COLUMN_NOT_FOUND - io.prestosql.spi.StandardErrorCode
 
COLUMN_TYPE_UNKNOWN - io.prestosql.spi.StandardErrorCode
 
ColumnarArray - Class in io.prestosql.spi.block
 
ColumnarMap - Class in io.prestosql.spi.block
 
ColumnarRow - Class in io.prestosql.spi.block
 
ColumnDomain(C, Domain) - Constructor for class io.prestosql.spi.predicate.TupleDomain.ColumnDomain
 
ColumnHandle - Interface in io.prestosql.spi.connector
 
ColumnInfo - Class in io.prestosql.spi.eventlistener
 
ColumnInfo(String, List<String>) - Constructor for class io.prestosql.spi.eventlistener.ColumnInfo
 
ColumnMetadata - Class in io.prestosql.spi.connector
 
ColumnMetadata(String, Type) - Constructor for class io.prestosql.spi.connector.ColumnMetadata
 
ColumnMetadata(String, Type, boolean, String, String, boolean, Map<String, Object>) - Constructor for class io.prestosql.spi.connector.ColumnMetadata
Deprecated.
ColumnMetadata(String, Type, String) - Constructor for class io.prestosql.spi.connector.ColumnMetadata
Deprecated.
ColumnMetadata(String, Type, String, boolean) - Constructor for class io.prestosql.spi.connector.ColumnMetadata
Deprecated.
ColumnMetadata(String, Type, String, String, boolean) - Constructor for class io.prestosql.spi.connector.ColumnMetadata
Deprecated.
ColumnMetadata(String, Type, String, String, boolean, Map<String, Object>) - Constructor for class io.prestosql.spi.connector.ColumnMetadata
Deprecated.
ColumnMetadata.Builder - Class in io.prestosql.spi.connector
 
ColumnNotFoundException - Exception in io.prestosql.spi.connector
 
ColumnNotFoundException(SchemaTableName, String) - Constructor for exception io.prestosql.spi.connector.ColumnNotFoundException
 
ColumnNotFoundException(SchemaTableName, String, String) - Constructor for exception io.prestosql.spi.connector.ColumnNotFoundException
 
ColumnNotFoundException(SchemaTableName, String, String, Throwable) - Constructor for exception io.prestosql.spi.connector.ColumnNotFoundException
 
ColumnNotFoundException(SchemaTableName, String, Throwable) - Constructor for exception io.prestosql.spi.connector.ColumnNotFoundException
 
ColumnStatisticMetadata - Class in io.prestosql.spi.statistics
 
ColumnStatisticMetadata(String, ColumnStatisticType) - Constructor for class io.prestosql.spi.statistics.ColumnStatisticMetadata
 
ColumnStatistics - Class in io.prestosql.spi.statistics
 
ColumnStatistics(Estimate, Estimate, Estimate, Optional<DoubleRange>) - Constructor for class io.prestosql.spi.statistics.ColumnStatistics
 
ColumnStatistics.Builder - Class in io.prestosql.spi.statistics
If one of the estimates below is unspecified (i.e.
ColumnStatisticType - Enum in io.prestosql.spi.statistics
 
columnWiseUnion(TupleDomain<T>, TupleDomain<T>, TupleDomain<T>...) - Static method in class io.prestosql.spi.predicate.TupleDomain
 
columnWiseUnion(List<TupleDomain<T>>) - Static method in class io.prestosql.spi.predicate.TupleDomain
Returns a TupleDomain in which corresponding column Domains are unioned together.
CombineFunction - Annotation Type in io.prestosql.spi.function
A function annotated with @CombineFunction is one that will be used to combine two states into one in aggregation functions.
commit(ConnectorTransactionHandle) - Method in interface io.prestosql.spi.connector.Connector
Commit the transaction.
compact() - Method in class io.prestosql.spi.block.DictionaryBlock
 
compact() - Method in class io.prestosql.spi.Page
 
compare(long, long, long, long) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
compare(Slice, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
compareAbsolute(Slice, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
compareBlockValue(Type, Block, int, Block, int) - Method in enum io.prestosql.spi.block.SortOrder
Compares the values at the specified positions.
compareChars(Slice, Slice) - Static method in class io.prestosql.spi.type.Chars
 
compareTo(int, int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
compareTo(int, int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
compareTo(int, int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
compareTo(int, int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
compareTo(int, int, int, Block, int, int, int) - Method in interface io.prestosql.spi.block.Block
Compares the byte sequences at offset in the value at position to the byte sequence at otherOffset in the value at otherPosition in otherBlock.
compareTo(int, int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
compareTo(int, int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
compareTo(int, int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.AbstractIntType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.AbstractLongType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.AbstractType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.ArrayType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.BooleanType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.CharType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.DoubleType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.LongTimestampType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.RealType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.RowType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.ShortTimestampType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.SmallintType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.TimestampWithTimeZoneType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.TimeWithTimeZoneType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.TinyintType
 
compareTo(Block, int, Block, int) - Method in interface io.prestosql.spi.type.Type
Compare the values in the specified block at the specified positions.
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.VarbinaryType
 
compareTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.VarcharType
 
compareTo(Marker) - Method in class io.prestosql.spi.predicate.Marker
 
compareTo(SqlVarbinary) - Method in class io.prestosql.spi.type.SqlVarbinary
 
compareUnsigned(long, long, long, long) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
COMPILER_ERROR - io.prestosql.spi.StandardErrorCode
 
complement() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
complement() - Method in class io.prestosql.spi.predicate.Domain
 
complement() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
complement() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
complement() - Method in interface io.prestosql.spi.predicate.ValueSet
 
compose(MethodHandle, MethodHandle) - Static method in class io.prestosql.spi.block.MethodHandleUtil
 
compose(MethodHandle, MethodHandle, MethodHandle) - Static method in class io.prestosql.spi.block.MethodHandleUtil
 
ComputedStatistics - Class in io.prestosql.spi.statistics
 
ComputedStatistics.Builder - Class in io.prestosql.spi.statistics
 
CONFIGURATION_INVALID - io.prestosql.spi.StandardErrorCode
 
CONFIGURATION_UNAVAILABLE - io.prestosql.spi.StandardErrorCode
 
configure(ResourceGroup, SelectionContext<C>) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroupConfigurationManager
Implementations may retain a reference to the group, and re-configure it asynchronously.
Connector - Interface in io.prestosql.spi.connector
 
ConnectorAccessControl - Interface in io.prestosql.spi.connector
 
ConnectorBucketNodeMap - Class in io.prestosql.spi.connector
 
ConnectorCapabilities - Enum in io.prestosql.spi.connector
 
ConnectorContext - Interface in io.prestosql.spi.connector
 
ConnectorExpression - Class in io.prestosql.spi.expression
 
ConnectorExpression(Type) - Constructor for class io.prestosql.spi.expression.ConnectorExpression
 
ConnectorFactory - Interface in io.prestosql.spi.connector
 
ConnectorHandleResolver - Interface in io.prestosql.spi.connector
 
ConnectorIdentity - Class in io.prestosql.spi.security
 
ConnectorIdentity(String, Optional<Principal>, Optional<SelectedRole>) - Constructor for class io.prestosql.spi.security.ConnectorIdentity
Deprecated.
ConnectorIdentity(String, Optional<Principal>, Optional<SelectedRole>, Map<String, String>) - Constructor for class io.prestosql.spi.security.ConnectorIdentity
Deprecated.
ConnectorIdentity.Builder - Class in io.prestosql.spi.security
 
ConnectorIndex - Interface in io.prestosql.spi.connector
 
ConnectorIndexHandle - Interface in io.prestosql.spi.connector
 
ConnectorIndexProvider - Interface in io.prestosql.spi.connector
 
ConnectorInsertTableHandle - Interface in io.prestosql.spi.connector
 
ConnectorMetadata - Interface in io.prestosql.spi.connector
 
ConnectorNewTableLayout - Class in io.prestosql.spi.connector
 
ConnectorNewTableLayout(ConnectorPartitioningHandle, List<String>) - Constructor for class io.prestosql.spi.connector.ConnectorNewTableLayout
 
ConnectorNewTableLayout(List<String>) - Constructor for class io.prestosql.spi.connector.ConnectorNewTableLayout
Creates a preferred table layout that is evenly partitioned on given columns by the engine.
ConnectorNodePartitioningProvider - Interface in io.prestosql.spi.connector
 
ConnectorOutputMetadata - Interface in io.prestosql.spi.connector
Connectors can choose to return ConnectorOutputMetadata from finishInsert or finishCreate.
ConnectorOutputTableHandle - Interface in io.prestosql.spi.connector
 
ConnectorPageSink - Interface in io.prestosql.spi.connector
 
ConnectorPageSinkProvider - Interface in io.prestosql.spi.connector
 
ConnectorPageSource - Interface in io.prestosql.spi.connector
 
ConnectorPageSourceProvider - Interface in io.prestosql.spi.connector
 
ConnectorPartitionHandle - Class in io.prestosql.spi.connector
 
ConnectorPartitionHandle() - Constructor for class io.prestosql.spi.connector.ConnectorPartitionHandle
 
ConnectorPartitioningHandle - Interface in io.prestosql.spi.connector
 
ConnectorRecordSetProvider - Interface in io.prestosql.spi.connector
 
ConnectorResolvedIndex - Class in io.prestosql.spi.connector
 
ConnectorResolvedIndex(ConnectorIndexHandle, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.spi.connector.ConnectorResolvedIndex
 
ConnectorSecurityContext - Class in io.prestosql.spi.connector
 
ConnectorSecurityContext(ConnectorTransactionHandle, ConnectorIdentity, QueryId) - Constructor for class io.prestosql.spi.connector.ConnectorSecurityContext
 
ConnectorSession - Interface in io.prestosql.spi.connector
 
ConnectorSplit - Interface in io.prestosql.spi.connector
 
ConnectorSplitBatch(List<ConnectorSplit>, boolean) - Constructor for class io.prestosql.spi.connector.ConnectorSplitSource.ConnectorSplitBatch
 
ConnectorSplitManager - Interface in io.prestosql.spi.connector
 
ConnectorSplitManager.SplitSchedulingStrategy - Enum in io.prestosql.spi.connector
 
ConnectorSplitSource - Interface in io.prestosql.spi.connector
 
ConnectorSplitSource.ConnectorSplitBatch - Class in io.prestosql.spi.connector
 
ConnectorTableHandle - Interface in io.prestosql.spi.connector
 
ConnectorTableLayout - Class in io.prestosql.spi.connector
Deprecated.
ConnectorTableLayout(ConnectorTableLayoutHandle) - Constructor for class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
 
ConnectorTableLayout(ConnectorTableLayoutHandle, Optional<List<ColumnHandle>>, TupleDomain<ColumnHandle>, Optional<ConnectorTablePartitioning>, Optional<Set<ColumnHandle>>, Optional<DiscretePredicates>, List<LocalProperty<ColumnHandle>>) - Constructor for class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
 
ConnectorTableLayoutHandle - Interface in io.prestosql.spi.connector
Deprecated.
ConnectorTableLayoutResult - Class in io.prestosql.spi.connector
 
ConnectorTableLayoutResult(ConnectorTableLayout, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.spi.connector.ConnectorTableLayoutResult
 
ConnectorTableMetadata - Class in io.prestosql.spi.connector
 
ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>) - Constructor for class io.prestosql.spi.connector.ConnectorTableMetadata
 
ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>, Map<String, Object>) - Constructor for class io.prestosql.spi.connector.ConnectorTableMetadata
 
ConnectorTableMetadata(SchemaTableName, List<ColumnMetadata>, Map<String, Object>, Optional<String>) - Constructor for class io.prestosql.spi.connector.ConnectorTableMetadata
 
ConnectorTablePartitioning - Class in io.prestosql.spi.connector
The partitioning of split groups in a table.
ConnectorTablePartitioning(ConnectorPartitioningHandle, List<ColumnHandle>) - Constructor for class io.prestosql.spi.connector.ConnectorTablePartitioning
 
ConnectorTableProperties - Class in io.prestosql.spi.connector
 
ConnectorTableProperties() - Constructor for class io.prestosql.spi.connector.ConnectorTableProperties
 
ConnectorTableProperties(ConnectorTableLayout) - Constructor for class io.prestosql.spi.connector.ConnectorTableProperties
Deprecated.
ConnectorTableProperties(TupleDomain<ColumnHandle>, Optional<ConnectorTablePartitioning>, Optional<Set<ColumnHandle>>, Optional<DiscretePredicates>, List<LocalProperty<ColumnHandle>>) - Constructor for class io.prestosql.spi.connector.ConnectorTableProperties
 
ConnectorTransactionHandle - Interface in io.prestosql.spi.connector
 
ConnectorViewDefinition - Class in io.prestosql.spi.connector
 
ConnectorViewDefinition(String, Optional<String>, Optional<String>, List<ConnectorViewDefinition.ViewColumn>, Optional<String>, Optional<String>, boolean) - Constructor for class io.prestosql.spi.connector.ConnectorViewDefinition
 
ConnectorViewDefinition.ViewColumn - Class in io.prestosql.spi.connector
 
Constant - Class in io.prestosql.spi.expression
 
Constant(Object, Type) - Constructor for class io.prestosql.spi.expression.Constant
 
ConstantProperty<E> - Class in io.prestosql.spi.connector
 
ConstantProperty(E) - Constructor for class io.prestosql.spi.connector.ConstantProperty
 
constrain(Set<E>) - Method in class io.prestosql.spi.connector.GroupingProperty
 
constrain(Set<E>) - Method in interface io.prestosql.spi.connector.LocalProperty
Return a new instance with the give (reduced) set of columns
Constraint - Class in io.prestosql.spi.connector
 
Constraint(TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.spi.connector.Constraint
 
Constraint(TupleDomain<ColumnHandle>, Predicate<Map<ColumnHandle, NullableValue>>) - Constructor for class io.prestosql.spi.connector.Constraint
Deprecated.
Constraint(TupleDomain<ColumnHandle>, Predicate<Map<ColumnHandle, NullableValue>>, Set<ColumnHandle>) - Constructor for class io.prestosql.spi.connector.Constraint
 
Constraint(TupleDomain<ColumnHandle>, Optional<Predicate<Map<ColumnHandle, NullableValue>>>) - Constructor for class io.prestosql.spi.connector.Constraint
Constraint(TupleDomain<ColumnHandle>, Optional<Predicate<Map<ColumnHandle, NullableValue>>>, Optional<Set<ColumnHandle>>) - Constructor for class io.prestosql.spi.connector.Constraint
 
CONSTRAINT_VIOLATION - io.prestosql.spi.StandardErrorCode
 
ConstraintApplicationResult<T> - Class in io.prestosql.spi.connector
 
ConstraintApplicationResult(T, TupleDomain<ColumnHandle>) - Constructor for class io.prestosql.spi.connector.ConstraintApplicationResult
 
consume(Consumer<Ranges>, Consumer<DiscreteValues>, Consumer<AllOrNone>) - Method in interface io.prestosql.spi.predicate.ValuesProcessor
 
contains(Domain) - Method in class io.prestosql.spi.predicate.Domain
 
contains(Range) - Method in class io.prestosql.spi.predicate.Range
 
contains(TupleDomain<T>) - Method in class io.prestosql.spi.predicate.TupleDomain
Returns true only if the this TupleDomain contains all possible tuples that would be allowable by the other TupleDomain.
contains(ValueSet) - Method in interface io.prestosql.spi.predicate.ValueSet
 
containsValue(Object) - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
containsValue(Object) - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
containsValue(Object) - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
containsValue(Object) - Method in interface io.prestosql.spi.predicate.ValueSet
 
convention() - Method in annotation type io.prestosql.spi.function.CastDependency
 
convention() - Method in annotation type io.prestosql.spi.function.FunctionDependency
 
convention() - Method in annotation type io.prestosql.spi.function.OperatorDependency
 
Convention - Annotation Type in io.prestosql.spi.function
 
copyOf(Type, Collection<Object>) - Static method in interface io.prestosql.spi.predicate.ValueSet
 
copyOf(Type, List<Range>) - Static method in class io.prestosql.spi.predicate.SortedRangeSet
 
copyOfRanges(Type, Collection<Range>) - Static method in interface io.prestosql.spi.predicate.ValueSet
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.AbstractMapBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
copyPositions(int[], int, int) - Method in interface io.prestosql.spi.block.Block
Returns a block containing the specified positions.
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.IntArrayBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.LongArrayBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.VariableWidthBlock
 
copyPositions(int[], int, int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.AbstractMapBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
copyRegion(int, int) - Method in interface io.prestosql.spi.block.Block
Returns a block starting at the specified position and extends for the specified length.
copyRegion(int, int) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.IntArrayBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.LongArrayBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.VariableWidthBlock
 
copyRegion(int, int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
CORRUPT_PAGE - io.prestosql.spi.StandardErrorCode
 
CORRUPT_SERIALIZED_IDENTITY - io.prestosql.spi.StandardErrorCode
 
CPU_TIME - Static variable in class io.prestosql.spi.session.ResourceEstimates
 
create(ValueSet, boolean) - Static method in class io.prestosql.spi.predicate.Domain
 
create(Type, Object) - Static method in class io.prestosql.spi.predicate.EquatableValueSet.ValueEntry
 
create(Type, Object, int) - Static method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
create(String, Map<String, String>, ConnectorContext) - Method in interface io.prestosql.spi.connector.ConnectorFactory
 
create(Map<String, String>) - Method in interface io.prestosql.spi.eventlistener.EventListenerFactory
 
create(Map<String, String>) - Method in interface io.prestosql.spi.security.CertificateAuthenticatorFactory
 
create(Map<String, String>) - Method in interface io.prestosql.spi.security.GroupProviderFactory
 
create(Map<String, String>) - Method in interface io.prestosql.spi.security.PasswordAuthenticatorFactory
 
create(Map<String, String>) - Method in interface io.prestosql.spi.security.SystemAccessControlFactory
 
create(Map<String, String>, ResourceGroupConfigurationManagerContext) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroupConfigurationManagerFactory
 
create(Map<String, String>, SessionPropertyConfigurationManagerContext) - Method in interface io.prestosql.spi.session.SessionPropertyConfigurationManagerFactory
 
createAuthenticatedPrincipal(String, String) - Method in interface io.prestosql.spi.security.PasswordAuthenticator
Authenticate the provided user and password.
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.AbstractIntType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.AbstractLongType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.AbstractVariableWidthType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.ArrayType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.BooleanType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.DoubleType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.LongTimestampType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.MapType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.RowType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.ShortTimestampType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.SmallintType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in class io.prestosql.spi.type.TinyintType
 
createBlockBuilder(BlockBuilderStatus, int) - Method in interface io.prestosql.spi.type.Type
Creates the preferred block builder for this type.
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.AbstractIntType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.AbstractLongType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.AbstractVariableWidthType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.ArrayType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.BooleanType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.DoubleType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.LongTimestampType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.MapType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.RowType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.ShortTimestampType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.SmallintType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in class io.prestosql.spi.type.TinyintType
 
createBlockBuilder(BlockBuilderStatus, int, int) - Method in interface io.prestosql.spi.type.Type
Creates the preferred block builder for this type.
createBlockBuilderStatus() - Method in class io.prestosql.spi.block.PageBuilderStatus
 
createBlockFromKeyValue(Optional<boolean[]>, int[], Block, Block) - Method in class io.prestosql.spi.type.MapType
 
createBucketNodeMap(int) - Static method in class io.prestosql.spi.connector.ConnectorBucketNodeMap
 
createBucketNodeMap(List<Node>) - Static method in class io.prestosql.spi.connector.ConnectorBucketNodeMap
 
createCharType(long) - Static method in class io.prestosql.spi.type.CharType
 
createDecimalType() - Static method in class io.prestosql.spi.type.DecimalType
 
createDecimalType(int) - Static method in class io.prestosql.spi.type.DecimalType
 
createDecimalType(int, int) - Static method in class io.prestosql.spi.type.DecimalType
 
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.spi.type.AbstractIntType
 
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.spi.type.AbstractLongType
 
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.spi.type.BooleanType
 
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.spi.type.DoubleType
 
createFixedSizeBlockBuilder(int) - Method in interface io.prestosql.spi.type.FixedWidthType
Creates a block builder for this type sized to hold the specified number of positions.
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.spi.type.LongTimestampType
 
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.spi.type.ShortTimestampType
 
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.spi.type.SmallintType
 
createFixedSizeBlockBuilder(int) - Method in class io.prestosql.spi.type.TinyintType
 
createGroupedState() - Method in interface io.prestosql.spi.function.AccumulatorStateFactory
Return value is also guaranteed to implement GroupedAccumulatorState
createMapBlockInternal(MapType, int, int, Optional<boolean[]>, int[], Block, Block, MapHashTables) - Static method in class io.prestosql.spi.block.MapBlock
Create a map block directly without per element validations.
createPageIndexer(List<? extends Type>) - Method in interface io.prestosql.spi.PageIndexerFactory
 
createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorInsertTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorPageSinkProvider
 
createPageSink(ConnectorTransactionHandle, ConnectorSession, ConnectorOutputTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorPageSinkProvider
 
createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, ConnectorTableHandle, List<ColumnHandle>) - Method in interface io.prestosql.spi.connector.ConnectorPageSourceProvider
createPageSource(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, ConnectorTableHandle, List<ColumnHandle>, TupleDomain<ColumnHandle>) - Method in interface io.prestosql.spi.connector.ConnectorPageSourceProvider
 
createRole(ConnectorSession, String, Optional<PrestoPrincipal>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Creates the specified role.
createSchema(ConnectorSession, String, Map<String, Object>, PrestoPrincipal) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Creates a schema.
createSingleState() - Method in interface io.prestosql.spi.function.AccumulatorStateFactory
 
createTable(ConnectorSession, ConnectorTableMetadata, boolean) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Creates a table using the specified table metadata.
createTimestampType(int) - Static method in class io.prestosql.spi.type.TimestampType
 
createType(TypeManager, List<TypeParameter>) - Method in interface io.prestosql.spi.type.ParametricType
 
createType(TypeManager, List<TypeParameter>) - Method in class io.prestosql.spi.type.QuantileDigestParametricType
 
createType(TypeManager, List<TypeParameter>) - Method in class io.prestosql.spi.type.TimestampParametricType
 
createUnboundedVarcharType() - Static method in class io.prestosql.spi.type.VarcharType
 
createVarcharType(int) - Static method in class io.prestosql.spi.type.VarcharType
 
createView(ConnectorSession, SchemaTableName, ConnectorViewDefinition, boolean) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Create the specified view.
createWithTypeSignature(TypeSignature, List<RowType.Field>) - Static method in class io.prestosql.spi.type.RowType
 
cursor() - Method in class io.prestosql.spi.connector.InMemoryRecordSet
 
cursor() - Method in interface io.prestosql.spi.connector.RecordSet
 
cursor(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in interface io.prestosql.spi.connector.SystemTable
Create a cursor for the data in this table.

D

DATA_DEFINITION - io.prestosql.spi.resourcegroups.QueryType
 
DATE - Static variable in class io.prestosql.spi.type.DateType
 
DATE - Static variable in class io.prestosql.spi.type.StandardTypes
 
DateTimeEncoding - Class in io.prestosql.spi.type
 
DateType - Class in io.prestosql.spi.type
 
DECIMAL - Static variable in class io.prestosql.spi.type.StandardTypes
 
DecimalConversions - Class in io.prestosql.spi.type
 
DecimalParseResult - Class in io.prestosql.spi.type
 
DecimalParseResult(Object, DecimalType) - Constructor for class io.prestosql.spi.type.DecimalParseResult
 
Decimals - Class in io.prestosql.spi.type
 
DecimalType - Class in io.prestosql.spi.type
 
declarePosition() - Method in class io.prestosql.spi.PageBuilder
 
declarePositions(int) - Method in class io.prestosql.spi.PageBuilder
 
decode(Object) - Method in class io.prestosql.spi.session.PropertyMetadata
Decodes the SQL type object value to the Java type of the property.
decodePageIndex(long) - Method in interface io.prestosql.spi.PageSorter
 
decodePositionIndex(long) - Method in interface io.prestosql.spi.PageSorter
 
decodeUnscaledValue(Slice) - Static method in class io.prestosql.spi.type.Decimals
 
decomposable() - Method in annotation type io.prestosql.spi.function.AggregationFunction
 
DEFAULT_MAX_PAGE_SIZE_IN_BYTES - Static variable in class io.prestosql.spi.block.PageBuilderStatus
 
DEFAULT_PRECISION - Static variable in class io.prestosql.spi.type.DecimalType
 
DEFAULT_SCALE - Static variable in class io.prestosql.spi.type.DecimalType
 
DELETE - io.prestosql.spi.resourcegroups.QueryType
 
DELETE - io.prestosql.spi.security.Privilege
 
deleteRows(Block) - Method in class io.prestosql.spi.connector.EmptyPageSource
 
deleteRows(Block) - Method in interface io.prestosql.spi.connector.UpdatablePageSource
 
denyAddColumn(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyAddColumn(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCatalogAccess(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCatalogAccess(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCommentTable(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCommentTable(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCreateRole(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCreateSchema(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCreateSchema(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCreateTable(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCreateTable(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCreateView(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCreateView(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCreateViewWithSelect(String, ConnectorIdentity) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCreateViewWithSelect(String, ConnectorIdentity, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyCreateViewWithSelect(String, Identity) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDeleteTable(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDeleteTable(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDropColumn(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDropColumn(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDropRole(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDropSchema(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDropSchema(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDropTable(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDropTable(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDropView(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyDropView(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyExecuteFunction(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyExecuteProcedure(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyExecuteQuery() - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyExecuteQuery(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyGrantExecuteFunctionPrivilege(String, Identity, Identity) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyGrantExecuteFunctionPrivilege(String, Identity, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyGrantRoles(Set<String>, Set<PrestoPrincipal>) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyGrantTablePrivilege(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyGrantTablePrivilege(String, String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyImpersonateUser(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyImpersonateUser(String, String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyInsertTable(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyInsertTable(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyKillQuery() - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyKillQuery(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRenameColumn(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRenameColumn(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRenameSchema(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRenameSchema(String, String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRenameTable(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRenameTable(String, String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRenameView(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRenameView(String, String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRevokeRoles(Set<String>, Set<PrestoPrincipal>) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRevokeTablePrivilege(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyRevokeTablePrivilege(String, String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySelectColumns(String, Collection<String>) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySelectColumns(String, Collection<String>, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySelectTable(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySelectTable(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySelectView(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySelectView(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySetCatalogSessionProperty(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySetCatalogSessionProperty(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySetCatalogSessionProperty(String, String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySetRole(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySetSchemaAuthorization(String, PrestoPrincipal) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySetSystemSessionProperty(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySetSystemSessionProperty(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySetUser(Optional<Principal>, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denySetUser(Optional<Principal>, String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowColumns(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowCreateSchema(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowCreateTable(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowCreateTable(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowCurrentRoles(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowRoleAuthorizationDescriptors(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowRoleGrants(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowRoles(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowSchemas() - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowSchemas(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowTables(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyShowTables(String, String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyViewQuery() - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
denyViewQuery(String) - Static method in exception io.prestosql.spi.security.AccessDeniedException
 
DEPRECATED_FUNCTION - io.prestosql.spi.connector.StandardWarningCode
 
DESC_NULLS_FIRST - io.prestosql.spi.block.SortOrder
 
DESC_NULLS_FIRST - io.prestosql.spi.connector.SortOrder
 
DESC_NULLS_LAST - io.prestosql.spi.block.SortOrder
 
DESC_NULLS_LAST - io.prestosql.spi.connector.SortOrder
 
DESCRIBE - io.prestosql.spi.resourcegroups.QueryType
 
Description - Annotation Type in io.prestosql.spi.function
 
deserialize(Block, int, T) - Method in interface io.prestosql.spi.function.AccumulatorStateSerializer
Deserialize index-th position in block into state.
destroy() - Method in class io.prestosql.spi.security.Identity
 
deterministic() - Method in annotation type io.prestosql.spi.function.ScalarFunction
 
DictionaryBlock - Class in io.prestosql.spi.block
 
DictionaryBlock(int, int, Block, int[], boolean, DictionaryId) - Constructor for class io.prestosql.spi.block.DictionaryBlock
 
DictionaryBlock(int, Block, int[]) - Constructor for class io.prestosql.spi.block.DictionaryBlock
 
DictionaryBlock(int, Block, int[], boolean) - Constructor for class io.prestosql.spi.block.DictionaryBlock
 
DictionaryBlock(int, Block, int[], boolean, DictionaryId) - Constructor for class io.prestosql.spi.block.DictionaryBlock
 
DictionaryBlock(int, Block, int[], DictionaryId) - Constructor for class io.prestosql.spi.block.DictionaryBlock
 
DictionaryBlock(Block, int[]) - Constructor for class io.prestosql.spi.block.DictionaryBlock
 
DictionaryBlockEncoding - Class in io.prestosql.spi.block
 
DictionaryBlockEncoding() - Constructor for class io.prestosql.spi.block.DictionaryBlockEncoding
 
DictionaryId - Class in io.prestosql.spi.block
 
DictionaryId(long, long, long) - Constructor for class io.prestosql.spi.block.DictionaryId
 
DiscretePredicates - Class in io.prestosql.spi.connector
 
DiscretePredicates(List<ColumnHandle>, Iterable<TupleDomain<ColumnHandle>>) - Constructor for class io.prestosql.spi.connector.DiscretePredicates
 
DiscreteValues - Interface in io.prestosql.spi.predicate
 
DIVIDE - io.prestosql.spi.function.OperatorType
 
divideRoundUp(long, int, long) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
divideRoundUp(long, int, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
divideRoundUp(Slice, int, long) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
divideRoundUp(Slice, int, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
DIVISION_BY_ZERO - io.prestosql.spi.StandardErrorCode
 
Domain - Class in io.prestosql.spi.predicate
Defines the possible values of a single variable in terms of its valid scalar values and nullability.
DOUBLE - Static variable in class io.prestosql.spi.type.DoubleType
 
DOUBLE - Static variable in class io.prestosql.spi.type.StandardTypes
 
doubleProperty(String, String, Double, boolean) - Static method in class io.prestosql.spi.session.PropertyMetadata
 
DoubleRange - Class in io.prestosql.spi.statistics
 
DoubleRange(double, double) - Constructor for class io.prestosql.spi.statistics.DoubleRange
 
doubleToLongDecimal(double, long, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
doubleToShortDecimal(double, long, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
DoubleType - Class in io.prestosql.spi.type
 
dropColumn(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Drop the specified column
dropRole(ConnectorSession, String) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Drops the specified role.
dropSchema(ConnectorSession, String) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Drops the specified schema.
dropTable(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Drops the specified table
dropView(ConnectorSession, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Drop the specified view.
DUPLICATE_COLUMN_NAME - io.prestosql.spi.StandardErrorCode
 
DUPLICATE_NAMED_QUERY - io.prestosql.spi.StandardErrorCode
 
DUPLICATE_PROPERTY - io.prestosql.spi.StandardErrorCode
 
DuplicateMapKeyException - Exception in io.prestosql.spi.block
 
DuplicateMapKeyException(Block, int) - Constructor for exception io.prestosql.spi.block.DuplicateMapKeyException
 
duplicatePluginClassLoader() - Method in interface io.prestosql.spi.connector.ConnectorContext
 

E

embedVersion(Runnable) - Method in interface io.prestosql.spi.VersionEmbedder
Encodes Presto server version information in the stack
embedVersion(Callable<T>) - Method in interface io.prestosql.spi.VersionEmbedder
 
embedVersion(Executor) - Method in interface io.prestosql.spi.VersionEmbedder
 
empty() - Static method in class io.prestosql.spi.statistics.ColumnStatistics
 
empty() - Static method in class io.prestosql.spi.statistics.TableStatistics
 
empty() - Static method in class io.prestosql.spi.statistics.TableStatisticsMetadata
 
EmptyPageSource - Class in io.prestosql.spi.connector
 
EmptyPageSource() - Constructor for class io.prestosql.spi.connector.EmptyPageSource
 
encode(T) - Method in class io.prestosql.spi.session.PropertyMetadata
Encodes the Java type value to SQL type object value
encodeScaledValue(BigDecimal) - Static method in class io.prestosql.spi.type.Decimals
Converts BigDecimal to Slice representing it for long DecimalType.
encodeScaledValue(BigDecimal, int) - Static method in class io.prestosql.spi.type.Decimals
 
encodeScaledValue(BigDecimal, int, RoundingMode) - Static method in class io.prestosql.spi.type.Decimals
 
encodeShortScaledValue(BigDecimal, int) - Static method in class io.prestosql.spi.type.Decimals
 
encodeShortScaledValue(BigDecimal, int, RoundingMode) - Static method in class io.prestosql.spi.type.Decimals
 
encodeUnscaledValue(long) - Static method in class io.prestosql.spi.type.Decimals
 
encodeUnscaledValue(BigInteger) - Static method in class io.prestosql.spi.type.Decimals
 
ensureCapacity(long) - Method in interface io.prestosql.spi.function.GroupedAccumulatorState
 
ensureHashTableLoaded() - Method in class io.prestosql.spi.block.AbstractMapBlock
 
ensureHashTableLoaded() - Method in class io.prestosql.spi.block.MapBlock
 
ensureHashTableLoaded() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
enumProperty(String, String, Class<T>, T, boolean) - Static method in class io.prestosql.spi.session.PropertyMetadata
 
equal(Type, Object) - Static method in class io.prestosql.spi.predicate.Range
 
EQUAL - io.prestosql.spi.function.OperatorType
 
equals(int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
equals(int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
equals(int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
equals(int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
equals(int, int, Block, int, int, int) - Method in interface io.prestosql.spi.block.Block
Is the byte sequences at offset in the value at position equal to the byte sequence at otherOffset in the value at otherPosition in otherBlock.
equals(int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
equals(int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
equals(int, int, Block, int, int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
equals(Object) - Method in class io.prestosql.spi.block.DictionaryId
 
equals(Object) - Method in class io.prestosql.spi.connector.AggregateFunction
 
equals(Object) - Method in class io.prestosql.spi.connector.CatalogSchemaName
 
equals(Object) - Method in class io.prestosql.spi.connector.CatalogSchemaRoutineName
 
equals(Object) - Method in class io.prestosql.spi.connector.CatalogSchemaTableName
 
equals(Object) - Method in class io.prestosql.spi.connector.ColumnMetadata
 
equals(Object) - Method in class io.prestosql.spi.connector.ConnectorPartitionHandle
 
equals(Object) - Method in class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
 
equals(Object) - Method in class io.prestosql.spi.connector.ConnectorTablePartitioning
 
equals(Object) - Method in class io.prestosql.spi.connector.ConnectorTableProperties
 
equals(Object) - Method in class io.prestosql.spi.connector.ConstantProperty
 
equals(Object) - Method in class io.prestosql.spi.connector.GroupingProperty
 
equals(Object) - Method in class io.prestosql.spi.connector.NotPartitionedPartitionHandle
 
equals(Object) - Method in class io.prestosql.spi.connector.SchemaRoutineName
 
equals(Object) - Method in class io.prestosql.spi.connector.SchemaTableName
 
equals(Object) - Method in class io.prestosql.spi.connector.SchemaTablePrefix
 
equals(Object) - Method in class io.prestosql.spi.connector.SortingProperty
 
equals(Object) - Method in class io.prestosql.spi.connector.SortItem
 
equals(Object) - Method in class io.prestosql.spi.ErrorCode
 
equals(Object) - Method in class io.prestosql.spi.expression.ConnectorExpression
 
equals(Object) - Method in class io.prestosql.spi.expression.Constant
 
equals(Object) - Method in class io.prestosql.spi.expression.FieldDereference
 
equals(Object) - Method in class io.prestosql.spi.expression.Variable
 
equals(Object) - Method in class io.prestosql.spi.HostAddress
 
equals(Object) - Method in class io.prestosql.spi.memory.MemoryPoolId
 
equals(Object) - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
equals(Object) - Method in class io.prestosql.spi.predicate.Domain
 
equals(Object) - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
equals(Object) - Method in class io.prestosql.spi.predicate.EquatableValueSet.ValueEntry
 
equals(Object) - Method in class io.prestosql.spi.predicate.Marker
 
equals(Object) - Method in class io.prestosql.spi.predicate.NullableValue
 
equals(Object) - Method in class io.prestosql.spi.predicate.Range
 
equals(Object) - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
equals(Object) - Method in class io.prestosql.spi.predicate.TupleDomain
 
equals(Object) - Method in class io.prestosql.spi.PrestoWarning
 
equals(Object) - Method in class io.prestosql.spi.QueryId
 
equals(Object) - Method in class io.prestosql.spi.resourcegroups.ResourceGroupId
 
equals(Object) - Method in class io.prestosql.spi.security.BasicPrincipal
 
equals(Object) - Method in class io.prestosql.spi.security.GrantInfo
 
equals(Object) - Method in class io.prestosql.spi.security.Identity
 
equals(Object) - Method in class io.prestosql.spi.security.PrestoPrincipal
 
equals(Object) - Method in class io.prestosql.spi.security.PrivilegeInfo
 
equals(Object) - Method in class io.prestosql.spi.security.RoleGrant
 
equals(Object) - Method in class io.prestosql.spi.security.SelectedRole
 
equals(Object) - Method in class io.prestosql.spi.statistics.ColumnStatisticMetadata
 
equals(Object) - Method in class io.prestosql.spi.statistics.ColumnStatistics
 
equals(Object) - Method in class io.prestosql.spi.statistics.DoubleRange
 
equals(Object) - Method in class io.prestosql.spi.statistics.Estimate
 
equals(Object) - Method in class io.prestosql.spi.statistics.TableStatistics
 
equals(Object) - Method in class io.prestosql.spi.type.AbstractType
 
equals(Object) - Method in class io.prestosql.spi.type.BigintType
 
equals(Object) - Method in class io.prestosql.spi.type.BooleanType
 
equals(Object) - Method in class io.prestosql.spi.type.CharType
 
equals(Object) - Method in class io.prestosql.spi.type.DateType
 
equals(Object) - Method in class io.prestosql.spi.type.DecimalParseResult
 
equals(Object) - Method in class io.prestosql.spi.type.DoubleType
 
equals(Object) - Method in class io.prestosql.spi.type.IntegerType
 
equals(Object) - Method in class io.prestosql.spi.type.LongTimestamp
 
equals(Object) - Method in class io.prestosql.spi.type.NamedType
 
equals(Object) - Method in class io.prestosql.spi.type.NamedTypeSignature
 
equals(Object) - Method in class io.prestosql.spi.type.RealType
 
equals(Object) - Method in class io.prestosql.spi.type.RowFieldName
 
equals(Object) - Method in class io.prestosql.spi.type.SmallintType
 
equals(Object) - Method in class io.prestosql.spi.type.SqlDate
 
equals(Object) - Method in class io.prestosql.spi.type.SqlDecimal
 
equals(Object) - Method in class io.prestosql.spi.type.SqlTime
 
equals(Object) - Method in class io.prestosql.spi.type.SqlTimestamp
 
equals(Object) - Method in class io.prestosql.spi.type.SqlTimestampWithTimeZone
 
equals(Object) - Method in class io.prestosql.spi.type.SqlTimeWithTimeZone
 
equals(Object) - Method in class io.prestosql.spi.type.SqlVarbinary
 
equals(Object) - Method in class io.prestosql.spi.type.TimestampWithTimeZoneType
 
equals(Object) - Method in class io.prestosql.spi.type.TimeType
 
equals(Object) - Method in class io.prestosql.spi.type.TimeWithTimeZoneType
 
equals(Object) - Method in class io.prestosql.spi.type.TimeZoneKey
 
equals(Object) - Method in class io.prestosql.spi.type.TinyintType
 
equals(Object) - Method in class io.prestosql.spi.type.TypeId
 
equals(Object) - Method in class io.prestosql.spi.type.TypeParameter
 
equals(Object) - Method in class io.prestosql.spi.type.TypeSignature
 
equals(Object) - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
equals(Object) - Method in class io.prestosql.spi.type.VarbinaryType
 
equals(Object) - Method in class io.prestosql.spi.type.VarcharType
 
equals(Object) - Method in class io.prestosql.spi.WarningCode
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.AbstractIntType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.AbstractLongType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.AbstractType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.ArrayType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.BooleanType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.CharType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.DoubleType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.LongTimestampType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.MapType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.RealType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.RowType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.ShortTimestampType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.SmallintType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.TimestampWithTimeZoneType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.TimeWithTimeZoneType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.TinyintType
 
equalTo(Block, int, Block, int) - Method in interface io.prestosql.spi.type.Type
Are the values in the specified blocks at the specified positions equal?
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.VarbinaryType
 
equalTo(Block, int, Block, int) - Method in class io.prestosql.spi.type.VarcharType
 
EquatableValueSet - Class in io.prestosql.spi.predicate
A set containing values that are uniquely identifiable.
EquatableValueSet(Type, boolean, Set<EquatableValueSet.ValueEntry>) - Constructor for class io.prestosql.spi.predicate.EquatableValueSet
 
EquatableValueSet.ValueEntry - Class in io.prestosql.spi.predicate
 
ErrorCode - Class in io.prestosql.spi
 
ErrorCode(int, String, ErrorType) - Constructor for class io.prestosql.spi.ErrorCode
 
ErrorCodeSupplier - Interface in io.prestosql.spi
 
ErrorType - Enum in io.prestosql.spi
 
Estimate - Class in io.prestosql.spi.statistics
 
EventListener - Interface in io.prestosql.spi.eventlistener
 
EventListenerFactory - Interface in io.prestosql.spi.eventlistener
 
exactly(Type, Object) - Static method in class io.prestosql.spi.predicate.Marker
 
EXACTLY - io.prestosql.spi.predicate.Marker.Bound
 
EXCEEDED_CPU_LIMIT - io.prestosql.spi.StandardErrorCode
 
EXCEEDED_FUNCTION_MEMORY_LIMIT - io.prestosql.spi.StandardErrorCode
 
EXCEEDED_GLOBAL_MEMORY_LIMIT - io.prestosql.spi.StandardErrorCode
 
EXCEEDED_LOCAL_MEMORY_LIMIT - io.prestosql.spi.StandardErrorCode
 
EXCEEDED_SPILL_LIMIT - io.prestosql.spi.StandardErrorCode
 
EXCEEDED_TIME_LIMIT - io.prestosql.spi.StandardErrorCode
 
executeDelete(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
EXECUTION_TIME - Static variable in class io.prestosql.spi.session.ResourceEstimates
 
EXPLAIN - io.prestosql.spi.resourcegroups.QueryType
 
EXPRESSION_NOT_AGGREGATE - io.prestosql.spi.StandardErrorCode
 
EXPRESSION_NOT_CONSTANT - io.prestosql.spi.StandardErrorCode
 
EXPRESSION_NOT_IN_DISTINCT - io.prestosql.spi.StandardErrorCode
 
EXPRESSION_NOT_SCALAR - io.prestosql.spi.StandardErrorCode
 
EXTERNAL - io.prestosql.spi.ErrorType
 
extractDiscreteValues(TupleDomain<T>) - Static method in class io.prestosql.spi.predicate.TupleDomain
Extract all column constraints that define a non-empty set of discrete values allowed for the columns in their respective Domains.
extractFixedValues(TupleDomain<T>) - Static method in class io.prestosql.spi.predicate.TupleDomain
Extract all column constraints that require exactly one value or only null in their respective Domains.

F

FAIL_ON_NULL - io.prestosql.spi.function.InvocationConvention.InvocationReturnConvention
 
FAIR - io.prestosql.spi.resourcegroups.SchedulingPolicy
 
field(Type) - Static method in class io.prestosql.spi.type.RowType
 
field(String, Type) - Static method in class io.prestosql.spi.type.RowType
 
Field(Optional<String>, Type) - Constructor for class io.prestosql.spi.type.RowType.Field
 
FieldDereference - Class in io.prestosql.spi.expression
 
FieldDereference(Type, ConnectorExpression, int) - Constructor for class io.prestosql.spi.expression.FieldDereference
 
filter(BiPredicate<T, Domain>) - Method in class io.prestosql.spi.predicate.TupleDomain
 
filterCatalogs(SystemSecurityContext, Set<String>) - Method in interface io.prestosql.spi.security.SystemAccessControl
Filter the list of catalogs to those visible to the identity.
filterColumns(ConnectorSecurityContext, SchemaTableName, List<ColumnMetadata>) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Filter the list of columns to those visible to the identity.
filterColumns(SystemSecurityContext, CatalogSchemaTableName, List<ColumnMetadata>) - Method in interface io.prestosql.spi.security.SystemAccessControl
Filter the list of columns to those visible to the identity.
filterSchemas(ConnectorSecurityContext, Set<String>) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Filter the list of schemas to those visible to the identity.
filterSchemas(SystemSecurityContext, String, Set<String>) - Method in interface io.prestosql.spi.security.SystemAccessControl
Filter the list of schemas in a catalog to those visible to the identity.
filterTables(ConnectorSecurityContext, Set<SchemaTableName>) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Filter the list of tables and views to those visible to the identity.
filterTables(SystemSecurityContext, String, Set<SchemaTableName>) - Method in interface io.prestosql.spi.security.SystemAccessControl
Filter the list of tables and views to those visible to the identity.
filterViewQueryOwnedBy(SystemSecurityContext, Set<String>) - Method in interface io.prestosql.spi.security.SystemAccessControl
Filter the list of users to those the identity view query owned by the user.
finish() - Method in interface io.prestosql.spi.connector.ConnectorPageSink
Notifies the connector that no more pages will be appended and returns connector-specific information that will be sent to the coordinator to complete the write operation.
finish() - Method in class io.prestosql.spi.connector.EmptyPageSource
 
finish() - Method in interface io.prestosql.spi.connector.UpdatablePageSource
 
finishCreateTable(ConnectorSession, ConnectorOutputTableHandle, Collection<Slice>, Collection<ComputedStatistics>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Finish a table creation with data after the data is written.
finishDelete(ConnectorSession, ConnectorTableHandle, Collection<Slice>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Finish delete query
finishInsert(ConnectorSession, ConnectorInsertTableHandle, Collection<Slice>, Collection<ComputedStatistics>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Finish insert query
finishStatisticsCollection(ConnectorSession, ConnectorTableHandle, Collection<ComputedStatistics>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Finish statistics collection
FixedPageSource - Class in io.prestosql.spi.connector
 
FixedPageSource(Iterable<Page>) - Constructor for class io.prestosql.spi.connector.FixedPageSource
 
FixedSplitSource - Class in io.prestosql.spi.connector
 
FixedSplitSource(Iterable<? extends ConnectorSplit>) - Constructor for class io.prestosql.spi.connector.FixedSplitSource
 
FixedWidthType - Interface in io.prestosql.spi.type
FixedWidthType is a type that has a fixed size for every value.
forUser(String) - Static method in class io.prestosql.spi.security.ConnectorIdentity
 
forUser(String) - Static method in class io.prestosql.spi.security.Identity
 
from(Identity) - Static method in class io.prestosql.spi.security.Identity
 
from(List<RowType.Field>) - Static method in class io.prestosql.spi.type.RowType
 
fromColumnDomains(Optional<List<TupleDomain.ColumnDomain<T>>>) - Static method in class io.prestosql.spi.predicate.TupleDomain
 
fromElementBlock(int, Optional<boolean[]>, int[], Block) - Static method in class io.prestosql.spi.block.ArrayBlock
Create an array block directly from columnar nulls, values, and offsets into the values.
fromFieldBlocks(int, Optional<boolean[]>, Block[]) - Static method in class io.prestosql.spi.block.RowBlock
Create a row block directly from columnar nulls and field blocks.
fromFixedValues(Map<T, NullableValue>) - Static method in class io.prestosql.spi.predicate.TupleDomain
Convert a map of columns to values into the TupleDomain which requires those columns to be fixed to those values.
fromKeyValueBlock(Optional<boolean[]>, int[], Block, Block, MapType) - Static method in class io.prestosql.spi.block.MapBlock
Create a map block directly from columnar nulls, keys, values, and offsets into the keys and values.
fromMillis(int, long) - Static method in class io.prestosql.spi.type.SqlTimestamp
 
fromParts(String, int) - Static method in class io.prestosql.spi.HostAddress
Build a HostAddress instance from separate host and port values.
fromSerializable(NullableValue.Serializable) - Static method in class io.prestosql.spi.predicate.NullableValue
 
fromSqlType(String) - Method in interface io.prestosql.spi.type.TypeManager
Gets a type given it's SQL representation
fromString(String) - Static method in class io.prestosql.spi.HostAddress
Split a freeform string into a host and port, without strict validation.
fromType() - Method in annotation type io.prestosql.spi.function.CastDependency
 
fromUri(URI) - Static method in class io.prestosql.spi.HostAddress
 
FULL - io.prestosql.spi.resourcegroups.ResourceGroupState
 
FUNCTION - io.prestosql.spi.function.InvocationConvention.InvocationArgumentConvention
Argument is a lambda function.
FUNCTION_IMPLEMENTATION_ERROR - io.prestosql.spi.StandardErrorCode
 
FUNCTION_IMPLEMENTATION_MISSING - io.prestosql.spi.StandardErrorCode
 
FUNCTION_NOT_AGGREGATE - io.prestosql.spi.StandardErrorCode
 
FUNCTION_NOT_FOUND - io.prestosql.spi.StandardErrorCode
 
FUNCTION_NOT_WINDOW - io.prestosql.spi.StandardErrorCode
 
FunctionDependency - Annotation Type in io.prestosql.spi.function
 
functionType(TypeSignature, TypeSignature...) - Static method in class io.prestosql.spi.type.TypeSignature
 

G

GENERIC_INSUFFICIENT_RESOURCES - io.prestosql.spi.StandardErrorCode
 
GENERIC_INTERNAL_ERROR - io.prestosql.spi.StandardErrorCode
 
GENERIC_USER_ERROR - io.prestosql.spi.StandardErrorCode
 
GEOMETRY - Static variable in class io.prestosql.spi.type.StandardTypes
 
getAccessControl() - Method in interface io.prestosql.spi.connector.Connector
 
getAddresses() - Method in interface io.prestosql.spi.connector.ConnectorSplit
 
getAllNodes() - Method in interface io.prestosql.spi.NodeManager
 
getAllocation() - Method in class io.prestosql.spi.memory.MemoryAllocation
 
getAllOrNone() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
getAnalysisTime() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getAnalyzeProperties() - Method in interface io.prestosql.spi.connector.Connector
 
getArgumentConvention(int) - Method in class io.prestosql.spi.function.InvocationConvention
 
getArgumentConventions() - Method in class io.prestosql.spi.function.InvocationConvention
 
getArgumentCount() - Method in enum io.prestosql.spi.function.OperatorType
 
getArguments() - Method in class io.prestosql.spi.procedure.Procedure
 
getAssignments() - Method in class io.prestosql.spi.connector.AggregationApplicationResult
 
getAssignments() - Method in class io.prestosql.spi.connector.ProjectionApplicationResult
 
getAuthorization() - Method in class io.prestosql.spi.eventlistener.RoutineInfo
 
getAuthorization() - Method in class io.prestosql.spi.eventlistener.TableInfo
 
getAverage() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getAverageFullGcSec() - Method in class io.prestosql.spi.eventlistener.StageGcStatistics
 
getBase() - Method in class io.prestosql.spi.type.TypeSignature
 
getBaseName() - Method in interface io.prestosql.spi.type.Type
Returns the base name of this type.
getBlock() - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getBlock() - Method in class io.prestosql.spi.block.LazyBlock
 
getBlock() - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
getBlock() - Method in class io.prestosql.spi.predicate.EquatableValueSet.ValueEntry
 
getBlock() - Method in class io.prestosql.spi.predicate.NullableValue.Serializable
 
getBlock(int) - Method in class io.prestosql.spi.Page
 
getBlockBuilder(int) - Method in class io.prestosql.spi.PageBuilder
 
getBlockEncodings() - Method in interface io.prestosql.spi.Plugin
 
getBoolean(int) - Method in interface io.prestosql.spi.connector.RecordCursor
 
getBoolean(int, int) - Method in interface io.prestosql.spi.function.WindowIndex
Gets a value as a boolean.
getBoolean(Block, int) - Method in class io.prestosql.spi.type.AbstractType
 
getBoolean(Block, int) - Method in class io.prestosql.spi.type.BooleanType
 
getBoolean(Block, int) - Method in interface io.prestosql.spi.type.Type
Gets the value at the block position as a boolean.
getBound() - Method in class io.prestosql.spi.predicate.Marker
 
getBoundedLength() - Method in class io.prestosql.spi.type.VarcharType
 
getBucket(Page, int) - Method in interface io.prestosql.spi.connector.BucketFunction
Gets the bucket for the tuple at the specified position.
getBucketCount() - Method in class io.prestosql.spi.connector.ConnectorBucketNodeMap
 
getBucketFunction(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle, List<Type>, int) - Method in interface io.prestosql.spi.connector.ConnectorNodePartitioningProvider
 
getBucketNodeMap(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle) - Method in interface io.prestosql.spi.connector.ConnectorNodePartitioningProvider
 
getByte(int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getByte(int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getByte(int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getByte(int, int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
getByte(int, int) - Method in interface io.prestosql.spi.block.Block
Gets a byte at offset in the value at position.
getByte(int, int) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
getByte(int, int) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
getByte(int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getByte(int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
getByte(int, int) - Method in class io.prestosql.spi.block.LongArrayBlock
Deprecated.
getByte(int, int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
Deprecated.
getByte(int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getBytes() - Method in class io.prestosql.spi.type.SqlVarbinary
 
getCapabilities() - Method in interface io.prestosql.spi.connector.Connector
 
getCatalog() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition
 
getCatalog() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getCatalog() - Method in class io.prestosql.spi.eventlistener.TableInfo
 
getCatalog() - Method in class io.prestosql.spi.security.ViewExpression
 
getCatalogName() - Method in class io.prestosql.spi.connector.CatalogSchemaName
 
getCatalogName() - Method in class io.prestosql.spi.connector.CatalogSchemaRoutineName
 
getCatalogName() - Method in class io.prestosql.spi.connector.CatalogSchemaTableName
 
getCatalogName() - Method in class io.prestosql.spi.eventlistener.QueryInputMetadata
 
getCatalogName() - Method in class io.prestosql.spi.eventlistener.QueryOutputMetadata
 
getCatalogSessionProperties(SessionConfigurationContext) - Method in interface io.prestosql.spi.session.SessionPropertyConfigurationManager
 
getCertificateAuthenticatorFactories() - Method in interface io.prestosql.spi.Plugin
 
getChannelCount() - Method in class io.prestosql.spi.Page
 
getChildren() - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getChildren() - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getChildren() - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getChildren() - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getChildren() - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getChildren() - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getChildren() - Method in interface io.prestosql.spi.block.Block
Gets the direct child blocks of this block.
getChildren() - Method in class io.prestosql.spi.block.DictionaryBlock
 
getChildren() - Method in class io.prestosql.spi.block.LazyBlock
 
getChildren() - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getChildren() - Method in class io.prestosql.spi.expression.ConnectorExpression
 
getChildren() - Method in class io.prestosql.spi.expression.Constant
 
getChildren() - Method in class io.prestosql.spi.expression.FieldDereference
 
getChildren() - Method in class io.prestosql.spi.expression.Variable
 
getClientCapabilities() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getClientInfo() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getClientTags() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getClientTags() - Method in class io.prestosql.spi.session.SessionConfigurationContext
 
getCode() - Method in class io.prestosql.spi.ErrorCode
 
getCode() - Method in class io.prestosql.spi.WarningCode
 
getColumn() - Method in class io.prestosql.spi.connector.Assignment
 
getColumn() - Method in class io.prestosql.spi.connector.ConstantProperty
 
getColumn() - Method in class io.prestosql.spi.connector.SortingProperty
 
getColumn() - Method in class io.prestosql.spi.eventlistener.ColumnInfo
 
getColumn() - Method in class io.prestosql.spi.predicate.TupleDomain.ColumnDomain
 
getColumnDomains() - Method in class io.prestosql.spi.predicate.TupleDomain
 
getColumnHandleClass() - Method in interface io.prestosql.spi.connector.ConnectorHandleResolver
 
getColumnHandles(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Gets all of the columns on the specified table, or an empty map if the columns cannot be enumerated.
getColumnMask(ConnectorSecurityContext, SchemaTableName, String, Type) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Get a column mask associated with the given table, column and identity.
getColumnMask(SystemSecurityContext, CatalogSchemaTableName, String, Type) - Method in interface io.prestosql.spi.security.SystemAccessControl
Get a column mask associated with the given table, column and identity.
getColumnMetadata(ConnectorSession, ConnectorTableHandle, ColumnHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Gets the metadata for the specified table column.
getColumnName() - Method in exception io.prestosql.spi.connector.ColumnNotFoundException
 
getColumnName() - Method in class io.prestosql.spi.statistics.ColumnStatisticMetadata
 
getColumnNumber() - Method in class io.prestosql.spi.Location
 
getColumnProperties() - Method in interface io.prestosql.spi.connector.Connector
 
getColumns() - Method in class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
The columns from the original table provided by this layout.
getColumns() - Method in class io.prestosql.spi.connector.ConnectorTableMetadata
 
getColumns() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition
 
getColumns() - Method in class io.prestosql.spi.connector.ConstantProperty
 
getColumns() - Method in class io.prestosql.spi.connector.Constraint
Deprecated.
getColumns() - Method in class io.prestosql.spi.connector.DiscretePredicates
 
getColumns() - Method in class io.prestosql.spi.connector.GroupingProperty
 
getColumns() - Method in interface io.prestosql.spi.connector.LocalProperty
 
getColumns() - Method in class io.prestosql.spi.connector.SortingProperty
 
getColumns() - Method in class io.prestosql.spi.eventlistener.QueryInputMetadata
 
getColumns() - Method in class io.prestosql.spi.eventlistener.TableInfo
 
getColumnStatistics() - Method in class io.prestosql.spi.statistics.ComputedStatistics
 
getColumnStatistics() - Method in class io.prestosql.spi.statistics.TableStatistics
 
getColumnStatistics() - Method in class io.prestosql.spi.statistics.TableStatisticsMetadata
 
getColumnTypes() - Method in class io.prestosql.spi.connector.InMemoryRecordSet
 
getColumnTypes() - Method in interface io.prestosql.spi.connector.RecordSet
 
getComment() - Method in class io.prestosql.spi.connector.ColumnMetadata
 
getComment() - Method in class io.prestosql.spi.connector.ConnectorTableMetadata
 
getComment() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition
 
getCommonPartitioningHandle(ConnectorSession, ConnectorPartitioningHandle, ConnectorPartitioningHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Return a partitioning handle which the connector can transparently convert both left and right into.
getCompletedBytes() - Method in interface io.prestosql.spi.connector.ConnectorPageSink
Gets the number of output bytes written by this page source so far.
getCompletedBytes() - Method in interface io.prestosql.spi.connector.ConnectorPageSource
Gets the number of input bytes processed by this page source so far.
getCompletedBytes() - Method in class io.prestosql.spi.connector.EmptyPageSource
 
getCompletedBytes() - Method in class io.prestosql.spi.connector.FixedPageSource
 
getCompletedBytes() - Method in interface io.prestosql.spi.connector.RecordCursor
 
getCompletedBytes() - Method in class io.prestosql.spi.connector.RecordPageSource
 
getCompletedDataSizeBytes() - Method in class io.prestosql.spi.eventlistener.SplitStatistics
 
getCompletedPositions() - Method in class io.prestosql.spi.eventlistener.SplitStatistics
 
getCompletedReadTime() - Method in class io.prestosql.spi.eventlistener.SplitStatistics
 
getCompletedSplits() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getConnectorFactories() - Method in interface io.prestosql.spi.Plugin
 
getConnectorInfo() - Method in class io.prestosql.spi.eventlistener.QueryInputMetadata
 
getConnectorOutputMetadata() - Method in class io.prestosql.spi.eventlistener.QueryOutputMetadata
 
getContext() - Method in class io.prestosql.spi.eventlistener.QueryCompletedEvent
 
getContext() - Method in class io.prestosql.spi.eventlistener.QueryCreatedEvent
 
getContext() - Method in class io.prestosql.spi.resourcegroups.SelectionContext
 
getCpuQuotaGenerationMillisPerSecond() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getCpuTime() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getCpuTime() - Method in class io.prestosql.spi.eventlistener.SplitStatistics
 
getCpuTime() - Method in class io.prestosql.spi.session.ResourceEstimates
 
getCpuTimeDistribution() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getCreateTime() - Method in class io.prestosql.spi.eventlistener.QueryCompletedEvent
 
getCreateTime() - Method in class io.prestosql.spi.eventlistener.QueryCreatedEvent
 
getCreateTime() - Method in class io.prestosql.spi.eventlistener.SplitCompletedEvent
 
getCumulativeMemory() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getCurrentNode() - Method in interface io.prestosql.spi.NodeManager
 
getCursor() - Method in class io.prestosql.spi.connector.RecordPageSource
 
getDataSize() - Method in class io.prestosql.spi.statistics.ColumnStatistics
 
getDays() - Method in class io.prestosql.spi.type.SqlDate
 
getDefaultValue() - Method in class io.prestosql.spi.procedure.Procedure.Argument
Argument default value in type's stack representation.
getDefaultValue() - Method in class io.prestosql.spi.session.PropertyMetadata
Gets the default value for this property.
getDescription() - Method in class io.prestosql.spi.session.PropertyMetadata
Description for the end user.
getDetailedMessage(Type, ConnectorSession) - Method in exception io.prestosql.spi.block.DuplicateMapKeyException
 
getDictionary() - Method in class io.prestosql.spi.block.DictionaryBlock
 
getDictionarySourceId() - Method in class io.prestosql.spi.block.DictionaryBlock
 
getDiscretePredicates() - Method in class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
A collection of discrete predicates describing the data in this layout.
getDiscretePredicates() - Method in class io.prestosql.spi.connector.ConnectorTableProperties
A collection of discrete predicates describing the data in this layout.
getDiscreteSet() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
getDiscreteSet() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
getDiscreteSet() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
getDiscreteSet() - Method in interface io.prestosql.spi.predicate.ValueSet
 
getDiscreteValues() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
getDiscreteValues() - Method in interface io.prestosql.spi.predicate.ValueSet
 
getDisplayName() - Method in class io.prestosql.spi.type.AbstractType
 
getDisplayName() - Method in class io.prestosql.spi.type.ArrayType
 
getDisplayName() - Method in class io.prestosql.spi.type.CharType
 
getDisplayName() - Method in class io.prestosql.spi.type.MapType
 
getDisplayName() - Method in class io.prestosql.spi.type.RowType
 
getDisplayName() - Method in interface io.prestosql.spi.type.Type
Returns the name of this type that should be displayed to end-users.
getDisplayName() - Method in class io.prestosql.spi.type.VarcharType
 
getDistinctValuesCount() - Method in class io.prestosql.spi.statistics.ColumnStatistics
 
getDistribution() - Method in interface io.prestosql.spi.connector.SystemTable
 
getDomain() - Method in class io.prestosql.spi.predicate.TupleDomain.ColumnDomain
 
getDomains() - Method in class io.prestosql.spi.predicate.TupleDomain
Gets the TupleDomain as a map of each column to its respective Domain.
getDouble(int) - Method in interface io.prestosql.spi.connector.RecordCursor
 
getDouble(int, int) - Method in interface io.prestosql.spi.function.WindowIndex
Gets a value as a double.
getDouble(Block, int) - Method in class io.prestosql.spi.type.AbstractType
 
getDouble(Block, int) - Method in class io.prestosql.spi.type.DoubleType
 
getDouble(Block, int) - Method in interface io.prestosql.spi.type.Type
Gets the value at the block position as a double.
getElementsBlock() - Method in class io.prestosql.spi.block.ColumnarArray
 
getElementType() - Method in class io.prestosql.spi.type.ArrayType
 
getEncodingName() - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
getEncodingName() - Method in interface io.prestosql.spi.block.Block
Get the encoding for this block.
getEncodingName() - Method in class io.prestosql.spi.block.ByteArrayBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
getEncodingName() - Method in class io.prestosql.spi.block.DictionaryBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
getEncodingName() - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getEncodingName() - Method in class io.prestosql.spi.block.IntArrayBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
getEncodingName() - Method in class io.prestosql.spi.block.LazyBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.LongArrayBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
getEncodingName() - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.ShortArrayBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
getEncodingName() - Method in class io.prestosql.spi.block.SingleMapBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
getEncodingName() - Method in class io.prestosql.spi.block.SingleRowBlock
 
getEncodingName() - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
getEndTime() - Method in class io.prestosql.spi.eventlistener.QueryCompletedEvent
 
getEndTime() - Method in class io.prestosql.spi.eventlistener.SplitCompletedEvent
 
getEntries() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
getEntryCount(int) - Method in class io.prestosql.spi.block.ColumnarMap
 
getEnvironment() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getEnvironment() - Method in interface io.prestosql.spi.NodeManager
 
getEnvironment() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroupConfigurationManagerContext
 
getEnvironment() - Method in interface io.prestosql.spi.resourcegroups.SessionPropertyConfigurationManagerContext
 
getEpochMicros() - Method in class io.prestosql.spi.type.LongTimestamp
 
getEpochMicros() - Method in class io.prestosql.spi.type.SqlTimestamp
 
getErrorCode() - Method in class io.prestosql.spi.eventlistener.QueryFailureInfo
 
getErrorCode() - Method in exception io.prestosql.spi.PrestoException
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
getEstimatedDataSizeForStats(int) - Method in interface io.prestosql.spi.block.Block
Returns the estimated in memory data size for stats of position.
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.IntArrayBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.LazyBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.LongArrayBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
getEstimatedDataSizeForStats(int) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
getEstimatedSize() - Method in interface io.prestosql.spi.function.AccumulatorState
 
getEventListenerFactories() - Method in interface io.prestosql.spi.Plugin
 
getEventListeners() - Method in interface io.prestosql.spi.connector.Connector
 
getEventListeners() - Method in interface io.prestosql.spi.security.SystemAccessControl
 
getExecutionStartTime() - Method in class io.prestosql.spi.eventlistener.QueryCompletedEvent
 
getExecutionTime() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getExecutionTime() - Method in class io.prestosql.spi.session.ResourceEstimates
 
getExpression() - Method in class io.prestosql.spi.security.ViewExpression
 
getExtraCredentials() - Method in class io.prestosql.spi.security.ConnectorIdentity
 
getExtraCredentials() - Method in class io.prestosql.spi.security.Identity
 
getExtraInfo() - Method in class io.prestosql.spi.connector.ColumnMetadata
 
getFailureHost() - Method in class io.prestosql.spi.eventlistener.QueryFailureInfo
 
getFailureInfo() - Method in class io.prestosql.spi.eventlistener.QueryCompletedEvent
 
getFailureInfo() - Method in class io.prestosql.spi.eventlistener.SplitCompletedEvent
 
getFailureMessage() - Method in class io.prestosql.spi.eventlistener.QueryFailureInfo
 
getFailureMessage() - Method in class io.prestosql.spi.eventlistener.SplitFailureInfo
 
getFailuresJson() - Method in class io.prestosql.spi.eventlistener.QueryFailureInfo
 
getFailureTask() - Method in class io.prestosql.spi.eventlistener.QueryFailureInfo
 
getFailureType() - Method in class io.prestosql.spi.eventlistener.QueryFailureInfo
 
getFailureType() - Method in class io.prestosql.spi.eventlistener.SplitFailureInfo
 
getField() - Method in class io.prestosql.spi.expression.FieldDereference
 
getField(int) - Method in class io.prestosql.spi.block.ColumnarRow
Gets the specified field for all rows as a column.
getFieldBlockBuilder(int) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
Obtains the field BlockBuilder.
getFieldBlockOffset(int) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getFieldBlockOffsets() - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getFieldBlockOffsets() - Method in class io.prestosql.spi.block.RowBlock
 
getFieldBlockOffsets() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
getFieldCount() - Method in class io.prestosql.spi.block.ColumnarRow
 
getFieldName() - Method in class io.prestosql.spi.type.NamedTypeSignature
 
getFields() - Method in class io.prestosql.spi.type.RowType
 
getFilter() - Method in class io.prestosql.spi.connector.AggregateFunction
 
getFilters() - Method in class io.prestosql.spi.eventlistener.TableInfo
 
getFixedMapping() - Method in class io.prestosql.spi.connector.ConnectorBucketNodeMap
 
getFixedSize() - Method in class io.prestosql.spi.type.AbstractIntType
 
getFixedSize() - Method in class io.prestosql.spi.type.AbstractLongType
 
getFixedSize() - Method in class io.prestosql.spi.type.BooleanType
 
getFixedSize() - Method in class io.prestosql.spi.type.DoubleType
 
getFixedSize() - Method in interface io.prestosql.spi.type.FixedWidthType
Gets the size of a value of this type is bytes.
getFixedSize() - Method in class io.prestosql.spi.type.LongTimestampType
 
getFixedSize() - Method in class io.prestosql.spi.type.ShortTimestampType
 
getFixedSize() - Method in class io.prestosql.spi.type.SmallintType
 
getFixedSize() - Method in class io.prestosql.spi.type.TinyintType
 
getFreeBytes() - Method in class io.prestosql.spi.memory.MemoryPoolInfo
 
getFullGcTasks() - Method in class io.prestosql.spi.eventlistener.StageGcStatistics
 
getFunctionName() - Method in class io.prestosql.spi.connector.AggregateFunction
 
getFunctions() - Method in interface io.prestosql.spi.Plugin
 
getGrantee() - Method in class io.prestosql.spi.security.GrantInfo
 
getGrantee() - Method in class io.prestosql.spi.security.RoleGrant
 
getGrantor() - Method in class io.prestosql.spi.security.GrantInfo
 
getGroupedStateClass() - Method in interface io.prestosql.spi.function.AccumulatorStateFactory
 
getGroupingColumnMapping() - Method in class io.prestosql.spi.connector.AggregationApplicationResult
 
getGroupingColumns() - Method in class io.prestosql.spi.statistics.ComputedStatistics
 
getGroupingColumns() - Method in class io.prestosql.spi.statistics.TableStatisticsMetadata
 
getGroupingValues() - Method in class io.prestosql.spi.statistics.ComputedStatistics
 
getGroupProviderFactories() - Method in interface io.prestosql.spi.Plugin
 
getGroups() - Method in class io.prestosql.spi.security.ConnectorIdentity
 
getGroups() - Method in class io.prestosql.spi.security.Identity
 
getGroups(String) - Method in interface io.prestosql.spi.security.GroupProvider
 
getHandle() - Method in class io.prestosql.spi.connector.AggregationApplicationResult
 
getHandle() - Method in class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
 
getHandle() - Method in class io.prestosql.spi.connector.ConstraintApplicationResult
 
getHandle() - Method in class io.prestosql.spi.connector.LimitApplicationResult
 
getHandle() - Method in class io.prestosql.spi.connector.ProjectionApplicationResult
 
getHandleResolver() - Method in interface io.prestosql.spi.connector.Connector
Get handle resolver for this connector instance.
getHandleResolver() - Method in interface io.prestosql.spi.connector.ConnectorFactory
Gets the default handle resolver for connectors created by this factory.
getHardConcurrencyLimit() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getHardCpuLimit() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getHashTables() - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getHashTables() - Method in class io.prestosql.spi.block.MapBlock
 
getHashTables() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
getHigh() - Method in class io.prestosql.spi.predicate.Range
 
getHost() - Method in interface io.prestosql.spi.Node
 
getHostAndPort() - Method in interface io.prestosql.spi.Node
 
getHostText() - Method in class io.prestosql.spi.HostAddress
Returns the portion of this HostAddress instance that should represent the hostname or IPv4/IPv6 literal.
getHttpUri() - Method in interface io.prestosql.spi.Node
Deprecated.
Connectors should not access the HTTP endpoints of other nodes.
getId() - Method in class io.prestosql.spi.memory.MemoryPoolId
 
getId() - Method in class io.prestosql.spi.QueryId
 
getId() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getId() - Method in class io.prestosql.spi.type.TimeZoneKey
 
getId() - Method in class io.prestosql.spi.type.TypeId
 
getId(int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getIdentity() - Method in class io.prestosql.spi.connector.ConnectorSecurityContext
 
getIdentity() - Method in interface io.prestosql.spi.connector.ConnectorSession
 
getIdentity() - Method in class io.prestosql.spi.security.SystemSecurityContext
 
getIdentity() - Method in class io.prestosql.spi.security.ViewExpression
 
getIndex(ConnectorTransactionHandle, ConnectorSession, ConnectorIndexHandle, List<ColumnHandle>, List<ColumnHandle>) - Method in interface io.prestosql.spi.connector.ConnectorIndexProvider
 
getIndexHandle() - Method in class io.prestosql.spi.connector.ConnectorResolvedIndex
 
getIndexHandleClass() - Method in interface io.prestosql.spi.connector.ConnectorHandleResolver
 
getIndexProvider() - Method in interface io.prestosql.spi.connector.Connector
 
getInfo() - Method in interface io.prestosql.spi.connector.ConnectorOutputMetadata
 
getInfo() - Method in interface io.prestosql.spi.connector.ConnectorSplit
 
getInfo(ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
 
getInfo(ConnectorTableLayoutHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Deprecated.
getInputs() - Method in class io.prestosql.spi.connector.AggregateFunction
 
getInputs() - Method in class io.prestosql.spi.eventlistener.QueryIOMetadata
 
getInsertLayout(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Get the physical layout for a inserting into an existing table.
getInsertTableHandleClass() - Method in interface io.prestosql.spi.connector.ConnectorHandleResolver
 
getInt(int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getInt(int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getInt(int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getInt(int, int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
getInt(int, int) - Method in interface io.prestosql.spi.block.Block
Gets a little endian int at offset in the value at position.
getInt(int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getInt(int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getInt(int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getInt(int, int) - Method in class io.prestosql.spi.block.IntArrayBlock
 
getInt(int, int) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
getInt(int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
getInt(int, int) - Method in class io.prestosql.spi.block.LongArrayBlock
Deprecated.
getInt(int, int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
Deprecated.
getInt(int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getInt(Slice, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
getInternalNetworkBytes() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getInternalNetworkRows() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getIoMetadata() - Method in class io.prestosql.spi.eventlistener.QueryCompletedEvent
 
getJavaType() - Method in class io.prestosql.spi.session.PropertyMetadata
Java type of this property.
getJavaType() - Method in class io.prestosql.spi.type.AbstractType
 
getJavaType() - Method in interface io.prestosql.spi.type.Type
Gets the Java class type used to represent this value on the stack during expression execution.
getJmxExport() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getJsonLengthLimitExceeded() - Method in class io.prestosql.spi.eventlistener.QueryOutputMetadata
 
getKey() - Method in class io.prestosql.spi.type.TimeZoneKey
 
getKeyBlockEquals() - Method in class io.prestosql.spi.type.MapType
Internal use by this package and io.prestosql.spi.block only.
getKeyBlockHashCode() - Method in class io.prestosql.spi.type.MapType
Internal use by this package and io.prestosql.spi.block only.
getKeyBlockNativeEquals() - Method in class io.prestosql.spi.type.MapType
Internal use by this package and io.prestosql.spi.block only.
getKeyNativeHashCode() - Method in class io.prestosql.spi.type.MapType
Internal use by this package and io.prestosql.spi.block only.
getKeysBlock() - Method in class io.prestosql.spi.block.ColumnarMap
 
getKeyType() - Method in class io.prestosql.spi.type.MapType
 
getKind() - Method in class io.prestosql.spi.type.TypeParameter
 
getKind() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
getLastSegment() - Method in class io.prestosql.spi.resourcegroups.ResourceGroupId
 
getLeastSignificantBits() - Method in class io.prestosql.spi.block.DictionaryId
 
getLength() - Method in class io.prestosql.spi.type.CharType
 
getLength() - Method in class io.prestosql.spi.type.VarcharType
 
getLength(int) - Method in class io.prestosql.spi.block.ColumnarArray
 
getLineNumber() - Method in class io.prestosql.spi.Location
 
getLoadedBlock() - Method in class io.prestosql.spi.block.ArrayBlock
 
getLoadedBlock() - Method in interface io.prestosql.spi.block.Block
Returns a fully loaded block that assures all data is in memory.
getLoadedBlock() - Method in class io.prestosql.spi.block.DictionaryBlock
 
getLoadedBlock() - Method in class io.prestosql.spi.block.LazyBlock
 
getLoadedBlock() - Method in class io.prestosql.spi.block.MapBlock
 
getLoadedBlock() - Method in class io.prestosql.spi.block.RowBlock
 
getLoadedBlock() - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getLoadedBlock() - Method in class io.prestosql.spi.block.SingleMapBlock
 
getLoadedBlock() - Method in class io.prestosql.spi.block.SingleRowBlock
 
getLoadedPage() - Method in class io.prestosql.spi.Page
Returns a page that assures all data is in memory.
getLocale() - Method in interface io.prestosql.spi.connector.ConnectorSession
 
getLocalProperties() - Method in class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
Properties describing the layout of the data (grouping/sorting) within each partition
getLocalProperties() - Method in class io.prestosql.spi.connector.ConnectorTableProperties
Properties describing the layout of the data (grouping/sorting) within each partition
getLocation() - Method in exception io.prestosql.spi.PrestoException
 
getLogicalSizeInBytes() - Method in interface io.prestosql.spi.block.Block
Returns the size of the block contents, regardless of internal representation.
getLogicalSizeInBytes() - Method in class io.prestosql.spi.block.DictionaryBlock
 
getLogicalSizeInBytes() - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getLogicalSizeInBytes() - Method in class io.prestosql.spi.Page
 
getLong(int) - Method in interface io.prestosql.spi.connector.RecordCursor
 
getLong(int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getLong(int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getLong(int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getLong(int, int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
getLong(int, int) - Method in interface io.prestosql.spi.block.Block
Gets a little endian long at offset in the value at position.
getLong(int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getLong(int, int) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
getLong(int, int) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
getLong(int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getLong(int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getLong(int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
getLong(int, int) - Method in class io.prestosql.spi.block.LongArrayBlock
 
getLong(int, int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
getLong(int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getLong(int, int) - Method in interface io.prestosql.spi.function.WindowIndex
Gets a value as a long.
getLong(Slice, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
getLong(Block, int) - Method in class io.prestosql.spi.type.AbstractIntType
 
getLong(Block, int) - Method in class io.prestosql.spi.type.AbstractLongType
 
getLong(Block, int) - Method in class io.prestosql.spi.type.AbstractType
 
getLong(Block, int) - Method in class io.prestosql.spi.type.ShortTimestampType
 
getLong(Block, int) - Method in class io.prestosql.spi.type.SmallintType
 
getLong(Block, int) - Method in class io.prestosql.spi.type.TinyintType
 
getLong(Block, int) - Method in interface io.prestosql.spi.type.Type
Gets the value at the block position as a long.
getLongLiteral() - Method in class io.prestosql.spi.type.TypeParameter
 
getLongLiteral() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
getLow() - Method in class io.prestosql.spi.predicate.Range
 
getMapIsNull() - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getMapIsNull() - Method in class io.prestosql.spi.block.MapBlock
 
getMapIsNull() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
getMapType() - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getMapType() - Method in class io.prestosql.spi.block.SingleMapBlock
 
getMasks() - Method in class io.prestosql.spi.eventlistener.ColumnInfo
 
getMax() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getMax() - Method in class io.prestosql.spi.statistics.DoubleRange
 
getMax() - Method in class io.prestosql.spi.type.Type.Range
 
getMaxBytes() - Method in class io.prestosql.spi.memory.MemoryPoolInfo
 
getMaxFullGcSec() - Method in class io.prestosql.spi.eventlistener.StageGcStatistics
 
getMaxIndex() - Method in interface io.prestosql.spi.PageIndexer
Returns maximum index value returned.
getMaxPageSizeInBytes() - Method in class io.prestosql.spi.block.BlockBuilderStatus
 
getMaxPageSizeInBytes() - Method in class io.prestosql.spi.block.PageBuilderStatus
 
getMaxQueuedQueries() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getMemoryPoolManager() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroupConfigurationManagerContext
 
getMessage() - Method in exception io.prestosql.spi.PrestoException
 
getMessage() - Method in class io.prestosql.spi.PrestoWarning
 
getMetadata() - Method in class io.prestosql.spi.eventlistener.QueryCompletedEvent
 
getMetadata() - Method in class io.prestosql.spi.eventlistener.QueryCreatedEvent
 
getMetadata(ConnectorTransactionHandle) - Method in interface io.prestosql.spi.connector.Connector
Guaranteed to be called at most once per transaction.
getMethodHandle() - Method in class io.prestosql.spi.procedure.Procedure
 
getMillis() - Method in class io.prestosql.spi.type.SqlTime
 
getMillis() - Method in class io.prestosql.spi.type.SqlTimestamp
 
getMillisUtc() - Method in class io.prestosql.spi.type.SqlTime
Deprecated.
applicable in legacy timestamp semantics only
getMillisUtc() - Method in class io.prestosql.spi.type.SqlTimestamp
Deprecated.
applicable in legacy timestamp semantics only
getMillisUtc() - Method in class io.prestosql.spi.type.SqlTimestampWithTimeZone
 
getMillisUtc() - Method in class io.prestosql.spi.type.SqlTimeWithTimeZone
 
getMin() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getMin() - Method in class io.prestosql.spi.statistics.DoubleRange
 
getMin() - Method in class io.prestosql.spi.type.Type.Range
 
getMinFullGcSec() - Method in class io.prestosql.spi.eventlistener.StageGcStatistics
 
getMinScheduleSplitBatchSize() - Method in interface io.prestosql.spi.connector.ConnectorSplitSource
 
getMostSignificantBits() - Method in class io.prestosql.spi.block.DictionaryId
 
getName() - Method in class io.prestosql.spi.block.ArrayBlockEncoding
 
getName() - Method in interface io.prestosql.spi.block.BlockEncoding
Gets the unique name of this encoding.
getName() - Method in class io.prestosql.spi.block.ByteArrayBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.DictionaryBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.Int128ArrayBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.Int96ArrayBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.IntArrayBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.LazyBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.LongArrayBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.MapBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.RowBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.RunLengthBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.ShortArrayBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.SingleMapBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.SingleRowBlockEncoding
 
getName() - Method in class io.prestosql.spi.block.VariableWidthBlockEncoding
 
getName() - Method in class io.prestosql.spi.connector.ColumnMetadata
 
getName() - Method in interface io.prestosql.spi.connector.ConnectorFactory
 
getName() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition.ViewColumn
 
getName() - Method in class io.prestosql.spi.connector.SortItem
 
getName() - Method in class io.prestosql.spi.ErrorCode
 
getName() - Method in interface io.prestosql.spi.eventlistener.EventListenerFactory
 
getName() - Method in class io.prestosql.spi.expression.Variable
 
getName() - Method in class io.prestosql.spi.procedure.Procedure.Argument
 
getName() - Method in class io.prestosql.spi.procedure.Procedure
 
getName() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroupConfigurationManagerFactory
 
getName() - Method in class io.prestosql.spi.security.BasicPrincipal
 
getName() - Method in interface io.prestosql.spi.security.CertificateAuthenticatorFactory
 
getName() - Method in interface io.prestosql.spi.security.GroupProviderFactory
 
getName() - Method in interface io.prestosql.spi.security.PasswordAuthenticatorFactory
 
getName() - Method in class io.prestosql.spi.security.PrestoPrincipal
 
getName() - Method in interface io.prestosql.spi.security.SystemAccessControlFactory
 
getName() - Method in class io.prestosql.spi.session.PropertyMetadata
Name of the property.
getName() - Method in interface io.prestosql.spi.session.SessionPropertyConfigurationManagerFactory
 
getName() - Method in class io.prestosql.spi.type.NamedType
 
getName() - Method in class io.prestosql.spi.type.NamedTypeSignature
 
getName() - Method in interface io.prestosql.spi.type.ParametricType
 
getName() - Method in class io.prestosql.spi.type.QuantileDigestParametricType
 
getName() - Method in class io.prestosql.spi.type.RowFieldName
 
getName() - Method in class io.prestosql.spi.type.RowType.Field
 
getName() - Method in class io.prestosql.spi.type.TimestampParametricType
 
getName() - Method in class io.prestosql.spi.WarningCode
 
getNamedType() - Method in class io.prestosql.spi.type.TypeParameter
 
getNamedTypeSignature() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
getNewTableLayout(ConnectorSession, ConnectorTableMetadata) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Get the physical layout for a new table.
getNextBatch(ConnectorPartitionHandle, int) - Method in interface io.prestosql.spi.connector.ConnectorSplitSource
 
getNextBatch(ConnectorPartitionHandle, int) - Method in class io.prestosql.spi.connector.FixedSplitSource
 
getNextPage() - Method in interface io.prestosql.spi.connector.ConnectorPageSource
Gets the next page of data.
getNextPage() - Method in class io.prestosql.spi.connector.EmptyPageSource
 
getNextPage() - Method in class io.prestosql.spi.connector.FixedPageSource
 
getNextPage() - Method in class io.prestosql.spi.connector.RecordPageSource
 
getNodeIdentifier() - Method in interface io.prestosql.spi.Node
 
getNodeManager() - Method in interface io.prestosql.spi.connector.ConnectorContext
 
getNodePartitioningProvider() - Method in interface io.prestosql.spi.connector.Connector
 
getNullableSingleValue() - Method in class io.prestosql.spi.predicate.Domain
 
getNullsFraction() - Method in class io.prestosql.spi.statistics.ColumnStatistics
 
getObject() - Method in class io.prestosql.spi.type.DecimalParseResult
 
getObject(int) - Method in interface io.prestosql.spi.connector.RecordCursor
 
getObject(int, int) - Method in interface io.prestosql.spi.function.WindowIndex
Gets an object value.
getObject(int, Class<T>) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getObject(int, Class<T>) - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getObject(int, Class<T>) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getObject(int, Class<T>) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getObject(int, Class<T>) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getObject(int, Class<T>) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getObject(int, Class<T>) - Method in interface io.prestosql.spi.block.Block
Gets an object in the value at position.
getObject(int, Class<T>) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getObject(int, Class<T>) - Method in class io.prestosql.spi.block.LazyBlock
 
getObject(int, Class<T>) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getObject(Block, int) - Method in class io.prestosql.spi.type.AbstractType
 
getObject(Block, int) - Method in class io.prestosql.spi.type.ArrayType
 
getObject(Block, int) - Method in class io.prestosql.spi.type.LongTimestampType
 
getObject(Block, int) - Method in class io.prestosql.spi.type.MapType
 
getObject(Block, int) - Method in class io.prestosql.spi.type.RowType
 
getObject(Block, int) - Method in interface io.prestosql.spi.type.Type
Gets the value at the block position as an Object.
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.ArrayType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.BigintType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.BooleanType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.CharType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.DateType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.DoubleType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.HyperLogLogType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.IntegerType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.LongTimestampType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.MapType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.P4HyperLogLogType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.QuantileDigestType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.RealType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.RowType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.ShortTimestampType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.SmallintType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.TimestampWithTimeZoneType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.TimeType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.TimeWithTimeZoneType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.TinyintType
 
getObjectValue(ConnectorSession, Block, int) - Method in interface io.prestosql.spi.type.Type
Gets an object representation of the type value in the block position.
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.VarbinaryType
 
getObjectValue(ConnectorSession, Block, int) - Method in class io.prestosql.spi.type.VarcharType
 
getOffset() - Method in class io.prestosql.spi.block.SingleMapBlock
 
getOffset(int) - Method in class io.prestosql.spi.block.ColumnarArray
 
getOffset(int) - Method in class io.prestosql.spi.block.ColumnarMap
 
getOffsetBase() - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getOffsetBase() - Method in class io.prestosql.spi.block.AbstractMapBlock
offset is entry-based, not position-based.
getOffsetBase() - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getOffsetBase() - Method in class io.prestosql.spi.block.ArrayBlock
 
getOffsetBase() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
getOffsetBase() - Method in class io.prestosql.spi.block.MapBlock
 
getOffsetBase() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
getOffsetBase() - Method in class io.prestosql.spi.block.RowBlock
 
getOffsetBase() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
getOffsets() - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getOffsets() - Method in class io.prestosql.spi.block.AbstractMapBlock
offset is entry-based, not position-based.
getOffsets() - Method in class io.prestosql.spi.block.ArrayBlock
 
getOffsets() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
getOffsets() - Method in class io.prestosql.spi.block.MapBlock
 
getOffsets() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
getOperator() - Method in enum io.prestosql.spi.function.OperatorType
 
getOperatorSummaries() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getOrder() - Method in class io.prestosql.spi.connector.SortingProperty
 
getOrderedRanges() - Method in interface io.prestosql.spi.predicate.Ranges
 
getOrderedRanges() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
getOriginalSql() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition
 
getOutput() - Method in class io.prestosql.spi.eventlistener.QueryIOMetadata
 
getOutputBytes() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getOutputRows() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getOutputTableHandleClass() - Method in interface io.prestosql.spi.connector.ConnectorHandleResolver
 
getOutputType() - Method in class io.prestosql.spi.connector.AggregateFunction
 
getOwner() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition
 
getP25() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getP50() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getP75() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getP90() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getP95() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getP99() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getPageIndexerFactory() - Method in interface io.prestosql.spi.connector.ConnectorContext
 
getPageSinkProvider() - Method in interface io.prestosql.spi.connector.Connector
 
getPageSorter() - Method in interface io.prestosql.spi.connector.ConnectorContext
 
getPageSourceProvider() - Method in interface io.prestosql.spi.connector.Connector
 
getParameterizedType(String, List<TypeSignatureParameter>) - Method in interface io.prestosql.spi.type.TypeManager
Gets the type with the specified base type and the given parameters.
getParameters() - Method in class io.prestosql.spi.type.TypeSignature
 
getParametricTypes() - Method in interface io.prestosql.spi.Plugin
 
getParametrizedVarcharSignature(String) - Static method in class io.prestosql.spi.type.VarcharType
 
getParent() - Method in class io.prestosql.spi.resourcegroups.ResourceGroupId
 
getPartitionColumns() - Method in class io.prestosql.spi.connector.ConnectorNewTableLayout
 
getPartitioning() - Method in class io.prestosql.spi.connector.ConnectorNewTableLayout
 
getPartitioningColumns() - Method in class io.prestosql.spi.connector.ConnectorTablePartitioning
The columns used to partition the table across the worker nodes.
getPartitioningHandle() - Method in class io.prestosql.spi.connector.ConnectorTablePartitioning
A handle to the partitioning scheme used to divide the table across worker nodes.
getPartitioningHandleClass() - Method in interface io.prestosql.spi.connector.ConnectorHandleResolver
 
getPasswordAuthenticatorFactories() - Method in interface io.prestosql.spi.Plugin
 
getPayload() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getPayload() - Method in class io.prestosql.spi.eventlistener.SplitCompletedEvent
 
getPeakMemoryBytes() - Method in class io.prestosql.spi.session.ResourceEstimates
 
getPeakTaskTotalMemory() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getPeakTaskUserMemory() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getPeakTotalNonRevocableMemoryBytes() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getPeakUserMemoryBytes() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getPhysicalInputBytes() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getPhysicalInputRows() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getPicosOfMicro() - Method in class io.prestosql.spi.type.LongTimestamp
 
getPicosOfMicros() - Method in class io.prestosql.spi.type.SqlTimestamp
 
getPlan() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getPlanNodeStatsAndCosts() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getPort() - Method in class io.prestosql.spi.HostAddress
Get the current port number, failing if no port is defined.
getPortOrDefault(int) - Method in class io.prestosql.spi.HostAddress
Returns the current port number, with a default if no port is defined.
getPositionCount() - Method in class io.prestosql.spi.block.ArrayBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
getPositionCount() - Method in interface io.prestosql.spi.block.Block
Returns the number of positions in this block.
getPositionCount() - Method in class io.prestosql.spi.block.ByteArrayBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
getPositionCount() - Method in class io.prestosql.spi.block.ColumnarArray
 
getPositionCount() - Method in class io.prestosql.spi.block.ColumnarMap
 
getPositionCount() - Method in class io.prestosql.spi.block.ColumnarRow
 
getPositionCount() - Method in class io.prestosql.spi.block.DictionaryBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
getPositionCount() - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getPositionCount() - Method in class io.prestosql.spi.block.IntArrayBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
getPositionCount() - Method in class io.prestosql.spi.block.LazyBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.LongArrayBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
getPositionCount() - Method in class io.prestosql.spi.block.MapBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
getPositionCount() - Method in class io.prestosql.spi.block.RowBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
getPositionCount() - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.ShortArrayBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
getPositionCount() - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
getPositionCount() - Method in class io.prestosql.spi.block.SingleMapBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
getPositionCount() - Method in class io.prestosql.spi.block.SingleRowBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
getPositionCount() - Method in class io.prestosql.spi.block.VariableWidthBlock
 
getPositionCount() - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
getPositionCount() - Method in class io.prestosql.spi.Page
 
getPositionCount() - Method in class io.prestosql.spi.PageBuilder
 
getPositionOffset(int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
getPositionOffset(int) - Method in class io.prestosql.spi.block.VariableWidthBlock
 
getPositionOffset(int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
getPositions(int[], int, int) - Method in interface io.prestosql.spi.block.Block
Create a new block from the current block by keeping the same elements only with respect to positions that starts at offset and has length of length.
getPositions(int[], int, int) - Method in interface io.prestosql.spi.block.BlockBuilder
Create a new block from the current materialized block by keeping the same elements only with respect to visiblePositions.
getPositions(int[], int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getPositions(int[], int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
getPositions(int[], int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getPositions(int[], int, int) - Method in class io.prestosql.spi.Page
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getPositionsSizeInBytes(boolean[]) - Method in interface io.prestosql.spi.block.Block
Returns the size of of all positions marked true in the positions array.
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.IntArrayBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.LazyBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.LongArrayBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.VariableWidthBlock
 
getPositionsSizeInBytes(boolean[]) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
getPrecision() - Method in class io.prestosql.spi.type.DecimalType
 
getPrecision() - Method in class io.prestosql.spi.type.SqlDecimal
 
getPrecision() - Method in class io.prestosql.spi.type.SqlTimestamp
 
getPrecision() - Method in class io.prestosql.spi.type.TimestampType
 
getPredicate() - Method in class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
A TupleDomain that represents a predicate that every row this TableScan node produces is guaranteed to satisfy.
getPredicate() - Method in class io.prestosql.spi.connector.ConnectorTableProperties
A TupleDomain that represents a predicate that every row in this table satisfies.
getPredicateColumns() - Method in class io.prestosql.spi.connector.Constraint
Set of columns the Constraint.predicate() result depends on.
getPredicates() - Method in class io.prestosql.spi.connector.DiscretePredicates
 
getPreparedQuery() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getPrincipal() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getPrincipal() - Method in class io.prestosql.spi.security.ConnectorIdentity
 
getPrincipal() - Method in class io.prestosql.spi.security.Identity
 
getPrintableValue(ConnectorSession) - Method in class io.prestosql.spi.predicate.Marker
 
getPrivilege() - Method in class io.prestosql.spi.security.PrivilegeInfo
 
getPrivilegeInfo() - Method in class io.prestosql.spi.security.GrantInfo
 
getProcedures() - Method in interface io.prestosql.spi.connector.Connector
 
getProjections() - Method in class io.prestosql.spi.connector.AggregationApplicationResult
 
getProjections() - Method in class io.prestosql.spi.connector.ProjectionApplicationResult
 
getProperties() - Method in class io.prestosql.spi.connector.ColumnMetadata
 
getProperties() - Method in class io.prestosql.spi.connector.ConnectorTableMetadata
 
getProperty(String, Class<T>) - Method in interface io.prestosql.spi.connector.ConnectorSession
 
getQuery() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getQueryId() - Method in class io.prestosql.spi.connector.ConnectorSecurityContext
 
getQueryId() - Method in interface io.prestosql.spi.connector.ConnectorSession
 
getQueryId() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getQueryId() - Method in class io.prestosql.spi.eventlistener.SplitCompletedEvent
 
getQueryId() - Method in class io.prestosql.spi.security.SystemSecurityContext
 
getQueryMemoryAllocations() - Method in class io.prestosql.spi.memory.MemoryPoolInfo
 
getQueryMemoryReservations() - Method in class io.prestosql.spi.memory.MemoryPoolInfo
 
getQueryMemoryRevocableReservations() - Method in class io.prestosql.spi.memory.MemoryPoolInfo
 
getQueryState() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getQueryType() - Method in class io.prestosql.spi.resourcegroups.SelectionCriteria
 
getQueryType() - Method in class io.prestosql.spi.session.SessionConfigurationContext
 
getQueuedTime() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getQueuedTime() - Method in class io.prestosql.spi.eventlistener.SplitStatistics
 
getRange() - Method in class io.prestosql.spi.statistics.ColumnStatistics
 
getRange() - Method in class io.prestosql.spi.type.BigintType
 
getRange() - Method in class io.prestosql.spi.type.DoubleType
 
getRange() - Method in class io.prestosql.spi.type.IntegerType
 
getRange() - Method in class io.prestosql.spi.type.RealType
 
getRange() - Method in class io.prestosql.spi.type.SmallintType
 
getRange() - Method in class io.prestosql.spi.type.TinyintType
 
getRange() - Method in interface io.prestosql.spi.type.Type
Return the range of possible values for this type, if available.
getRange() - Method in class io.prestosql.spi.type.VarcharType
 
getRangeCount() - Method in interface io.prestosql.spi.predicate.Ranges
 
getRangeCount() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
getRanges() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
getRanges() - Method in interface io.prestosql.spi.predicate.ValueSet
 
getRawElementBlock() - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getRawElementBlock() - Method in class io.prestosql.spi.block.ArrayBlock
 
getRawElementBlock() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
getRawFieldBlock(int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getRawFieldBlock(int) - Method in class io.prestosql.spi.block.SingleRowBlock
 
getRawFieldBlock(int) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
getRawFieldBlocks() - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getRawFieldBlocks() - Method in class io.prestosql.spi.block.RowBlock
 
getRawFieldBlocks() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
getRawKeyBlock() - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getRawKeyBlock() - Method in class io.prestosql.spi.block.MapBlock
 
getRawKeyBlock() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
getRawMessage() - Method in exception io.prestosql.spi.PrestoException
 
getRawSlice(int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
getRawSlice(int) - Method in class io.prestosql.spi.block.VariableWidthBlock
 
getRawSlice(int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
getRawValueBlock() - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getRawValueBlock() - Method in class io.prestosql.spi.block.MapBlock
 
getRawValueBlock() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
getReadTimeNanos() - Method in interface io.prestosql.spi.connector.ConnectorPageSource
Gets the wall time this page source spent reading data from the input.
getReadTimeNanos() - Method in class io.prestosql.spi.connector.EmptyPageSource
 
getReadTimeNanos() - Method in class io.prestosql.spi.connector.FixedPageSource
 
getReadTimeNanos() - Method in interface io.prestosql.spi.connector.RecordCursor
Gets the wall time spent reading data.
getReadTimeNanos() - Method in class io.prestosql.spi.connector.RecordPageSource
 
getRecordSet(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, ConnectorTableHandle, List<? extends ColumnHandle>) - Method in interface io.prestosql.spi.connector.ConnectorRecordSetProvider
 
getRecordSet(ConnectorTransactionHandle, ConnectorSession, ConnectorSplit, List<? extends ColumnHandle>) - Method in interface io.prestosql.spi.connector.ConnectorRecordSetProvider
Deprecated.
getRecordSetProvider() - Method in interface io.prestosql.spi.connector.Connector
 
getRegion(int, int) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getRegion(int, int) - Method in interface io.prestosql.spi.block.Block
Returns a block starting at the specified position and extends for the specified length.
getRegion(int, int) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
getRegion(int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
getRegion(int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getRegion(int, int) - Method in class io.prestosql.spi.block.IntArrayBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
getRegion(int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.LongArrayBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
getRegion(int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
getRegion(int, int) - Method in class io.prestosql.spi.block.VariableWidthBlock
 
getRegion(int, int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
getRegion(int, int) - Method in class io.prestosql.spi.Page
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getRegionSizeInBytes(int, int) - Method in interface io.prestosql.spi.block.Block
Returns the size of block.getRegion(position, length).
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.IntArrayBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.LongArrayBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.VariableWidthBlock
 
getRegionSizeInBytes(int, int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
getRemainingFilter() - Method in class io.prestosql.spi.connector.ConstraintApplicationResult
 
getRemoteClientAddress() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getRemoteHost() - Method in exception io.prestosql.spi.PrestoTransportException
 
getRequiredWorkerNodes() - Method in interface io.prestosql.spi.NodeManager
 
getReservedBytes() - Method in class io.prestosql.spi.memory.MemoryPoolInfo
 
getReservedRevocableBytes() - Method in class io.prestosql.spi.memory.MemoryPoolInfo
 
getResourceEstimates() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getResourceEstimates() - Method in class io.prestosql.spi.resourcegroups.SelectionCriteria
 
getResourceGroupConfigurationManagerFactories() - Method in interface io.prestosql.spi.Plugin
 
getResourceGroupId() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getResourceGroupId() - Method in class io.prestosql.spi.resourcegroups.SelectionContext
 
getResourceGroupId() - Method in class io.prestosql.spi.session.SessionConfigurationContext
 
getResourceWaitingTime() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.ArrayBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
getRetainedSizeInBytes() - Method in interface io.prestosql.spi.block.Block
Returns the retained size of this block in memory, including over-allocations.
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.ByteArrayBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.DictionaryBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.IntArrayBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.LazyBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.LongArrayBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.MapBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.MapHashTables
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.RowBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.ShortArrayBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.SingleMapBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.SingleRowBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.VariableWidthBlock
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.Page
 
getRetainedSizeInBytes() - Method in class io.prestosql.spi.PageBuilder
 
getReturnConvention() - Method in class io.prestosql.spi.function.InvocationConvention
 
getRole() - Method in class io.prestosql.spi.security.ConnectorIdentity
 
getRole() - Method in class io.prestosql.spi.security.SelectedRole
 
getRoleName() - Method in class io.prestosql.spi.security.RoleGrant
 
getRoles() - Method in class io.prestosql.spi.security.Identity
 
getRoot() - Method in class io.prestosql.spi.resourcegroups.ResourceGroupId
 
getRoutine() - Method in class io.prestosql.spi.eventlistener.RoutineInfo
 
getRoutineName() - Method in class io.prestosql.spi.connector.CatalogSchemaRoutineName
 
getRoutineName() - Method in class io.prestosql.spi.connector.SchemaRoutineName
 
getRoutines() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getRowCount() - Method in class io.prestosql.spi.statistics.TableStatistics
 
getRowFilter(ConnectorSecurityContext, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorAccessControl
Get a row filter associated with the given table and identity.
getRowFilter(SystemSecurityContext, CatalogSchemaTableName) - Method in interface io.prestosql.spi.security.SystemAccessControl
Get a row filter associated with the given table and identity.
getRowIndex() - Method in class io.prestosql.spi.block.SingleRowBlock
 
getRowIsNull() - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getRowIsNull() - Method in class io.prestosql.spi.block.RowBlock
 
getRowIsNull() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
getScale() - Method in class io.prestosql.spi.type.DecimalType
 
getScale() - Method in class io.prestosql.spi.type.SqlDecimal
 
getSchedulingPolicy() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getSchedulingWeight() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getSchema() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition
 
getSchema() - Method in class io.prestosql.spi.connector.SchemaTablePrefix
 
getSchema() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getSchema() - Method in class io.prestosql.spi.eventlistener.QueryInputMetadata
 
getSchema() - Method in class io.prestosql.spi.eventlistener.QueryOutputMetadata
 
getSchema() - Method in class io.prestosql.spi.eventlistener.TableInfo
 
getSchema() - Method in class io.prestosql.spi.procedure.Procedure
 
getSchema() - Method in class io.prestosql.spi.security.ViewExpression
 
getSchemaName() - Method in class io.prestosql.spi.connector.CatalogSchemaName
 
getSchemaName() - Method in class io.prestosql.spi.connector.CatalogSchemaRoutineName
 
getSchemaName() - Method in exception io.prestosql.spi.connector.SchemaNotFoundException
 
getSchemaName() - Method in class io.prestosql.spi.connector.SchemaRoutineName
 
getSchemaName() - Method in class io.prestosql.spi.connector.SchemaTableName
 
getSchemaOwner(ConnectorSession, CatalogSchemaName) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Get the schema properties for the specified schema.
getSchemaProperties() - Method in interface io.prestosql.spi.connector.Connector
 
getSchemaProperties(ConnectorSession, CatalogSchemaName) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Gets the schema properties for the specified schema.
getSchemaRoutineName() - Method in class io.prestosql.spi.connector.CatalogSchemaRoutineName
 
getSchemaTableName() - Method in class io.prestosql.spi.connector.CatalogSchemaTableName
 
getSchemaTableName() - Method in class io.prestosql.spi.security.GrantInfo
 
getSegments() - Method in class io.prestosql.spi.resourcegroups.ResourceGroupId
 
getSequenceId() - Method in class io.prestosql.spi.block.DictionaryId
 
getSerializable() - Method in class io.prestosql.spi.predicate.NullableValue
 
getSerializedType() - Method in interface io.prestosql.spi.function.AccumulatorStateSerializer
 
getServerAddress() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getServerVersion() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getSessionProperties() - Method in interface io.prestosql.spi.connector.Connector
 
getSessionProperties() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getSessionPropertyConfigurationManagerFactories() - Method in interface io.prestosql.spi.Plugin
 
getSessionTimeZoneKey() - Method in class io.prestosql.spi.type.SqlTime
Deprecated.
applicable in legacy timestamp semantics only
getSessionTimeZoneKey() - Method in class io.prestosql.spi.type.SqlTimestamp
Deprecated.
applicable in legacy timestamp semantics only
getShort(int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getShort(int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getShort(int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getShort(int, int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
getShort(int, int) - Method in interface io.prestosql.spi.block.Block
Gets a little endian short at offset in the value at position.
getShort(int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getShort(int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
getShort(int, int) - Method in class io.prestosql.spi.block.LongArrayBlock
Deprecated.
getShort(int, int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
Deprecated.
getShort(int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getShort(int, int) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
getShort(int, int) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
getSingleStateClass() - Method in interface io.prestosql.spi.function.AccumulatorStateFactory
 
getSingleValue() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
getSingleValue() - Method in class io.prestosql.spi.predicate.Domain
 
getSingleValue() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
getSingleValue() - Method in class io.prestosql.spi.predicate.Range
 
getSingleValue() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
getSingleValue() - Method in interface io.prestosql.spi.predicate.ValueSet
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.AbstractMapBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
getSingleValueBlock(int) - Method in interface io.prestosql.spi.block.Block
Gets the value at the specified position as a single element block.
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.IntArrayBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.LazyBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.LongArrayBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
getSingleValueBlock(int) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
getSingleValueBlock(int, int) - Method in interface io.prestosql.spi.function.WindowIndex
Gets a value stored as a Block.
getSingleValuePage(int) - Method in class io.prestosql.spi.Page
Gets the values at the specified position as a single element page.
getSizeInBytes() - Method in class io.prestosql.spi.block.ArrayBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
getSizeInBytes() - Method in interface io.prestosql.spi.block.Block
Returns the size of this block as if it was compacted, ignoring any over-allocations and any unloaded nested blocks.
getSizeInBytes() - Method in class io.prestosql.spi.block.ByteArrayBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
getSizeInBytes() - Method in class io.prestosql.spi.block.DictionaryBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
getSizeInBytes() - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
getSizeInBytes() - Method in class io.prestosql.spi.block.IntArrayBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
getSizeInBytes() - Method in class io.prestosql.spi.block.LazyBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.LongArrayBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
getSizeInBytes() - Method in class io.prestosql.spi.block.MapBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
getSizeInBytes() - Method in class io.prestosql.spi.block.PageBuilderStatus
 
getSizeInBytes() - Method in class io.prestosql.spi.block.RowBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
getSizeInBytes() - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.ShortArrayBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
getSizeInBytes() - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
getSizeInBytes() - Method in class io.prestosql.spi.block.SingleMapBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
getSizeInBytes() - Method in class io.prestosql.spi.block.SingleRowBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
getSizeInBytes() - Method in class io.prestosql.spi.block.VariableWidthBlock
 
getSizeInBytes() - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
getSizeInBytes() - Method in class io.prestosql.spi.Page
 
getSizeInBytes() - Method in class io.prestosql.spi.PageBuilder
 
getSlice(int) - Method in interface io.prestosql.spi.connector.RecordCursor
 
getSlice(int, int) - Method in interface io.prestosql.spi.function.WindowIndex
Gets a value as a Slice.
getSlice(int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getSlice(int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getSlice(int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getSlice(int, int, int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
getSlice(int, int, int) - Method in interface io.prestosql.spi.block.Block
Gets a slice at offset in the value at position.
getSlice(int, int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getSlice(int, int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
getSlice(int, int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getSlice(Block, int) - Method in class io.prestosql.spi.type.AbstractIntType
 
getSlice(Block, int) - Method in class io.prestosql.spi.type.AbstractLongType
 
getSlice(Block, int) - Method in class io.prestosql.spi.type.AbstractType
 
getSlice(Block, int) - Method in class io.prestosql.spi.type.ArrayType
 
getSlice(Block, int) - Method in class io.prestosql.spi.type.CharType
 
getSlice(Block, int) - Method in class io.prestosql.spi.type.HyperLogLogType
 
getSlice(Block, int) - Method in class io.prestosql.spi.type.P4HyperLogLogType
 
getSlice(Block, int) - Method in class io.prestosql.spi.type.QuantileDigestType
 
getSlice(Block, int) - Method in interface io.prestosql.spi.type.Type
Gets the value at the block position as a Slice.
getSlice(Block, int) - Method in class io.prestosql.spi.type.VarbinaryType
 
getSlice(Block, int) - Method in class io.prestosql.spi.type.VarcharType
 
getSliceLength(int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
getSliceLength(int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
getSliceLength(int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
getSliceLength(int) - Method in interface io.prestosql.spi.block.Block
Gets the length of the value at the position.
getSliceLength(int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
getSliceLength(int) - Method in class io.prestosql.spi.block.LazyBlock
 
getSliceLength(int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getSliceLength(int) - Method in class io.prestosql.spi.block.VariableWidthBlock
 
getSliceLength(int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
getSoftConcurrencyLimit() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getSoftCpuLimit() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getSoftMemoryLimitBytes() - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
 
getSortItems() - Method in class io.prestosql.spi.connector.AggregateFunction
 
getSortOrder() - Method in class io.prestosql.spi.connector.SortItem
 
getSource() - Method in interface io.prestosql.spi.connector.ConnectorSession
 
getSource() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getSource() - Method in class io.prestosql.spi.resourcegroups.SelectionCriteria
 
getSource() - Method in class io.prestosql.spi.session.SessionConfigurationContext
 
getSpan() - Method in interface io.prestosql.spi.predicate.Ranges
 
getSpan() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
getSplitBucketFunction(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle) - Method in interface io.prestosql.spi.connector.ConnectorNodePartitioningProvider
 
getSplitClass() - Method in interface io.prestosql.spi.connector.ConnectorHandleResolver
 
getSplitManager() - Method in interface io.prestosql.spi.connector.Connector
 
getSplits() - Method in class io.prestosql.spi.connector.ConnectorSplitSource.ConnectorSplitBatch
 
getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableHandle, ConnectorSplitManager.SplitSchedulingStrategy) - Method in interface io.prestosql.spi.connector.ConnectorSplitManager
 
getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableHandle, ConnectorSplitManager.SplitSchedulingStrategy, Supplier<TupleDomain<ColumnHandle>>) - Method in interface io.prestosql.spi.connector.ConnectorSplitManager
 
getSplits(ConnectorTransactionHandle, ConnectorSession, ConnectorTableLayoutHandle, ConnectorSplitManager.SplitSchedulingStrategy) - Method in interface io.prestosql.spi.connector.ConnectorSplitManager
Deprecated.
getSqlType() - Method in class io.prestosql.spi.session.PropertyMetadata
SQL type of the property.
getStageGcStatistics() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getStageId() - Method in class io.prestosql.spi.eventlistener.SplitCompletedEvent
 
getStageId() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getStageId() - Method in class io.prestosql.spi.eventlistener.StageGcStatistics
 
getStart() - Method in interface io.prestosql.spi.connector.ConnectorSession
 
getStartTime() - Method in interface io.prestosql.spi.connector.ConnectorSession
Deprecated.
getStartTime() - Method in class io.prestosql.spi.eventlistener.SplitCompletedEvent
 
getStatistics() - Method in class io.prestosql.spi.eventlistener.QueryCompletedEvent
 
getStatistics() - Method in class io.prestosql.spi.eventlistener.SplitCompletedEvent
 
getStatisticsCollectionMetadata(ConnectorSession, ConnectorTableMetadata) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Describe statistics that must be collected during a statistics collection
getStatisticsCollectionMetadataForWrite(ConnectorSession, ConnectorTableMetadata) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Describes statistics that must be collected during a write.
getStatisticType() - Method in class io.prestosql.spi.statistics.ColumnStatisticMetadata
 
getStreamPartitioningColumns() - Method in class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
The partitioning for the table streams.
getStreamPartitioningColumns() - Method in class io.prestosql.spi.connector.ConnectorTableProperties
The partitioning for the table streams.
getSummary() - Method in class io.prestosql.spi.connector.Constraint
 
getSystemAccessControlFactories() - Method in interface io.prestosql.spi.Plugin
 
getSystemMemoryUsage() - Method in interface io.prestosql.spi.connector.ConnectorPageSink
Get the total memory that needs to be reserved in the general memory pool.
getSystemMemoryUsage() - Method in interface io.prestosql.spi.connector.ConnectorPageSource
Get the total memory that needs to be reserved in the general memory pool.
getSystemMemoryUsage() - Method in class io.prestosql.spi.connector.EmptyPageSource
 
getSystemMemoryUsage() - Method in class io.prestosql.spi.connector.FixedPageSource
 
getSystemMemoryUsage() - Method in interface io.prestosql.spi.connector.RecordCursor
 
getSystemMemoryUsage() - Method in class io.prestosql.spi.connector.RecordPageSource
 
getSystemSessionProperties(SessionConfigurationContext) - Method in interface io.prestosql.spi.session.SessionPropertyConfigurationManager
 
getSystemTable(ConnectorSession, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Returns the system table for the specified table name, if one exists.
getSystemTables() - Method in interface io.prestosql.spi.connector.Connector
 
getTable() - Method in class io.prestosql.spi.connector.ConnectorTableMetadata
 
getTable() - Method in class io.prestosql.spi.connector.SchemaTablePrefix
 
getTable() - Method in class io.prestosql.spi.eventlistener.QueryInputMetadata
 
getTable() - Method in class io.prestosql.spi.eventlistener.QueryOutputMetadata
 
getTable() - Method in class io.prestosql.spi.eventlistener.TableInfo
 
getTableHandle(ConnectorSession, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Returns a table handle for the specified table name, or null if the connector does not contain the table.
getTableHandleClass() - Method in interface io.prestosql.spi.connector.ConnectorHandleResolver
 
getTableHandleForStatisticsCollection(ConnectorSession, SchemaTableName, Map<String, Object>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Returns a table handle for the specified table name, or null if the connector does not contain the table.
getTableLayout() - Method in class io.prestosql.spi.connector.ConnectorTableLayoutResult
 
getTableLayout(ConnectorSession, ConnectorTableLayoutHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Deprecated.
getTableLayoutHandleClass() - Method in interface io.prestosql.spi.connector.ConnectorHandleResolver
 
getTableLayouts(ConnectorSession, ConnectorTableHandle, Constraint, Optional<Set<ColumnHandle>>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Deprecated.
getTableMetadata() - Method in interface io.prestosql.spi.connector.SystemTable
 
getTableMetadata(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Return the metadata for the specified table handle.
getTableName() - Method in exception io.prestosql.spi.connector.ColumnNotFoundException
 
getTableName() - Method in class io.prestosql.spi.connector.SchemaTableName
 
getTableName() - Method in exception io.prestosql.spi.connector.TableNotFoundException
 
getTablePartitioning() - Method in class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
The partitioning of the table across the worker nodes.
getTablePartitioning() - Method in class io.prestosql.spi.connector.ConnectorTableProperties
The partitioning of the table across the worker nodes.
getTableProperties() - Method in interface io.prestosql.spi.connector.Connector
 
getTableProperties(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
 
getTables() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getTableStatistics() - Method in class io.prestosql.spi.statistics.ComputedStatistics
 
getTableStatistics() - Method in class io.prestosql.spi.statistics.TableStatisticsMetadata
 
getTableStatistics(ConnectorSession, ConnectorTableHandle, Constraint) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Get statistics for table for given filtering constraint.
getTag() - Method in class io.prestosql.spi.memory.MemoryAllocation
 
getTags() - Method in class io.prestosql.spi.resourcegroups.SelectionCriteria
 
getTarget() - Method in class io.prestosql.spi.expression.FieldDereference
 
getTaskId() - Method in class io.prestosql.spi.eventlistener.SplitCompletedEvent
 
getTasks() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getTasks() - Method in class io.prestosql.spi.eventlistener.StageGcStatistics
 
getTimeToFirstByte() - Method in class io.prestosql.spi.eventlistener.SplitStatistics
Deprecated.
getTimeToLastByte() - Method in class io.prestosql.spi.eventlistener.SplitStatistics
Deprecated.
getTimeZoneKey() - Method in interface io.prestosql.spi.connector.ConnectorSession
 
getTimeZoneKey() - Method in class io.prestosql.spi.type.SqlTimestampWithTimeZone
 
getTimeZoneKey() - Method in class io.prestosql.spi.type.SqlTimeWithTimeZone
 
getTimeZoneKey(short) - Static method in class io.prestosql.spi.type.TimeZoneKey
 
getTimeZoneKey(String) - Static method in class io.prestosql.spi.type.TimeZoneKey
 
getTimeZoneKeyForOffset(long) - Static method in class io.prestosql.spi.type.TimeZoneKey
 
getTimeZoneKeys() - Static method in class io.prestosql.spi.type.TimeZoneKey
 
getTotal() - Method in class io.prestosql.spi.eventlistener.StageCpuDistribution
 
getTotalBytes() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getTotalFullGcSec() - Method in class io.prestosql.spi.eventlistener.StageGcStatistics
 
getTotalRows() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getTraceToken() - Method in interface io.prestosql.spi.connector.ConnectorSession
 
getTraceToken() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getTransactionHandle() - Method in class io.prestosql.spi.connector.ConnectorSecurityContext
 
getTransactionHandleClass() - Method in interface io.prestosql.spi.connector.ConnectorHandleResolver
 
getTransactionId() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getType() - Method in class io.prestosql.spi.connector.Assignment
 
getType() - Method in class io.prestosql.spi.connector.ColumnMetadata
 
getType() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition.ViewColumn
 
getType() - Method in class io.prestosql.spi.ErrorCode
 
getType() - Method in class io.prestosql.spi.expression.ConnectorExpression
 
getType() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
getType() - Method in class io.prestosql.spi.predicate.Domain
 
getType() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
getType() - Method in class io.prestosql.spi.predicate.EquatableValueSet.ValueEntry
 
getType() - Method in class io.prestosql.spi.predicate.Marker
 
getType() - Method in class io.prestosql.spi.predicate.NullableValue
 
getType() - Method in class io.prestosql.spi.predicate.NullableValue.Serializable
 
getType() - Method in class io.prestosql.spi.predicate.Range
 
getType() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
getType() - Method in interface io.prestosql.spi.predicate.ValueSet
 
getType() - Method in class io.prestosql.spi.procedure.Procedure.Argument
 
getType() - Method in class io.prestosql.spi.security.PrestoPrincipal
 
getType() - Method in class io.prestosql.spi.security.SelectedRole
 
getType() - Method in class io.prestosql.spi.type.DecimalParseResult
 
getType() - Method in class io.prestosql.spi.type.NamedType
 
getType() - Method in class io.prestosql.spi.type.RowType.Field
 
getType() - Method in exception io.prestosql.spi.type.TypeNotFoundException
 
getType() - Method in class io.prestosql.spi.type.TypeParameter
 
getType(int) - Method in interface io.prestosql.spi.connector.RecordCursor
 
getType(int) - Method in class io.prestosql.spi.PageBuilder
 
getType(TypeId) - Method in interface io.prestosql.spi.type.TypeManager
Gets the type with the give (opaque) id
getType(TypeSignature) - Method in interface io.prestosql.spi.type.TypeManager
Gets the type with the specified signature.
getTypeId() - Method in interface io.prestosql.spi.type.Type
 
getTypeManager() - Method in interface io.prestosql.spi.connector.ConnectorContext
 
getTypeParameters() - Method in class io.prestosql.spi.type.AbstractType
 
getTypeParameters() - Method in class io.prestosql.spi.type.ArrayType
 
getTypeParameters() - Method in class io.prestosql.spi.type.MapType
 
getTypeParameters() - Method in class io.prestosql.spi.type.QuantileDigestType
 
getTypeParameters() - Method in class io.prestosql.spi.type.RowType
 
getTypeParameters() - Method in interface io.prestosql.spi.type.Type
For parameterized types returns the list of parameters.
getTypeParametersAsTypeSignatures() - Method in class io.prestosql.spi.type.TypeSignature
 
getTypes() - Method in interface io.prestosql.spi.Plugin
 
getTypeSignature() - Method in class io.prestosql.spi.type.AbstractType
 
getTypeSignature() - Method in class io.prestosql.spi.type.NamedTypeSignature
 
getTypeSignature() - Method in interface io.prestosql.spi.type.Type
Gets the name of this type which must be case insensitive globally unique.
getTypeSignature() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
getTypeSignatureOrNamedTypeSignature() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
getUnenforcedConstraint() - Method in class io.prestosql.spi.connector.ConnectorTableLayoutResult
 
getUnresolvedTupleDomain() - Method in class io.prestosql.spi.connector.ConnectorResolvedIndex
 
getUnscaledValue() - Method in class io.prestosql.spi.type.SqlDecimal
 
getUpdateRowIdColumnHandle(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Get the column handle that will generate row IDs for the delete operation.
getUpdateType() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getUri() - Method in class io.prestosql.spi.eventlistener.QueryMetadata
 
getUser() - Method in interface io.prestosql.spi.connector.ConnectorSession
 
getUser() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getUser() - Method in class io.prestosql.spi.resourcegroups.SelectionCriteria
 
getUser() - Method in class io.prestosql.spi.security.ConnectorIdentity
 
getUser() - Method in class io.prestosql.spi.security.Identity
 
getUser() - Method in class io.prestosql.spi.session.SessionConfigurationContext
 
getUserAgent() - Method in class io.prestosql.spi.eventlistener.QueryContext
 
getUserGroups() - Method in class io.prestosql.spi.resourcegroups.SelectionCriteria
 
getValidationCpuNanos() - Method in interface io.prestosql.spi.connector.ConnectorPageSink
ConnectorPageSink can provide optional validation to check the data is correctly consumed by connector (e.g.
getValue() - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
getValue() - Method in class io.prestosql.spi.expression.Constant
 
getValue() - Method in class io.prestosql.spi.predicate.EquatableValueSet.ValueEntry
 
getValue() - Method in class io.prestosql.spi.predicate.Marker
 
getValue() - Method in class io.prestosql.spi.predicate.NullableValue
 
getValue() - Method in class io.prestosql.spi.statistics.Estimate
 
getValue(ParameterKind, Class<A>) - Method in class io.prestosql.spi.type.TypeParameter
 
getValueBlock() - Method in class io.prestosql.spi.predicate.Marker
 
getValueIsNull() - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
getValueIsNull() - Method in class io.prestosql.spi.block.ArrayBlock
 
getValueIsNull() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
getValues() - Method in interface io.prestosql.spi.predicate.DiscreteValues
 
getValues() - Method in class io.prestosql.spi.predicate.Domain
 
getValues() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
getValuesBlock() - Method in class io.prestosql.spi.block.ColumnarMap
 
getValuesCount() - Method in interface io.prestosql.spi.predicate.DiscreteValues
 
getValuesCount() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
getValuesProcessor() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
getValuesProcessor() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
getValuesProcessor() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
getValuesProcessor() - Method in interface io.prestosql.spi.predicate.ValueSet
 
getValueType() - Method in class io.prestosql.spi.type.MapType
 
getVariable() - Method in class io.prestosql.spi.connector.Assignment
 
getVariable() - Method in class io.prestosql.spi.type.TypeParameter
 
getVariable() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
getVersion() - Method in interface io.prestosql.spi.Node
 
getVersionEmbedder() - Method in interface io.prestosql.spi.connector.ConnectorContext
 
getView(ConnectorSession, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Gets the view data for the specified view name.
getViewName() - Method in exception io.prestosql.spi.connector.ViewNotFoundException
 
getViews(ConnectorSession, Optional<String>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Gets the definitions of views, possibly filtered by schema.
getWallTime() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getWallTime() - Method in class io.prestosql.spi.eventlistener.SplitStatistics
 
getWarningCode() - Method in class io.prestosql.spi.PrestoWarning
 
getWarnings() - Method in class io.prestosql.spi.eventlistener.QueryCompletedEvent
 
getWithHierarchy() - Method in class io.prestosql.spi.security.GrantInfo
 
getWorkerNodes() - Method in interface io.prestosql.spi.NodeManager
 
getWrittenBytes() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getWrittenRows() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
getZoneId() - Method in class io.prestosql.spi.type.TimeZoneKey
 
getZoneId() - Method in exception io.prestosql.spi.type.TimeZoneNotSupportedException
 
GrantInfo - Class in io.prestosql.spi.security
 
GrantInfo(PrivilegeInfo, PrestoPrincipal, SchemaTableName, Optional<PrestoPrincipal>, Optional<Boolean>) - Constructor for class io.prestosql.spi.security.GrantInfo
 
grantRoles(ConnectorSession, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Grants the specified roles to the specified grantees
grantTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, PrestoPrincipal, boolean) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Grants the specified privilege to the specified user on the specified table
GREATER_THAN - io.prestosql.spi.function.OperatorType
 
GREATER_THAN_OR_EQUAL - io.prestosql.spi.function.OperatorType
 
greaterAdjacent() - Method in class io.prestosql.spi.predicate.Marker
 
greaterThan(Type, Object) - Static method in class io.prestosql.spi.predicate.Range
 
greaterThanOrEqual(Type, Object) - Static method in class io.prestosql.spi.predicate.Range
 
GROUPED_SCHEDULING - io.prestosql.spi.connector.ConnectorSplitManager.SplitSchedulingStrategy
 
GroupedAccumulatorState - Interface in io.prestosql.spi.function
 
GroupingProperty<E> - Class in io.prestosql.spi.connector
 
GroupingProperty(Collection<E>) - Constructor for class io.prestosql.spi.connector.GroupingProperty
 
GroupProvider - Interface in io.prestosql.spi.security
 
GroupProviderFactory - Interface in io.prestosql.spi.security
 

H

hasFixedMapping() - Method in class io.prestosql.spi.connector.ConnectorBucketNodeMap
 
hash(byte) - Static method in class io.prestosql.spi.type.TinyintType
 
hash(int) - Static method in class io.prestosql.spi.type.AbstractIntType
 
hash(int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
hash(int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
hash(int, int, int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
hash(int, int, int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
hash(int, int, int) - Method in interface io.prestosql.spi.block.Block
Calculates the hash code the byte sequences at offset in the value at position.
hash(int, int, int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
hash(int, int, int) - Method in class io.prestosql.spi.block.LazyBlock
 
hash(int, int, int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
hash(long) - Static method in class io.prestosql.spi.type.AbstractLongType
 
hash(long) - Static method in class io.prestosql.spi.type.ShortTimestampType
 
hash(long, long) - Static method in class io.prestosql.spi.type.LongTimestampType
 
hash(long, long) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
hash(short) - Static method in class io.prestosql.spi.type.SmallintType
 
hash(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
hash(Block, int) - Method in class io.prestosql.spi.type.AbstractIntType
 
hash(Block, int) - Method in class io.prestosql.spi.type.AbstractLongType
 
hash(Block, int) - Method in class io.prestosql.spi.type.AbstractType
 
hash(Block, int) - Method in class io.prestosql.spi.type.ArrayType
 
hash(Block, int) - Method in class io.prestosql.spi.type.BooleanType
 
hash(Block, int) - Method in class io.prestosql.spi.type.CharType
 
hash(Block, int) - Method in class io.prestosql.spi.type.DoubleType
 
hash(Block, int) - Method in class io.prestosql.spi.type.LongTimestampType
 
hash(Block, int) - Method in class io.prestosql.spi.type.MapType
 
hash(Block, int) - Method in class io.prestosql.spi.type.RealType
 
hash(Block, int) - Method in class io.prestosql.spi.type.RowType
 
hash(Block, int) - Method in class io.prestosql.spi.type.ShortTimestampType
 
hash(Block, int) - Method in class io.prestosql.spi.type.SmallintType
 
hash(Block, int) - Method in class io.prestosql.spi.type.TimestampWithTimeZoneType
 
hash(Block, int) - Method in class io.prestosql.spi.type.TimeWithTimeZoneType
 
hash(Block, int) - Method in class io.prestosql.spi.type.TinyintType
 
hash(Block, int) - Method in interface io.prestosql.spi.type.Type
Calculates the hash code of the value at the specified position in the specified block.
hash(Block, int) - Method in class io.prestosql.spi.type.VarbinaryType
 
hash(Block, int) - Method in class io.prestosql.spi.type.VarcharType
 
hash(LongTimestamp) - Static method in class io.prestosql.spi.type.LongTimestampType
 
HASH_CODE - io.prestosql.spi.function.OperatorType
 
hashCode() - Method in class io.prestosql.spi.block.DictionaryId
 
hashCode() - Method in class io.prestosql.spi.connector.AggregateFunction
 
hashCode() - Method in class io.prestosql.spi.connector.CatalogSchemaName
 
hashCode() - Method in class io.prestosql.spi.connector.CatalogSchemaRoutineName
 
hashCode() - Method in class io.prestosql.spi.connector.CatalogSchemaTableName
 
hashCode() - Method in class io.prestosql.spi.connector.ColumnMetadata
 
hashCode() - Method in class io.prestosql.spi.connector.ConnectorPartitionHandle
 
hashCode() - Method in class io.prestosql.spi.connector.ConnectorTableLayout
Deprecated.
 
hashCode() - Method in class io.prestosql.spi.connector.ConnectorTablePartitioning
 
hashCode() - Method in class io.prestosql.spi.connector.ConnectorTableProperties
 
hashCode() - Method in class io.prestosql.spi.connector.ConstantProperty
 
hashCode() - Method in class io.prestosql.spi.connector.GroupingProperty
 
hashCode() - Method in class io.prestosql.spi.connector.NotPartitionedPartitionHandle
 
hashCode() - Method in class io.prestosql.spi.connector.SchemaRoutineName
 
hashCode() - Method in class io.prestosql.spi.connector.SchemaTableName
 
hashCode() - Method in class io.prestosql.spi.connector.SchemaTablePrefix
 
hashCode() - Method in class io.prestosql.spi.connector.SortingProperty
 
hashCode() - Method in class io.prestosql.spi.connector.SortItem
 
hashCode() - Method in class io.prestosql.spi.ErrorCode
 
hashCode() - Method in class io.prestosql.spi.expression.ConnectorExpression
 
hashCode() - Method in class io.prestosql.spi.expression.Constant
 
hashCode() - Method in class io.prestosql.spi.expression.FieldDereference
 
hashCode() - Method in class io.prestosql.spi.expression.Variable
 
hashCode() - Method in class io.prestosql.spi.HostAddress
 
hashCode() - Method in class io.prestosql.spi.memory.MemoryPoolId
 
hashCode() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
hashCode() - Method in class io.prestosql.spi.predicate.Domain
 
hashCode() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
hashCode() - Method in class io.prestosql.spi.predicate.EquatableValueSet.ValueEntry
 
hashCode() - Method in class io.prestosql.spi.predicate.Marker
 
hashCode() - Method in class io.prestosql.spi.predicate.NullableValue
 
hashCode() - Method in class io.prestosql.spi.predicate.Range
 
hashCode() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
hashCode() - Method in class io.prestosql.spi.predicate.TupleDomain
 
hashCode() - Method in class io.prestosql.spi.PrestoWarning
 
hashCode() - Method in class io.prestosql.spi.QueryId
 
hashCode() - Method in class io.prestosql.spi.resourcegroups.ResourceGroupId
 
hashCode() - Method in class io.prestosql.spi.security.BasicPrincipal
 
hashCode() - Method in class io.prestosql.spi.security.GrantInfo
 
hashCode() - Method in class io.prestosql.spi.security.Identity
 
hashCode() - Method in class io.prestosql.spi.security.PrestoPrincipal
 
hashCode() - Method in class io.prestosql.spi.security.PrivilegeInfo
 
hashCode() - Method in class io.prestosql.spi.security.RoleGrant
 
hashCode() - Method in class io.prestosql.spi.security.SelectedRole
 
hashCode() - Method in class io.prestosql.spi.statistics.ColumnStatisticMetadata
 
hashCode() - Method in class io.prestosql.spi.statistics.ColumnStatistics
 
hashCode() - Method in class io.prestosql.spi.statistics.DoubleRange
 
hashCode() - Method in class io.prestosql.spi.statistics.Estimate
 
hashCode() - Method in class io.prestosql.spi.statistics.TableStatistics
 
hashCode() - Method in class io.prestosql.spi.type.AbstractType
 
hashCode() - Method in class io.prestosql.spi.type.BigintType
 
hashCode() - Method in class io.prestosql.spi.type.BooleanType
 
hashCode() - Method in class io.prestosql.spi.type.CharType
 
hashCode() - Method in class io.prestosql.spi.type.DateType
 
hashCode() - Method in class io.prestosql.spi.type.DecimalParseResult
 
hashCode() - Method in class io.prestosql.spi.type.DoubleType
 
hashCode() - Method in class io.prestosql.spi.type.IntegerType
 
hashCode() - Method in class io.prestosql.spi.type.LongTimestamp
 
hashCode() - Method in class io.prestosql.spi.type.NamedType
 
hashCode() - Method in class io.prestosql.spi.type.NamedTypeSignature
 
hashCode() - Method in class io.prestosql.spi.type.RealType
 
hashCode() - Method in class io.prestosql.spi.type.RowFieldName
 
hashCode() - Method in class io.prestosql.spi.type.SmallintType
 
hashCode() - Method in class io.prestosql.spi.type.SqlDate
 
hashCode() - Method in class io.prestosql.spi.type.SqlDecimal
 
hashCode() - Method in class io.prestosql.spi.type.SqlTime
 
hashCode() - Method in class io.prestosql.spi.type.SqlTimestamp
 
hashCode() - Method in class io.prestosql.spi.type.SqlTimestampWithTimeZone
 
hashCode() - Method in class io.prestosql.spi.type.SqlTimeWithTimeZone
 
hashCode() - Method in class io.prestosql.spi.type.SqlVarbinary
 
hashCode() - Method in class io.prestosql.spi.type.TimestampWithTimeZoneType
 
hashCode() - Method in class io.prestosql.spi.type.TimeType
 
hashCode() - Method in class io.prestosql.spi.type.TimeWithTimeZoneType
 
hashCode() - Method in class io.prestosql.spi.type.TimeZoneKey
 
hashCode() - Method in class io.prestosql.spi.type.TinyintType
 
hashCode() - Method in class io.prestosql.spi.type.TypeId
 
hashCode() - Method in class io.prestosql.spi.type.TypeParameter
 
hashCode() - Method in class io.prestosql.spi.type.TypeSignature
 
hashCode() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
hashCode() - Method in class io.prestosql.spi.type.VarbinaryType
 
hashCode() - Method in class io.prestosql.spi.type.VarcharType
 
hashCode() - Method in class io.prestosql.spi.WarningCode
 
hasPort() - Method in class io.prestosql.spi.HostAddress
Return true if this instance has a defined port.
hidden() - Method in annotation type io.prestosql.spi.function.AggregationFunction
 
hidden() - Method in annotation type io.prestosql.spi.function.ScalarFunction
 
HostAddress - Class in io.prestosql.spi
An immutable representation of a host and port.
HYPER_LOG_LOG - Static variable in class io.prestosql.spi.type.HyperLogLogType
 
HYPER_LOG_LOG - Static variable in class io.prestosql.spi.type.StandardTypes
 
HyperLogLogType - Class in io.prestosql.spi.type
 
HyperLogLogType() - Constructor for class io.prestosql.spi.type.HyperLogLogType
 

I

Identity - Class in io.prestosql.spi.security
 
Identity.Builder - Class in io.prestosql.spi.security
 
includes(Marker) - Method in class io.prestosql.spi.predicate.Range
 
includesNullableValue(Object) - Method in class io.prestosql.spi.predicate.Domain
 
INCOMPATIBLE_CLIENT - io.prestosql.spi.StandardErrorCode
 
incrementUnsafe(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
INDETERMINATE - io.prestosql.spi.function.OperatorType
 
indexPage(Page) - Method in interface io.prestosql.spi.PageIndexer
Returns the unique index of each position value.
InMemoryRecordSet - Class in io.prestosql.spi.connector
 
InMemoryRecordSet(Collection<? extends Type>, Iterable<? extends List<?>>) - Constructor for class io.prestosql.spi.connector.InMemoryRecordSet
 
InMemoryRecordSet.Builder - Class in io.prestosql.spi.connector
 
InputFunction - Annotation Type in io.prestosql.spi.function
 
INSERT - io.prestosql.spi.resourcegroups.QueryType
 
INSERT - io.prestosql.spi.security.Privilege
 
INSTANCE_SIZE - Static variable in class io.prestosql.spi.block.BlockBuilderStatus
 
INSTANCE_SIZE - Static variable in class io.prestosql.spi.block.MapHashTables
 
INSTANCE_SIZE - Static variable in class io.prestosql.spi.Page
 
INSUFFICIENT_RESOURCES - io.prestosql.spi.ErrorType
 
INT128_BYTES - Static variable in class io.prestosql.spi.block.Int128ArrayBlock
 
Int128ArrayBlock - Class in io.prestosql.spi.block
 
Int128ArrayBlock(int, Optional<boolean[]>, long[]) - Constructor for class io.prestosql.spi.block.Int128ArrayBlock
 
Int128ArrayBlockBuilder - Class in io.prestosql.spi.block
 
Int128ArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
Int128ArrayBlockEncoding - Class in io.prestosql.spi.block
 
Int128ArrayBlockEncoding() - Constructor for class io.prestosql.spi.block.Int128ArrayBlockEncoding
 
INT96_BYTES - Static variable in class io.prestosql.spi.block.Int96ArrayBlock
 
Int96ArrayBlock - Class in io.prestosql.spi.block
 
Int96ArrayBlock(int, Optional<boolean[]>, long[], int[]) - Constructor for class io.prestosql.spi.block.Int96ArrayBlock
 
Int96ArrayBlockBuilder - Class in io.prestosql.spi.block
 
Int96ArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
Int96ArrayBlockEncoding - Class in io.prestosql.spi.block
 
Int96ArrayBlockEncoding() - Constructor for class io.prestosql.spi.block.Int96ArrayBlockEncoding
 
IntArrayBlock - Class in io.prestosql.spi.block
 
IntArrayBlock(int, Optional<boolean[]>, int[]) - Constructor for class io.prestosql.spi.block.IntArrayBlock
 
IntArrayBlockBuilder - Class in io.prestosql.spi.block
 
IntArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.prestosql.spi.block.IntArrayBlockBuilder
 
IntArrayBlockEncoding - Class in io.prestosql.spi.block
 
IntArrayBlockEncoding() - Constructor for class io.prestosql.spi.block.IntArrayBlockEncoding
 
INTEGER - Static variable in class io.prestosql.spi.type.IntegerType
 
INTEGER - Static variable in class io.prestosql.spi.type.StandardTypes
 
integerProperty(String, String, Integer, boolean) - Static method in class io.prestosql.spi.session.PropertyMetadata
 
IntegerType - Class in io.prestosql.spi.type
 
INTERNAL_ERROR - io.prestosql.spi.ErrorType
 
intersect(Domain) - Method in class io.prestosql.spi.predicate.Domain
 
intersect(Range) - Method in class io.prestosql.spi.predicate.Range
 
intersect(TupleDomain<T>) - Method in class io.prestosql.spi.predicate.TupleDomain
Returns the strict intersection of the TupleDomains.
intersect(ValueSet) - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
intersect(ValueSet) - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
intersect(ValueSet) - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
intersect(ValueSet) - Method in interface io.prestosql.spi.predicate.ValueSet
 
INTERVAL_DAY_TO_SECOND - Static variable in class io.prestosql.spi.type.StandardTypes
 
INTERVAL_YEAR_TO_MONTH - Static variable in class io.prestosql.spi.type.StandardTypes
 
intScale(long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
INVALID_ANALYZE_PROPERTY - io.prestosql.spi.StandardErrorCode
 
INVALID_ARGUMENTS - io.prestosql.spi.StandardErrorCode
 
INVALID_CAST_ARGUMENT - io.prestosql.spi.StandardErrorCode
 
INVALID_COLUMN_MASK - io.prestosql.spi.StandardErrorCode
 
INVALID_COLUMN_PROPERTY - io.prestosql.spi.StandardErrorCode
 
INVALID_COLUMN_REFERENCE - io.prestosql.spi.StandardErrorCode
 
INVALID_FUNCTION_ARGUMENT - io.prestosql.spi.StandardErrorCode
 
INVALID_LITERAL - io.prestosql.spi.StandardErrorCode
 
INVALID_PARAMETER_USAGE - io.prestosql.spi.StandardErrorCode
 
INVALID_PRIVILEGE - io.prestosql.spi.StandardErrorCode
 
INVALID_PROCEDURE_ARGUMENT - io.prestosql.spi.StandardErrorCode
 
INVALID_PROCEDURE_DEFINITION - io.prestosql.spi.StandardErrorCode
 
INVALID_RESOURCE_GROUP - io.prestosql.spi.StandardErrorCode
 
INVALID_ROW_FILTER - io.prestosql.spi.StandardErrorCode
 
INVALID_SCHEMA_PROPERTY - io.prestosql.spi.StandardErrorCode
 
INVALID_SESSION_PROPERTY - io.prestosql.spi.StandardErrorCode
 
INVALID_SPATIAL_PARTITIONING - io.prestosql.spi.StandardErrorCode
 
INVALID_TABLE_PROPERTY - io.prestosql.spi.StandardErrorCode
 
INVALID_VIEW - io.prestosql.spi.StandardErrorCode
 
INVALID_WINDOW_FRAME - io.prestosql.spi.StandardErrorCode
 
InvocationConvention - Class in io.prestosql.spi.function
 
InvocationConvention(List<InvocationConvention.InvocationArgumentConvention>, InvocationConvention.InvocationReturnConvention, boolean, boolean) - Constructor for class io.prestosql.spi.function.InvocationConvention
 
InvocationConvention.InvocationArgumentConvention - Enum in io.prestosql.spi.function
 
InvocationConvention.InvocationReturnConvention - Enum in io.prestosql.spi.function
 
io.prestosql.spi - package io.prestosql.spi
 
io.prestosql.spi.block - package io.prestosql.spi.block
 
io.prestosql.spi.classloader - package io.prestosql.spi.classloader
 
io.prestosql.spi.connector - package io.prestosql.spi.connector
 
io.prestosql.spi.eventlistener - package io.prestosql.spi.eventlistener
 
io.prestosql.spi.expression - package io.prestosql.spi.expression
 
io.prestosql.spi.function - package io.prestosql.spi.function
 
io.prestosql.spi.memory - package io.prestosql.spi.memory
 
io.prestosql.spi.predicate - package io.prestosql.spi.predicate
 
io.prestosql.spi.procedure - package io.prestosql.spi.procedure
 
io.prestosql.spi.resourcegroups - package io.prestosql.spi.resourcegroups
 
io.prestosql.spi.security - package io.prestosql.spi.security
 
io.prestosql.spi.session - package io.prestosql.spi.session
 
io.prestosql.spi.statistics - package io.prestosql.spi.statistics
 
io.prestosql.spi.transaction - package io.prestosql.spi.transaction
 
io.prestosql.spi.type - package io.prestosql.spi.type
 
IPADDRESS - Static variable in class io.prestosql.spi.type.StandardTypes
 
IS_DISTINCT_FROM - io.prestosql.spi.function.OperatorType
 
isAdjacent(Marker) - Method in class io.prestosql.spi.predicate.Marker
Adjacency is defined by two Markers being infinitesimally close to each other.
isAll() - Method in interface io.prestosql.spi.predicate.AllOrNone
 
isAll() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
isAll() - Method in class io.prestosql.spi.predicate.Domain
 
isAll() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
isAll() - Method in class io.prestosql.spi.predicate.Range
 
isAll() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
isAll() - Method in class io.prestosql.spi.predicate.TupleDomain
Returns true if any tuples would satisfy this TupleDomain
isAll() - Method in interface io.prestosql.spi.predicate.ValueSet
 
isAncestorOf(ResourceGroupId) - Method in class io.prestosql.spi.resourcegroups.ResourceGroupId
 
isAscending() - Method in enum io.prestosql.spi.block.SortOrder
 
isAscending() - Method in enum io.prestosql.spi.connector.SortOrder
 
isAuthenticated() - Method in class io.prestosql.spi.resourcegroups.SelectionCriteria
 
isBlocked() - Method in interface io.prestosql.spi.connector.ConnectorPageSource
Returns a future that will be completed when the page source becomes unblocked.
isCalculated() - Method in class io.prestosql.spi.type.TypeSignature
 
isCalculated() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
isCharType(Type) - Static method in class io.prestosql.spi.type.Chars
 
isCompact() - Method in class io.prestosql.spi.block.DictionaryBlock
 
isComparable() - Method in class io.prestosql.spi.type.AbstractIntType
 
isComparable() - Method in class io.prestosql.spi.type.AbstractLongType
 
isComparable() - Method in class io.prestosql.spi.type.AbstractType
 
isComparable() - Method in class io.prestosql.spi.type.ArrayType
 
isComparable() - Method in class io.prestosql.spi.type.BooleanType
 
isComparable() - Method in class io.prestosql.spi.type.CharType
 
isComparable() - Method in class io.prestosql.spi.type.DecimalType
 
isComparable() - Method in class io.prestosql.spi.type.DoubleType
 
isComparable() - Method in class io.prestosql.spi.type.MapType
 
isComparable() - Method in class io.prestosql.spi.type.RowType
 
isComparable() - Method in class io.prestosql.spi.type.SmallintType
 
isComparable() - Method in class io.prestosql.spi.type.TimestampType
 
isComparable() - Method in class io.prestosql.spi.type.TinyintType
 
isComparable() - Method in interface io.prestosql.spi.type.Type
True if the type supports equalTo and hash.
isComparable() - Method in class io.prestosql.spi.type.VarbinaryType
 
isComparable() - Method in class io.prestosql.spi.type.VarcharType
 
isComplete() - Method in class io.prestosql.spi.eventlistener.QueryStatistics
 
isCoordinator() - Method in interface io.prestosql.spi.Node
 
isCoordinatorOnly() - Method in interface io.prestosql.spi.connector.ConnectorPartitioningHandle
 
isDiscreteSet() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
isDiscreteSet() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
isDiscreteSet() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
isDiscreteSet() - Method in interface io.prestosql.spi.predicate.ValueSet
 
isDistinct() - Method in class io.prestosql.spi.connector.AggregateFunction
 
isEmpty() - Method in class io.prestosql.spi.block.PageBuilderStatus
 
isEmpty() - Method in class io.prestosql.spi.connector.SchemaTablePrefix
 
isEmpty() - Method in class io.prestosql.spi.PageBuilder
 
isEmpty() - Method in class io.prestosql.spi.statistics.TableStatisticsMetadata
 
isEntryNull(int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
isEntryNull(int) - Method in class io.prestosql.spi.block.VariableWidthBlock
 
isEntryNull(int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
isFinished() - Method in interface io.prestosql.spi.connector.ConnectorPageSource
Will this page source product more pages?
isFinished() - Method in interface io.prestosql.spi.connector.ConnectorSplitSource
Returns whether any more ConnectorSplit may be produced.
isFinished() - Method in class io.prestosql.spi.connector.EmptyPageSource
 
isFinished() - Method in class io.prestosql.spi.connector.FixedPageSource
 
isFinished() - Method in class io.prestosql.spi.connector.FixedSplitSource
 
isFinished() - Method in class io.prestosql.spi.connector.RecordPageSource
 
isFull() - Method in class io.prestosql.spi.block.PageBuilderStatus
 
isFull() - Method in class io.prestosql.spi.PageBuilder
 
isGrantable() - Method in class io.prestosql.spi.security.RoleGrant
 
isGrantOption() - Method in class io.prestosql.spi.security.PrivilegeInfo
 
isHashTablesPresent() - Method in class io.prestosql.spi.block.AbstractMapBlock
 
isHidden() - Method in class io.prestosql.spi.connector.ColumnMetadata
 
isHidden() - Method in class io.prestosql.spi.session.PropertyMetadata
Is this property hidden from users?
isLegacyTimestamp() - Method in interface io.prestosql.spi.connector.ConnectorSession
 
isLegacyTimestamp() - Method in class io.prestosql.spi.type.SqlTime
 
isLegacyTimestamp() - Method in class io.prestosql.spi.type.SqlTimestamp
 
isLimitGuaranteed() - Method in class io.prestosql.spi.connector.LimitApplicationResult
 
isLoaded() - Method in class io.prestosql.spi.block.ArrayBlock
 
isLoaded() - Method in interface io.prestosql.spi.block.Block
Returns true if block data is fully loaded into memory.
isLoaded() - Method in class io.prestosql.spi.block.DictionaryBlock
 
isLoaded() - Method in class io.prestosql.spi.block.LazyBlock
 
isLoaded() - Method in class io.prestosql.spi.block.MapBlock
 
isLoaded() - Method in class io.prestosql.spi.block.RowBlock
 
isLoaded() - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
isLoaded() - Method in class io.prestosql.spi.block.SingleMapBlock
 
isLoaded() - Method in class io.prestosql.spi.block.SingleRowBlock
 
isLongDecimal(Type) - Static method in class io.prestosql.spi.type.Decimals
 
isLongLiteral() - Method in class io.prestosql.spi.type.TypeParameter
 
isLongLiteral() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
isLowerUnbounded() - Method in class io.prestosql.spi.predicate.Marker
 
isNamedTypeSignature() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
isNegative(long, long) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
isNegative(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
isNoMoreSplits() - Method in class io.prestosql.spi.connector.ConnectorSplitSource.ConnectorSplitBatch
 
isNone() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
isNone() - Method in class io.prestosql.spi.predicate.Domain
 
isNone() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
isNone() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
isNone() - Method in class io.prestosql.spi.predicate.TupleDomain
Returns true if no tuple could ever satisfy this TupleDomain
isNone() - Method in interface io.prestosql.spi.predicate.ValueSet
 
isNull() - Method in class io.prestosql.spi.predicate.NullableValue
 
isNull(int) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
isNull(int) - Method in class io.prestosql.spi.block.AbstractMapBlock
 
isNull(int) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
isNull(int) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
isNull(int) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
isNull(int) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
isNull(int) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
isNull(int) - Method in interface io.prestosql.spi.block.Block
Is the specified position null?
isNull(int) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
isNull(int) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
isNull(int) - Method in class io.prestosql.spi.block.ColumnarArray
 
isNull(int) - Method in class io.prestosql.spi.block.ColumnarMap
 
isNull(int) - Method in class io.prestosql.spi.block.ColumnarRow
 
isNull(int) - Method in class io.prestosql.spi.block.DictionaryBlock
 
isNull(int) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
isNull(int) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
isNull(int) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
isNull(int) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
isNull(int) - Method in class io.prestosql.spi.block.IntArrayBlock
 
isNull(int) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
isNull(int) - Method in class io.prestosql.spi.block.LazyBlock
 
isNull(int) - Method in class io.prestosql.spi.block.LongArrayBlock
 
isNull(int) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
isNull(int) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
isNull(int) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
isNull(int) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
isNull(int) - Method in interface io.prestosql.spi.connector.RecordCursor
 
isNull(int, int) - Method in interface io.prestosql.spi.function.WindowIndex
Check if a value is null.
IsNull - Annotation Type in io.prestosql.spi.function
 
isNullable() - Method in class io.prestosql.spi.connector.ColumnMetadata
 
isNullableSingleValue() - Method in class io.prestosql.spi.predicate.Domain
 
isNullAllowed() - Method in class io.prestosql.spi.predicate.Domain
 
isNullsFirst() - Method in enum io.prestosql.spi.block.SortOrder
 
isNullsFirst() - Method in enum io.prestosql.spi.connector.SortOrder
 
IsolationLevel - Enum in io.prestosql.spi.transaction
 
isOnlyNull() - Method in class io.prestosql.spi.predicate.Domain
 
isOptional() - Method in class io.prestosql.spi.procedure.Procedure.Argument
 
isOrderable() - Method in class io.prestosql.spi.type.AbstractIntType
 
isOrderable() - Method in class io.prestosql.spi.type.AbstractLongType
 
isOrderable() - Method in class io.prestosql.spi.type.AbstractType
 
isOrderable() - Method in class io.prestosql.spi.type.ArrayType
 
isOrderable() - Method in class io.prestosql.spi.type.BooleanType
 
isOrderable() - Method in class io.prestosql.spi.type.CharType
 
isOrderable() - Method in class io.prestosql.spi.type.DecimalType
 
isOrderable() - Method in class io.prestosql.spi.type.DoubleType
 
isOrderable() - Method in class io.prestosql.spi.type.RowType
 
isOrderable() - Method in class io.prestosql.spi.type.SmallintType
 
isOrderable() - Method in class io.prestosql.spi.type.TimestampType
 
isOrderable() - Method in class io.prestosql.spi.type.TinyintType
 
isOrderable() - Method in interface io.prestosql.spi.type.Type
True if the type supports compareTo.
isOrderable() - Method in class io.prestosql.spi.type.VarbinaryType
 
isOrderable() - Method in class io.prestosql.spi.type.VarcharType
 
isOrderSensitive() - Method in class io.prestosql.spi.connector.ConstantProperty
 
isOrderSensitive() - Method in class io.prestosql.spi.connector.GroupingProperty
 
isOrderSensitive() - Method in interface io.prestosql.spi.connector.LocalProperty
Returns true if reordering breaks this LocalProperty
isOrderSensitive() - Method in class io.prestosql.spi.connector.SortingProperty
 
isOrderSensitive() - Method in annotation type io.prestosql.spi.function.AggregationFunction
Indicates whether the result of the function depends on the order in which data is fed in, which allows the engine to optimize away ORDER BY clauses in aggregation calls
isRemotelyAccessible() - Method in interface io.prestosql.spi.connector.ConnectorSplit
 
isRequired() - Method in class io.prestosql.spi.procedure.Procedure.Argument
 
isRunAsInvoker() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition
 
isShort() - Method in class io.prestosql.spi.type.DecimalType
 
isShortDecimal(Type) - Static method in class io.prestosql.spi.type.Decimals
 
isSimplifiedBy(LocalProperty<E>) - Method in class io.prestosql.spi.connector.ConstantProperty
 
isSimplifiedBy(LocalProperty<E>) - Method in class io.prestosql.spi.connector.GroupingProperty
 
isSimplifiedBy(LocalProperty<E>) - Method in interface io.prestosql.spi.connector.LocalProperty
Return true if the actual LocalProperty can be used to simplify this LocalProperty
isSimplifiedBy(LocalProperty<E>) - Method in class io.prestosql.spi.connector.SortingProperty
 
isSingleNode() - Method in interface io.prestosql.spi.connector.ConnectorPartitioningHandle
 
isSingleStatementWritesOnly() - Method in interface io.prestosql.spi.connector.Connector
True if the connector only supports write statements in independent transactions.
isSingleValue() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
isSingleValue() - Method in class io.prestosql.spi.predicate.Domain
 
isSingleValue() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
isSingleValue() - Method in class io.prestosql.spi.predicate.Range
 
isSingleValue() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
isSingleValue() - Method in interface io.prestosql.spi.predicate.ValueSet
 
isStrictlyNegative(long, long) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
isStrictlyNegative(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
isTypeSignature() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
isUnbounded() - Method in class io.prestosql.spi.type.VarcharType
 
isUnknown() - Method in class io.prestosql.spi.statistics.Estimate
 
isUpperUnbounded() - Method in class io.prestosql.spi.predicate.Marker
 
isUtcZoneId(String) - Static method in class io.prestosql.spi.type.TimeZoneKey
 
isVarbinaryType(Type) - Static method in class io.prestosql.spi.type.VarbinaryType
 
isVarcharType(Type) - Static method in class io.prestosql.spi.type.Varchars
 
isVariable() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
isWhiteList() - Method in interface io.prestosql.spi.predicate.DiscreteValues
 
isWhiteList() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
isZero(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 

J

JSON - Static variable in class io.prestosql.spi.type.StandardTypes
 
JSON_FORMAT - Static variable in class io.prestosql.spi.type.SqlTimestamp
 
JSON_FORMAT - Static variable in class io.prestosql.spi.type.SqlTimestampWithTimeZone
 
JSON_FORMATTER - Static variable in class io.prestosql.spi.type.SqlTimestamp
 
jsonValue() - Method in class io.prestosql.spi.type.TypeSignature
 
jsonValue() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 

L

LazyBlock - Class in io.prestosql.spi.block
 
LazyBlock(int, LazyBlockLoader) - Constructor for class io.prestosql.spi.block.LazyBlock
 
LazyBlockEncoding - Class in io.prestosql.spi.block
 
LazyBlockEncoding() - Constructor for class io.prestosql.spi.block.LazyBlockEncoding
 
LazyBlockLoader - Interface in io.prestosql.spi.block
 
legacyFromMillis(int, long, TimeZoneKey) - Static method in class io.prestosql.spi.type.SqlTimestamp
Deprecated.
LESS_THAN - io.prestosql.spi.function.OperatorType
 
LESS_THAN_OR_EQUAL - io.prestosql.spi.function.OperatorType
 
lesserAdjacent() - Method in class io.prestosql.spi.predicate.Marker
 
lessThan(Type, Object) - Static method in class io.prestosql.spi.predicate.Range
 
lessThanOrEqual(Type, Object) - Static method in class io.prestosql.spi.predicate.Range
 
LimitApplicationResult<T> - Class in io.prestosql.spi.connector
 
LimitApplicationResult(T, boolean) - Constructor for class io.prestosql.spi.connector.LimitApplicationResult
 
listAllRoleGrants(ConnectorSession, Optional<Set<String>>, Optional<Set<String>>, OptionalLong) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
List all role grants in the specified catalog, optionally filtered by passed role, grantee, and limit predicates.
listApplicableRoles(ConnectorSession, PrestoPrincipal) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
List applicable roles, including the transitive grants, for the specified principal
listEnabledRoles(ConnectorSession) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
List applicable roles, including the transitive grants, in given session
listenForLoads(Block, Consumer<Block>) - Static method in class io.prestosql.spi.block.LazyBlock
 
listPartitionHandles(ConnectorTransactionHandle, ConnectorSession, ConnectorPartitioningHandle) - Method in interface io.prestosql.spi.connector.ConnectorNodePartitioningProvider
Returns a list of all partitions associated with the provided partitioningHandle.
listRoleGrants(ConnectorSession, PrestoPrincipal) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
List role grants for a given principal, not recursively.
listRoles(ConnectorSession) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
List available roles.
listSchemaNames(ConnectorSession) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Returns the schemas provided by this connector.
listTableColumns(ConnectorSession, SchemaTablePrefix) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Gets the metadata for all columns that match the specified table prefix.
listTablePrivileges(ConnectorSession, SchemaTablePrefix) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
List the table privileges granted to the specified grantee for the tables that have the specified prefix considering the selected session role
listTables(ConnectorSession, Optional<String>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
List table and view names, possibly filtered by schema.
listViews(ConnectorSession, Optional<String>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
 
LiteralParameter - Annotation Type in io.prestosql.spi.function
 
LiteralParameters - Annotation Type in io.prestosql.spi.function
 
load() - Method in interface io.prestosql.spi.block.LazyBlockLoader
Loads a lazy block.
LocalProperty<E> - Interface in io.prestosql.spi.connector
 
Location - Class in io.prestosql.spi
 
Location(int, int) - Constructor for class io.prestosql.spi.Location
 
LONG - io.prestosql.spi.type.ParameterKind
 
LongArrayBlock - Class in io.prestosql.spi.block
 
LongArrayBlock(int, Optional<boolean[]>, long[]) - Constructor for class io.prestosql.spi.block.LongArrayBlock
 
LongArrayBlockBuilder - Class in io.prestosql.spi.block
 
LongArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.prestosql.spi.block.LongArrayBlockBuilder
 
LongArrayBlockEncoding - Class in io.prestosql.spi.block
 
LongArrayBlockEncoding() - Constructor for class io.prestosql.spi.block.LongArrayBlockEncoding
 
longDecimalToDouble(Slice, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
longDecimalToReal(Slice, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
longProperty(String, String, Long, boolean) - Static method in class io.prestosql.spi.session.PropertyMetadata
 
longTenToNth(int) - Static method in class io.prestosql.spi.type.Decimals
 
LongTimestamp - Class in io.prestosql.spi.type
 
LongTimestamp(long, int) - Constructor for class io.prestosql.spi.type.LongTimestamp
 
LongTimestampType - Class in io.prestosql.spi.type
The representation is a 96-bit value that contains the microseconds from the epoch in the first long and the fractional increment in the remaining integer, as a number of picoseconds additional to the epoch microsecond.
LongTimestampType(int) - Constructor for class io.prestosql.spi.type.LongTimestampType
 
longToLongCast(Slice, long, long, long, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
longToShortCast(Slice, long, long, long, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
lookup(RecordSet) - Method in interface io.prestosql.spi.connector.ConnectorIndex
 
lowerUnbounded(Type) - Static method in class io.prestosql.spi.predicate.Marker
 

M

makeCompatiblePartitioning(ConnectorSession, ConnectorTableHandle, ConnectorPartitioningHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Return a table handle whose partitioning is converted to the provided partitioning handle, but otherwise identical to the provided table handle.
makeCompatiblePartitioning(ConnectorSession, ConnectorTableLayoutHandle, ConnectorPartitioningHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Deprecated.
use the version without layouts
MAP - Static variable in class io.prestosql.spi.type.StandardTypes
 
MapBlock - Class in io.prestosql.spi.block
 
MapBlockBuilder - Class in io.prestosql.spi.block
 
MapBlockBuilder(MapType, BlockBuilderStatus, int) - Constructor for class io.prestosql.spi.block.MapBlockBuilder
 
MapBlockEncoding - Class in io.prestosql.spi.block
 
MapBlockEncoding(TypeManager) - Constructor for class io.prestosql.spi.block.MapBlockEncoding
 
MapHashTables - Class in io.prestosql.spi.block
 
mapType(TypeSignature, TypeSignature) - Static method in class io.prestosql.spi.type.TypeSignature
 
MapType - Class in io.prestosql.spi.type
 
MapType(Type, Type, MethodHandle, MethodHandle, MethodHandle, MethodHandle) - Constructor for class io.prestosql.spi.type.MapType
 
Marker - Class in io.prestosql.spi.predicate
A point on the continuous space defined by the specified type.
Marker(Type, Optional<Block>, Marker.Bound) - Constructor for class io.prestosql.spi.predicate.Marker
LOWER UNBOUNDED is specified with an empty value and a ABOVE bound UPPER UNBOUNDED is specified with an empty value and a BELOW bound
Marker.Bound - Enum in io.prestosql.spi.predicate
 
match(SelectionCriteria) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroupConfigurationManager
This method is called for every query that is submitted, so it should be fast.
matches(SchemaTableName) - Method in class io.prestosql.spi.connector.SchemaTablePrefix
 
max(Marker, Marker) - Static method in class io.prestosql.spi.predicate.Marker
 
MAX_DECIMAL_UNSCALED_VALUE - Static variable in class io.prestosql.spi.type.Decimals
 
MAX_LENGTH - Static variable in class io.prestosql.spi.type.CharType
 
MAX_LENGTH - Static variable in class io.prestosql.spi.type.VarcharType
 
MAX_PRECISION - Static variable in class io.prestosql.spi.type.Decimals
 
MAX_PRECISION - Static variable in class io.prestosql.spi.type.TimestampType
 
MAX_SHORT_PRECISION - Static variable in class io.prestosql.spi.type.Decimals
 
MAX_SHORT_PRECISION - Static variable in class io.prestosql.spi.type.TimestampType
 
MAX_TIME_ZONE_KEY - Static variable in class io.prestosql.spi.type.TimeZoneKey
 
MAX_VALUE - io.prestosql.spi.statistics.ColumnStatisticType
 
MAX_VALUE_SIZE_IN_BYTES - io.prestosql.spi.statistics.ColumnStatisticType
 
mayHaveNull() - Method in interface io.prestosql.spi.block.Block
Is it possible the block may have a null value? If false, the block cannot contain a null, but if true, the block may or may not have a null.
mayHaveNull() - Method in class io.prestosql.spi.block.ByteArrayBlock
 
mayHaveNull() - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
mayHaveNull() - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
mayHaveNull() - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
mayHaveNull() - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
mayHaveNull() - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
mayHaveNull() - Method in class io.prestosql.spi.block.IntArrayBlock
 
mayHaveNull() - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
mayHaveNull() - Method in class io.prestosql.spi.block.LongArrayBlock
 
mayHaveNull() - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
mayHaveNull() - Method in class io.prestosql.spi.block.ShortArrayBlock
 
mayHaveNull() - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
mayHaveNull() - Method in class io.prestosql.spi.block.VariableWidthBlock
 
mayHaveNull() - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
meetsRequirementOf(IsolationLevel) - Method in enum io.prestosql.spi.transaction.IsolationLevel
 
MemoryAllocation - Class in io.prestosql.spi.memory
 
MemoryAllocation(String, long) - Constructor for class io.prestosql.spi.memory.MemoryAllocation
 
MemoryPoolId - Class in io.prestosql.spi.memory
 
MemoryPoolId(String) - Constructor for class io.prestosql.spi.memory.MemoryPoolId
 
MemoryPoolInfo - Class in io.prestosql.spi.memory
 
MemoryPoolInfo(long, long, long, Map<QueryId, Long>, Map<QueryId, List<MemoryAllocation>>, Map<QueryId, Long>) - Constructor for class io.prestosql.spi.memory.MemoryPoolInfo
 
metadataDelete(ConnectorSession, ConnectorTableHandle, ConnectorTableLayoutHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Delete the provided table layout
methodHandle(Class<?>, String, Class<?>...) - Static method in class io.prestosql.spi.block.MethodHandleUtil
Returns a MethodHandle corresponding to the specified method.
MethodHandleUtil - Class in io.prestosql.spi.block
 
min(Marker, Marker) - Static method in class io.prestosql.spi.predicate.Marker
 
MIN_DECIMAL_UNSCALED_VALUE - Static variable in class io.prestosql.spi.type.Decimals
 
MIN_VALUE - io.prestosql.spi.statistics.ColumnStatisticType
 
MISMATCHED_COLUMN_ALIASES - io.prestosql.spi.StandardErrorCode
 
MISSING_CATALOG_NAME - io.prestosql.spi.StandardErrorCode
 
MISSING_COLUMN_NAME - io.prestosql.spi.StandardErrorCode
 
MISSING_GROUP_BY - io.prestosql.spi.StandardErrorCode
 
MISSING_ORDER_BY - io.prestosql.spi.StandardErrorCode
 
MISSING_OVER - io.prestosql.spi.StandardErrorCode
 
MISSING_SCHEMA_NAME - io.prestosql.spi.StandardErrorCode
 
MODULUS - io.prestosql.spi.function.OperatorType
 
MULTI_CATALOG_WRITE_CONFLICT - io.prestosql.spi.StandardErrorCode
 
multipleValues(Type, List<?>) - Static method in class io.prestosql.spi.predicate.Domain
 
multiply(Slice, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
multiply(Slice, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
multiply(Slice, Slice, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
MULTIPLY - io.prestosql.spi.function.OperatorType
 
multiply256(Slice, Slice, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 

N

name() - Method in annotation type io.prestosql.spi.function.FunctionDependency
 
name() - Method in annotation type io.prestosql.spi.function.TypeParameterSpecialization
 
name() - Method in annotation type io.prestosql.spi.function.WindowFunctionSignature
 
NAME - Static variable in class io.prestosql.spi.block.ArrayBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.ByteArrayBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.DictionaryBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.Int128ArrayBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.Int96ArrayBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.IntArrayBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.LazyBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.LongArrayBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.MapBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.RowBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.RunLengthBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.ShortArrayBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.SingleMapBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.SingleRowBlockEncoding
 
NAME - Static variable in class io.prestosql.spi.block.VariableWidthBlockEncoding
 
NAMED_TYPE - io.prestosql.spi.type.ParameterKind
 
namedField(String, TypeSignature) - Static method in class io.prestosql.spi.type.TypeSignatureParameter
 
NamedType - Class in io.prestosql.spi.type
 
NamedType(Optional<RowFieldName>, Type) - Constructor for class io.prestosql.spi.type.NamedType
 
namedTypeParameter(NamedTypeSignature) - Static method in class io.prestosql.spi.type.TypeSignatureParameter
 
NamedTypeSignature - Class in io.prestosql.spi.type
 
NamedTypeSignature(Optional<RowFieldName>, TypeSignature) - Constructor for class io.prestosql.spi.type.NamedTypeSignature
 
nativeContainerType() - Method in annotation type io.prestosql.spi.function.SqlType
 
nativeContainerType() - Method in annotation type io.prestosql.spi.function.TypeParameterSpecialization
 
nativeValueGetter(Type) - Static method in class io.prestosql.spi.block.MethodHandleUtil
 
nativeValueToBlock(Type, Object) - Static method in class io.prestosql.spi.predicate.Utils
 
nativeValueWriter(Type) - Static method in class io.prestosql.spi.block.MethodHandleUtil
 
negate(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
NEGATION - io.prestosql.spi.function.OperatorType
 
NESTED_AGGREGATION - io.prestosql.spi.StandardErrorCode
 
NESTED_WINDOW - io.prestosql.spi.StandardErrorCode
 
NEVER_NULL - io.prestosql.spi.function.InvocationConvention.InvocationArgumentConvention
Argument must not be a boxed type.
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
newBlockBuilderLike(BlockBuilderStatus) - Method in interface io.prestosql.spi.block.BlockBuilder
Creates a new block builder of the same type based on the current usage statistics of this block builder.
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.MapBlockBuilder
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.RowBlockBuilder
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
newBlockBuilderLike(BlockBuilderStatus) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
newInstance(int, long, int) - Static method in class io.prestosql.spi.type.SqlTimestamp
 
newLegacyInstance(int, long, int, TimeZoneKey) - Static method in class io.prestosql.spi.type.SqlTimestamp
Deprecated.
newPageBuilderLike() - Method in class io.prestosql.spi.PageBuilder
 
NO_NODES_AVAILABLE - io.prestosql.spi.StandardErrorCode
 
Node - Interface in io.prestosql.spi
 
NodeManager - Interface in io.prestosql.spi
 
none() - Static method in class io.prestosql.spi.predicate.TupleDomain
 
none(Type) - Static method in class io.prestosql.spi.predicate.Domain
 
none(Type) - Static method in interface io.prestosql.spi.predicate.ValueSet
 
NONE - io.prestosql.spi.security.SelectedRole.Type
 
NOT_BLOCKED - Static variable in interface io.prestosql.spi.connector.ConnectorPageSink
 
NOT_BLOCKED - Static variable in interface io.prestosql.spi.connector.ConnectorPageSource
 
NOT_EQUAL - io.prestosql.spi.function.OperatorType
 
NOT_FOUND - io.prestosql.spi.StandardErrorCode
 
NOT_IN_TRANSACTION - io.prestosql.spi.StandardErrorCode
 
NOT_NULL_COLUMN_CONSTRAINT - io.prestosql.spi.connector.ConnectorCapabilities
 
NOT_PARTITIONED - Static variable in class io.prestosql.spi.connector.NotPartitionedPartitionHandle
 
NOT_SUPPORTED - io.prestosql.spi.StandardErrorCode
 
NotFoundException - Exception in io.prestosql.spi.connector
 
NotFoundException() - Constructor for exception io.prestosql.spi.connector.NotFoundException
 
NotFoundException(String) - Constructor for exception io.prestosql.spi.connector.NotFoundException
 
NotFoundException(String, Throwable) - Constructor for exception io.prestosql.spi.connector.NotFoundException
 
NotFoundException(Throwable) - Constructor for exception io.prestosql.spi.connector.NotFoundException
 
notNull(Type) - Static method in class io.prestosql.spi.predicate.Domain
 
NotPartitionedPartitionHandle - Class in io.prestosql.spi.connector
 
NULL_FLAG - io.prestosql.spi.function.InvocationConvention.InvocationArgumentConvention
Argument must not be a boxed type, and is always followed with a boolean argument to indicate if the sql value is null.
NULL_HASH_CODE - Static variable in class io.prestosql.spi.type.TypeUtils
 
NULL_TREATMENT_NOT_ALLOWED - io.prestosql.spi.StandardErrorCode
 
NULLABLE_RETURN - io.prestosql.spi.function.InvocationConvention.InvocationReturnConvention
 
NullableValue - Class in io.prestosql.spi.predicate
 
NullableValue(Type, Object) - Constructor for class io.prestosql.spi.predicate.NullableValue
 
NullableValue.Serializable - Class in io.prestosql.spi.predicate
 
NUMBER_OF_DISTINCT_VALUES - io.prestosql.spi.statistics.ColumnStatisticType
 
NUMBER_OF_NON_NULL_VALUES - io.prestosql.spi.statistics.ColumnStatisticType
 
NUMBER_OF_TRUE_VALUES - io.prestosql.spi.statistics.ColumnStatisticType
 
NUMERIC_VALUE_OUT_OF_RANGE - io.prestosql.spi.StandardErrorCode
 
numericParameter(long) - Static method in class io.prestosql.spi.type.TypeSignatureParameter
 
numFields - Variable in class io.prestosql.spi.block.AbstractRowBlock
 

O

of(double) - Static method in class io.prestosql.spi.statistics.Estimate
 
of(long) - Static method in class io.prestosql.spi.type.TypeParameter
 
of(long, int, int) - Static method in class io.prestosql.spi.type.SqlDecimal
 
of(NamedType) - Static method in class io.prestosql.spi.type.TypeParameter
 
of(Type) - Static method in class io.prestosql.spi.type.TypeParameter
 
of(Type, Object) - Static method in class io.prestosql.spi.predicate.NullableValue
 
of(Type, Object, Object...) - Static method in interface io.prestosql.spi.predicate.ValueSet
 
of(TypeSignatureParameter, TypeManager) - Static method in class io.prestosql.spi.type.TypeParameter
 
of(String) - Static method in class io.prestosql.spi.type.SqlDecimal
 
of(String) - Static method in class io.prestosql.spi.type.TypeId
 
of(String) - Static method in class io.prestosql.spi.type.TypeParameter
 
of(String, int, int) - Static method in class io.prestosql.spi.type.SqlDecimal
 
ofRanges(Range, Range...) - Static method in interface io.prestosql.spi.predicate.ValueSet
 
ofUser(String) - Static method in class io.prestosql.spi.security.ConnectorIdentity
 
ofUser(String) - Static method in class io.prestosql.spi.security.Identity
 
onlyNull(Type) - Static method in class io.prestosql.spi.predicate.Domain
 
operator() - Method in annotation type io.prestosql.spi.function.OperatorDependency
 
OPERATOR_NOT_FOUND - io.prestosql.spi.StandardErrorCode
 
OperatorDependency - Annotation Type in io.prestosql.spi.function
 
OperatorType - Enum in io.prestosql.spi.function
 
OPTIMIZER_TIMEOUT - io.prestosql.spi.StandardErrorCode
 
OUT_OF_SPILL_SPACE - io.prestosql.spi.StandardErrorCode
 
OutputFunction - Annotation Type in io.prestosql.spi.function
 
overflows(long, int) - Static method in class io.prestosql.spi.type.Decimals
 
overflows(Slice, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
overflows(BigDecimal, long) - Static method in class io.prestosql.spi.type.Decimals
 
overflows(BigInteger) - Static method in class io.prestosql.spi.type.Decimals
 
overflows(BigInteger, int) - Static method in class io.prestosql.spi.type.Decimals
 
overlaps(Domain) - Method in class io.prestosql.spi.predicate.Domain
 
overlaps(Range) - Method in class io.prestosql.spi.predicate.Range
 
overlaps(TupleDomain<T>) - Method in class io.prestosql.spi.predicate.TupleDomain
Returns true only if there exists a strict intersection between the TupleDomains.
overlaps(ValueSet) - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
overlaps(ValueSet) - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
overlaps(ValueSet) - Method in interface io.prestosql.spi.predicate.ValueSet
 

P

P4_HYPER_LOG_LOG - Static variable in class io.prestosql.spi.type.P4HyperLogLogType
 
P4_HYPER_LOG_LOG - Static variable in class io.prestosql.spi.type.StandardTypes
 
P4HyperLogLogType - Class in io.prestosql.spi.type
 
P4HyperLogLogType() - Constructor for class io.prestosql.spi.type.P4HyperLogLogType
 
pack(long, long, boolean) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
pack(long, long, boolean, long[], int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
pack(long, long, boolean, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
pack(long, long, boolean, Slice, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
pack(BigInteger, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
packDateTimeWithZone(long, int) - Static method in class io.prestosql.spi.type.DateTimeEncoding
 
packDateTimeWithZone(long, TimeZoneKey) - Static method in class io.prestosql.spi.type.DateTimeEncoding
 
packDateTimeWithZone(long, String) - Static method in class io.prestosql.spi.type.DateTimeEncoding
 
padSpaces(Slice, int) - Static method in class io.prestosql.spi.type.Chars
 
padSpaces(Slice, CharType) - Static method in class io.prestosql.spi.type.Chars
 
padSpaces(String, CharType) - Static method in class io.prestosql.spi.type.Chars
Pads String with spaces to given CharType's length in code points.
Page - Class in io.prestosql.spi
 
Page(int, Block...) - Constructor for class io.prestosql.spi.Page
 
Page(Block...) - Constructor for class io.prestosql.spi.Page
 
PAGE_TOO_LARGE - io.prestosql.spi.StandardErrorCode
 
PAGE_TRANSPORT_ERROR - io.prestosql.spi.StandardErrorCode
 
PAGE_TRANSPORT_TIMEOUT - io.prestosql.spi.StandardErrorCode
 
PageBuilder - Class in io.prestosql.spi
 
PageBuilder(int, List<? extends Type>) - Constructor for class io.prestosql.spi.PageBuilder
 
PageBuilder(List<? extends Type>) - Constructor for class io.prestosql.spi.PageBuilder
Create a PageBuilder with given types.
PageBuilderStatus - Class in io.prestosql.spi.block
 
PageBuilderStatus() - Constructor for class io.prestosql.spi.block.PageBuilderStatus
 
PageBuilderStatus(int) - Constructor for class io.prestosql.spi.block.PageBuilderStatus
 
PageIndexer - Interface in io.prestosql.spi
 
PageIndexerFactory - Interface in io.prestosql.spi
 
PageSorter - Interface in io.prestosql.spi
 
pageSource(ConnectorTransactionHandle, ConnectorSession, TupleDomain<Integer>) - Method in interface io.prestosql.spi.connector.SystemTable
Create a page source for the data in this table.
ParameterKind - Enum in io.prestosql.spi.type
 
parametricType(String, TypeSignature...) - Static method in class io.prestosql.spi.type.TypeSignature
 
ParametricType - Interface in io.prestosql.spi.type
 
parentGroupContext(SelectionContext<C>) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroupConfigurationManager
This method is called when parent group of the one specified by ResourceGroupConfigurationManager.match(SelectionCriteria)'s SelectionContext.getResourceGroupId() does not exist yet.
parse(String) - Static method in class io.prestosql.spi.type.Decimals
 
parseDottedId(String, int, String) - Static method in class io.prestosql.spi.QueryId
 
parseIncludeLeadingZerosInPrecision(String) - Static method in class io.prestosql.spi.type.Decimals
 
PasswordAuthenticator - Interface in io.prestosql.spi.security
 
PasswordAuthenticatorFactory - Interface in io.prestosql.spi.security
 
PEAK_MEMORY - Static variable in class io.prestosql.spi.session.ResourceEstimates
 
PERMISSION_DENIED - io.prestosql.spi.StandardErrorCode
 
Plugin - Interface in io.prestosql.spi
 
predicate() - Method in class io.prestosql.spi.connector.Constraint
 
prependColumn(Block) - Method in class io.prestosql.spi.Page
 
PrestoException - Exception in io.prestosql.spi
 
PrestoException(ErrorCodeSupplier, String) - Constructor for exception io.prestosql.spi.PrestoException
 
PrestoException(ErrorCodeSupplier, String, Throwable) - Constructor for exception io.prestosql.spi.PrestoException
 
PrestoException(ErrorCodeSupplier, Throwable) - Constructor for exception io.prestosql.spi.PrestoException
 
PrestoException(ErrorCodeSupplier, Optional<Location>, String, Throwable) - Constructor for exception io.prestosql.spi.PrestoException
 
PrestoPrincipal - Class in io.prestosql.spi.security
 
PrestoPrincipal(PrincipalType, String) - Constructor for class io.prestosql.spi.security.PrestoPrincipal
 
PrestoTransportException - Exception in io.prestosql.spi
 
PrestoTransportException(ErrorCodeSupplier, HostAddress, String) - Constructor for exception io.prestosql.spi.PrestoTransportException
 
PrestoTransportException(ErrorCodeSupplier, HostAddress, String, Throwable) - Constructor for exception io.prestosql.spi.PrestoTransportException
 
PrestoWarning - Class in io.prestosql.spi
 
PrestoWarning(WarningCode, String) - Constructor for class io.prestosql.spi.PrestoWarning
 
PrestoWarning(WarningCodeSupplier, String) - Constructor for class io.prestosql.spi.PrestoWarning
 
PrincipalType - Enum in io.prestosql.spi.security
 
Privilege - Enum in io.prestosql.spi.security
 
PrivilegeInfo - Class in io.prestosql.spi.security
 
PrivilegeInfo(Privilege, boolean) - Constructor for class io.prestosql.spi.security.PrivilegeInfo
 
Procedure - Class in io.prestosql.spi.procedure
 
Procedure(String, String, List<Procedure.Argument>, MethodHandle) - Constructor for class io.prestosql.spi.procedure.Procedure
 
PROCEDURE_CALL_FAILED - io.prestosql.spi.StandardErrorCode
 
PROCEDURE_NOT_FOUND - io.prestosql.spi.StandardErrorCode
 
Procedure.Argument - Class in io.prestosql.spi.procedure
 
processRow(BlockBuilder, boolean, int, int) - Method in class io.prestosql.spi.function.RankingWindowFunction
Process a row by outputting the result of the window function.
processRow(BlockBuilder, int, int, int) - Method in class io.prestosql.spi.function.ValueWindowFunction
Process a row by outputting the result of the window function.
processRow(BlockBuilder, int, int, int, int) - Method in class io.prestosql.spi.function.RankingWindowFunction
 
processRow(BlockBuilder, int, int, int, int) - Method in class io.prestosql.spi.function.ValueWindowFunction
 
processRow(BlockBuilder, int, int, int, int) - Method in interface io.prestosql.spi.function.WindowFunction
Process a row by outputting the result of the window function.
ProjectionApplicationResult<T> - Class in io.prestosql.spi.connector
 
ProjectionApplicationResult(T, List<ConnectorExpression>, List<Assignment>) - Constructor for class io.prestosql.spi.connector.ProjectionApplicationResult
 
PropertyMetadata<T> - Class in io.prestosql.spi.session
 
PropertyMetadata(String, String, Type, Class<T>, T, boolean, Function<Object, T>, Function<T, Object>) - Constructor for class io.prestosql.spi.session.PropertyMetadata
 

Q

QDIGEST - Static variable in class io.prestosql.spi.type.QuantileDigestParametricType
 
QDIGEST - Static variable in class io.prestosql.spi.type.StandardTypes
 
QuantileDigestParametricType - Class in io.prestosql.spi.type
 
QuantileDigestParametricType() - Constructor for class io.prestosql.spi.type.QuantileDigestParametricType
 
QuantileDigestType - Class in io.prestosql.spi.type
 
QuantileDigestType(Type) - Constructor for class io.prestosql.spi.type.QuantileDigestType
 
QUERY_HAS_TOO_MANY_STAGES - io.prestosql.spi.StandardErrorCode
 
QUERY_PRIORITY - io.prestosql.spi.resourcegroups.SchedulingPolicy
 
QUERY_QUEUE_FULL - io.prestosql.spi.StandardErrorCode
 
QUERY_REJECTED - io.prestosql.spi.StandardErrorCode
 
QUERY_TEXT_TOO_LARGE - io.prestosql.spi.StandardErrorCode
 
queryCompleted(QueryCompletedEvent) - Method in interface io.prestosql.spi.eventlistener.EventListener
 
QueryCompletedEvent - Class in io.prestosql.spi.eventlistener
 
QueryCompletedEvent(QueryMetadata, QueryStatistics, QueryContext, QueryIOMetadata, Optional<QueryFailureInfo>, List<PrestoWarning>, Instant, Instant, Instant) - Constructor for class io.prestosql.spi.eventlistener.QueryCompletedEvent
 
QueryContext - Class in io.prestosql.spi.eventlistener
 
QueryContext(String, Optional<String>, Optional<String>, Optional<String>, Optional<String>, Optional<String>, Set<String>, Set<String>, Optional<String>, Optional<String>, Optional<String>, Optional<ResourceGroupId>, Map<String, String>, ResourceEstimates, String, String, String) - Constructor for class io.prestosql.spi.eventlistener.QueryContext
 
queryCreated(QueryCreatedEvent) - Method in interface io.prestosql.spi.eventlistener.EventListener
 
QueryCreatedEvent - Class in io.prestosql.spi.eventlistener
 
QueryCreatedEvent(Instant, QueryContext, QueryMetadata) - Constructor for class io.prestosql.spi.eventlistener.QueryCreatedEvent
 
QueryFailureInfo - Class in io.prestosql.spi.eventlistener
 
QueryFailureInfo(ErrorCode, Optional<String>, Optional<String>, Optional<String>, Optional<String>, String) - Constructor for class io.prestosql.spi.eventlistener.QueryFailureInfo
 
QueryId - Class in io.prestosql.spi
 
QueryId(String) - Constructor for class io.prestosql.spi.QueryId
 
QueryInputMetadata - Class in io.prestosql.spi.eventlistener
 
QueryInputMetadata(String, String, String, List<String>, Optional<Object>) - Constructor for class io.prestosql.spi.eventlistener.QueryInputMetadata
 
QueryIOMetadata - Class in io.prestosql.spi.eventlistener
 
QueryIOMetadata(List<QueryInputMetadata>, Optional<QueryOutputMetadata>) - Constructor for class io.prestosql.spi.eventlistener.QueryIOMetadata
 
QueryMetadata - Class in io.prestosql.spi.eventlistener
 
QueryMetadata(String, Optional<String>, String, Optional<String>, Optional<String>, String, List<TableInfo>, List<RoutineInfo>, URI, Optional<String>, Optional<String>) - Constructor for class io.prestosql.spi.eventlistener.QueryMetadata
 
QueryOutputMetadata - Class in io.prestosql.spi.eventlistener
 
QueryOutputMetadata(String, String, String, Optional<String>, Optional<Boolean>) - Constructor for class io.prestosql.spi.eventlistener.QueryOutputMetadata
 
QueryStatistics - Class in io.prestosql.spi.eventlistener
 
QueryStatistics(Duration, Duration, Duration, Optional<Duration>, Optional<Duration>, Optional<Duration>, long, long, long, long, long, long, long, long, long, long, long, long, long, long, double, List<StageGcStatistics>, int, boolean, List<StageCpuDistribution>, List<String>, Optional<String>) - Constructor for class io.prestosql.spi.eventlistener.QueryStatistics
 
QueryType - Enum in io.prestosql.spi.resourcegroups
 

R

randomDictionaryId() - Static method in class io.prestosql.spi.block.DictionaryId
 
range(Type, Object, boolean, Object, boolean) - Static method in class io.prestosql.spi.predicate.Range
 
Range - Class in io.prestosql.spi.predicate
A Range of values across the continuous space defined by the types of the Markers
Range(Marker, Marker) - Constructor for class io.prestosql.spi.predicate.Range
 
Range(Object, Object) - Constructor for class io.prestosql.spi.type.Type.Range
 
Ranges - Interface in io.prestosql.spi.predicate
 
RankingWindowFunction - Class in io.prestosql.spi.function
 
RankingWindowFunction() - Constructor for class io.prestosql.spi.function.RankingWindowFunction
 
READ_COMMITTED - io.prestosql.spi.transaction.IsolationLevel
 
READ_ONLY_VIOLATION - io.prestosql.spi.StandardErrorCode
 
READ_UNCOMMITTED - io.prestosql.spi.transaction.IsolationLevel
 
readBigDecimal(DecimalType, Block, int) - Static method in class io.prestosql.spi.type.Decimals
 
readBlock(SliceInput) - Method in interface io.prestosql.spi.block.BlockEncodingSerde
Read a block encoding from the input.
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.ArrayBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in interface io.prestosql.spi.block.BlockEncoding
Read a block from the specified input.
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.ByteArrayBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.DictionaryBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.Int128ArrayBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.Int96ArrayBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.IntArrayBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.LazyBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.LongArrayBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.MapBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.RowBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.RunLengthBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.ShortArrayBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.SingleMapBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.SingleRowBlockEncoding
 
readBlock(BlockEncodingSerde, SliceInput) - Method in class io.prestosql.spi.block.VariableWidthBlockEncoding
 
readNativeValue(Type, Block, int) - Static method in class io.prestosql.spi.type.TypeUtils
Get the native value as an object in the value at position of block.
readType(TypeManager, SliceInput) - Static method in class io.prestosql.spi.type.TypeSerde
 
REAL - Static variable in class io.prestosql.spi.type.RealType
 
REAL - Static variable in class io.prestosql.spi.type.StandardTypes
 
realToLongDecimal(long, long, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
realToShortDecimal(long, long, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
RealType - Class in io.prestosql.spi.type
 
RecordCursor - Interface in io.prestosql.spi.connector
 
RecordPageSource - Class in io.prestosql.spi.connector
 
RecordPageSource(RecordSet) - Constructor for class io.prestosql.spi.connector.RecordPageSource
 
RecordPageSource(List<Type>, RecordCursor) - Constructor for class io.prestosql.spi.connector.RecordPageSource
 
RecordSet - Interface in io.prestosql.spi.connector
 
REDUNDANT_ORDER_BY - io.prestosql.spi.connector.StandardWarningCode
 
remainder(long, int, long, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
remainder(long, int, Slice, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
remainder(Slice, int, long, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
remainder(Slice, int, Slice, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
REMOTE_BUFFER_CLOSE_FAILED - io.prestosql.spi.StandardErrorCode
 
REMOTE_HOST_GONE - io.prestosql.spi.StandardErrorCode
 
REMOTE_TASK_ERROR - io.prestosql.spi.StandardErrorCode
 
REMOTE_TASK_MISMATCH - io.prestosql.spi.StandardErrorCode
 
RemoveInputFunction - Annotation Type in io.prestosql.spi.function
 
renameColumn(ConnectorSession, ConnectorTableHandle, ColumnHandle, String) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Rename the specified column
renameSchema(ConnectorSession, String, String) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Renames the specified schema.
renameTable(ConnectorSession, ConnectorTableHandle, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Rename the specified table
renameView(ConnectorSession, SchemaTableName, SchemaTableName) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Rename the specified view
REPEATABLE_READ - io.prestosql.spi.transaction.IsolationLevel
 
replacementBlockForWrite(Block) - Method in interface io.prestosql.spi.block.BlockEncoding
This method allows the implementor to specify a replacement object that will be serialized instead of the original one.
replacementBlockForWrite(Block) - Method in class io.prestosql.spi.block.LazyBlockEncoding
 
rescale(long, int, int) - Static method in class io.prestosql.spi.type.Decimals
 
rescale(Slice, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
rescale(Slice, int, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
rescale(BigDecimal, DecimalType) - Static method in class io.prestosql.spi.type.Decimals
 
rescale(BigInteger, int, int) - Static method in class io.prestosql.spi.type.Decimals
 
rescaleTruncate(Slice, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
rescaleTruncate(Slice, int, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
reset() - Method in class io.prestosql.spi.function.RankingWindowFunction
Reset state for a new partition (including the first one).
reset() - Method in class io.prestosql.spi.function.ValueWindowFunction
Reset state for a new partition (including the first one).
reset() - Method in class io.prestosql.spi.PageBuilder
 
reset(WindowIndex) - Method in class io.prestosql.spi.function.RankingWindowFunction
 
reset(WindowIndex) - Method in class io.prestosql.spi.function.ValueWindowFunction
 
reset(WindowIndex) - Method in interface io.prestosql.spi.function.WindowFunction
Reset state for a new partition (including the first one).
resolveIndex(ConnectorSession, ConnectorTableHandle, Set<ColumnHandle>, Set<ColumnHandle>, TupleDomain<ColumnHandle>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Try to locate a table index that can lookup results by indexableColumns and provide the requested outputColumns.
resolveOperator(OperatorType, List<? extends Type>) - Method in interface io.prestosql.spi.type.TypeManager
 
ResourceEstimates - Class in io.prestosql.spi.session
Estimated resource usage for a query.
ResourceEstimates(Optional<Duration>, Optional<Duration>, Optional<Long>) - Constructor for class io.prestosql.spi.session.ResourceEstimates
 
ResourceGroup - Interface in io.prestosql.spi.resourcegroups
 
ResourceGroupConfigurationManager<C> - Interface in io.prestosql.spi.resourcegroups
The engine calls the ResourceGroupConfigurationManager.match(SelectionCriteria) method whenever a query is submitted, and receives a SelectionContext in return which contains a fully-qualified ResourceGroupId, and a manager-specific data structure of type C.
ResourceGroupConfigurationManagerContext - Interface in io.prestosql.spi.resourcegroups
 
ResourceGroupConfigurationManagerFactory - Interface in io.prestosql.spi.resourcegroups
 
ResourceGroupId - Class in io.prestosql.spi.resourcegroups
 
ResourceGroupId(ResourceGroupId, String) - Constructor for class io.prestosql.spi.resourcegroups.ResourceGroupId
 
ResourceGroupId(String) - Constructor for class io.prestosql.spi.resourcegroups.ResourceGroupId
 
ResourceGroupId(List<String>) - Constructor for class io.prestosql.spi.resourcegroups.ResourceGroupId
 
ResourceGroupState - Enum in io.prestosql.spi.resourcegroups
 
result() - Method in annotation type io.prestosql.spi.function.Convention
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.ArrayBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in interface io.prestosql.spi.block.Block
consumer visits each of the internal data container and accepts the size for it.
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.DictionaryBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.IntArrayBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.LazyBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.LongArrayBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.MapBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.MapBlockBuilder
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.RowBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.RowBlockBuilder
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.SingleMapBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.SingleRowBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.VariableWidthBlock
 
retainedBytesForEachPart(BiConsumer<Object, Long>) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
returnType() - Method in annotation type io.prestosql.spi.function.WindowFunctionSignature
 
revokeRoles(ConnectorSession, Set<String>, Set<PrestoPrincipal>, boolean, Optional<PrestoPrincipal>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Revokes the specified roles from the specified grantees
revokeTablePrivileges(ConnectorSession, SchemaTableName, Set<Privilege>, PrestoPrincipal, boolean) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Revokes the specified privilege on the specified table from the specified user
ROLE - io.prestosql.spi.security.PrincipalType
 
ROLE - io.prestosql.spi.security.SelectedRole.Type
 
ROLE_ALREADY_EXISTS - io.prestosql.spi.StandardErrorCode
 
ROLE_NOT_FOUND - io.prestosql.spi.StandardErrorCode
 
RoleGrant - Class in io.prestosql.spi.security
 
RoleGrant(PrestoPrincipal, String, boolean) - Constructor for class io.prestosql.spi.security.RoleGrant
 
rollback(ConnectorTransactionHandle) - Method in interface io.prestosql.spi.connector.Connector
Rollback the transaction.
roundTo(int) - Method in class io.prestosql.spi.type.SqlTimestamp
 
RoutineInfo - Class in io.prestosql.spi.eventlistener
 
RoutineInfo(String, String) - Constructor for class io.prestosql.spi.eventlistener.RoutineInfo
 
ROW - Static variable in class io.prestosql.spi.type.StandardTypes
 
ROW_COUNT - io.prestosql.spi.statistics.TableStatisticType
 
RowBlock - Class in io.prestosql.spi.block
 
RowBlockBuilder - Class in io.prestosql.spi.block
 
RowBlockBuilder(List<Type>, BlockBuilderStatus, int) - Constructor for class io.prestosql.spi.block.RowBlockBuilder
 
RowBlockEncoding - Class in io.prestosql.spi.block
 
RowBlockEncoding() - Constructor for class io.prestosql.spi.block.RowBlockEncoding
 
RowFieldName - Class in io.prestosql.spi.type
 
RowFieldName(String) - Constructor for class io.prestosql.spi.type.RowFieldName
 
rowIndex - Variable in class io.prestosql.spi.block.AbstractSingleRowBlock
 
rowType(RowType.Field...) - Static method in class io.prestosql.spi.type.RowType
 
rowType(TypeSignatureParameter...) - Static method in class io.prestosql.spi.type.TypeSignature
 
rowType(List<TypeSignatureParameter>) - Static method in class io.prestosql.spi.type.TypeSignature
 
RowType - Class in io.prestosql.spi.type
As defined in ISO/IEC FCD 9075-2 (SQL 2011), section 4.8
RowType.Field - Class in io.prestosql.spi.type
 
RunLengthBlockEncoding - Class in io.prestosql.spi.block
 
RunLengthBlockEncoding() - Constructor for class io.prestosql.spi.block.RunLengthBlockEncoding
 
RunLengthEncodedBlock - Class in io.prestosql.spi.block
 
RunLengthEncodedBlock(Block, int) - Constructor for class io.prestosql.spi.block.RunLengthEncodedBlock
 

S

SampleType - Enum in io.prestosql.spi.connector
 
SATURATED_FLOOR_CAST - io.prestosql.spi.function.OperatorType
 
ScalarFunction - Annotation Type in io.prestosql.spi.function
 
ScalarOperator - Annotation Type in io.prestosql.spi.function
 
SchedulingPolicy - Enum in io.prestosql.spi.resourcegroups
 
SCHEMA_ALREADY_EXISTS - io.prestosql.spi.StandardErrorCode
 
SCHEMA_NOT_EMPTY - io.prestosql.spi.StandardErrorCode
 
SCHEMA_NOT_FOUND - io.prestosql.spi.StandardErrorCode
 
schemaExists(ConnectorSession, String) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Checks if a schema exists.
SchemaNotFoundException - Exception in io.prestosql.spi.connector
 
SchemaNotFoundException(String) - Constructor for exception io.prestosql.spi.connector.SchemaNotFoundException
 
SchemaNotFoundException(String, String) - Constructor for exception io.prestosql.spi.connector.SchemaNotFoundException
 
SchemaNotFoundException(String, String, Throwable) - Constructor for exception io.prestosql.spi.connector.SchemaNotFoundException
 
SchemaNotFoundException(String, Throwable) - Constructor for exception io.prestosql.spi.connector.SchemaNotFoundException
 
SchemaRoutineName - Class in io.prestosql.spi.connector
 
SchemaRoutineName(String, String) - Constructor for class io.prestosql.spi.connector.SchemaRoutineName
 
SchemaTableName - Class in io.prestosql.spi.connector
 
SchemaTableName(String, String) - Constructor for class io.prestosql.spi.connector.SchemaTableName
 
SchemaTablePrefix - Class in io.prestosql.spi.connector
 
SchemaTablePrefix() - Constructor for class io.prestosql.spi.connector.SchemaTablePrefix
 
SchemaTablePrefix(String) - Constructor for class io.prestosql.spi.connector.SchemaTablePrefix
 
SchemaTablePrefix(String, String) - Constructor for class io.prestosql.spi.connector.SchemaTablePrefix
 
seekKey(Object) - Method in class io.prestosql.spi.block.SingleMapBlock
 
seekKeyExact(boolean) - Method in class io.prestosql.spi.block.SingleMapBlock
 
seekKeyExact(double) - Method in class io.prestosql.spi.block.SingleMapBlock
 
seekKeyExact(long) - Method in class io.prestosql.spi.block.SingleMapBlock
 
seekKeyExact(Slice) - Method in class io.prestosql.spi.block.SingleMapBlock
 
seekKeyExact(Block) - Method in class io.prestosql.spi.block.SingleMapBlock
 
SELECT - io.prestosql.spi.resourcegroups.QueryType
 
SELECT - io.prestosql.spi.security.Privilege
 
SelectedRole - Class in io.prestosql.spi.security
 
SelectedRole(SelectedRole.Type, Optional<String>) - Constructor for class io.prestosql.spi.security.SelectedRole
 
SelectedRole.Type - Enum in io.prestosql.spi.security
 
SelectionContext<T> - Class in io.prestosql.spi.resourcegroups
 
SelectionContext(ResourceGroupId, T) - Constructor for class io.prestosql.spi.resourcegroups.SelectionContext
 
SelectionCriteria - Class in io.prestosql.spi.resourcegroups
 
SelectionCriteria(boolean, String, Set<String>, Optional<String>, Set<String>, ResourceEstimates, Optional<String>) - Constructor for class io.prestosql.spi.resourcegroups.SelectionCriteria
 
Serializable(Type, Block) - Constructor for class io.prestosql.spi.predicate.NullableValue.Serializable
 
SERIALIZABLE - io.prestosql.spi.transaction.IsolationLevel
 
serialize(T, BlockBuilder) - Method in interface io.prestosql.spi.function.AccumulatorStateSerializer
 
SERVER_SHUTTING_DOWN - io.prestosql.spi.StandardErrorCode
 
SERVER_STARTING_UP - io.prestosql.spi.StandardErrorCode
 
session() - Method in annotation type io.prestosql.spi.function.Convention
 
SessionConfigurationContext - Class in io.prestosql.spi.session
 
SessionConfigurationContext(String, Optional<String>, Set<String>, Optional<String>, ResourceGroupId) - Constructor for class io.prestosql.spi.session.SessionConfigurationContext
 
SessionPropertyConfigurationManager - Interface in io.prestosql.spi.session
This interface is used to provide default session property overrides for sessions, thus providing a way to dynamically configure default session properties according to request's user, source, or other characteristics identified by client tags.
SessionPropertyConfigurationManagerContext - Interface in io.prestosql.spi.resourcegroups
 
SessionPropertyConfigurationManagerFactory - Interface in io.prestosql.spi.session
 
setColumnStatistics(ColumnHandle, ColumnStatistics) - Method in class io.prestosql.spi.statistics.TableStatistics.Builder
 
setComment(Optional<String>) - Method in class io.prestosql.spi.connector.ColumnMetadata.Builder
 
setCpuQuotaGenerationMillisPerSecond(long) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
Rate at which distributed CPU usage quota regenerates.
setDataSize(Estimate) - Method in class io.prestosql.spi.statistics.ColumnStatistics.Builder
 
setDistinctValuesCount(Estimate) - Method in class io.prestosql.spi.statistics.ColumnStatistics.Builder
 
setExtraInfo(Optional<String>) - Method in class io.prestosql.spi.connector.ColumnMetadata.Builder
 
setGroupId(long) - Method in interface io.prestosql.spi.function.GroupedAccumulatorState
 
setHardConcurrencyLimit(int) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
Maximum number of concurrently running queries, after which new queries will queue instead of starting.
setHardCpuLimit(Duration) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
Threshold on total distributed CPU usage after which new queries will queue instead of starting.
setHidden(boolean) - Method in class io.prestosql.spi.connector.ColumnMetadata.Builder
 
setJmxExport(boolean) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
Whether to export statistics about this group and allow configuration via JMX.
setMaxQueuedQueries(int) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
Maximum number of queued queries after which submitted queries will be rejected.
setName(String) - Method in class io.prestosql.spi.connector.ColumnMetadata.Builder
 
setNullable(boolean) - Method in class io.prestosql.spi.connector.ColumnMetadata.Builder
 
setNullsFraction(Estimate) - Method in class io.prestosql.spi.statistics.ColumnStatistics.Builder
 
setProperties(Map<String, Object>) - Method in class io.prestosql.spi.connector.ColumnMetadata.Builder
 
setRange(DoubleRange) - Method in class io.prestosql.spi.statistics.ColumnStatistics.Builder
 
setRange(Optional<DoubleRange>) - Method in class io.prestosql.spi.statistics.ColumnStatistics.Builder
 
setRowCount(Estimate) - Method in class io.prestosql.spi.statistics.TableStatistics.Builder
 
setSchedulingPolicy(SchedulingPolicy) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
Scheduling policy to use when dividing resources among child resource groups, or among queries submitted to this group.
setSchedulingWeight(int) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
Scheduling weight of this group in its parent group.
setSchemaAuthorization(ConnectorSession, String, PrestoPrincipal) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Sets the user/role on the specified schema.
setSoftConcurrencyLimit(int) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
Number of concurrently running queries after which new queries will only run if all peer resource groups below their soft limits are ineligible or if all eligible peers are above soft limits.
setSoftCpuLimit(Duration) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
Threshold on total distributed CPU usage after which max running queries will be reduced.
setSoftMemoryLimitBytes(long) - Method in interface io.prestosql.spi.resourcegroups.ResourceGroup
Threshold on total distributed memory usage after which new queries will queue instead of starting.
setTableComment(ConnectorSession, ConnectorTableHandle, Optional<String>) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Comments to the specified table
setType(Type) - Method in class io.prestosql.spi.connector.ColumnMetadata.Builder
 
shiftRightArray8(int[], int, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
shift right array of 8 ints (rounding up) and ensure that result fits in unscaledDecimal
ShortArrayBlock - Class in io.prestosql.spi.block
 
ShortArrayBlock(int, Optional<boolean[]>, short[]) - Constructor for class io.prestosql.spi.block.ShortArrayBlock
 
ShortArrayBlockBuilder - Class in io.prestosql.spi.block
 
ShortArrayBlockBuilder(BlockBuilderStatus, int) - Constructor for class io.prestosql.spi.block.ShortArrayBlockBuilder
 
ShortArrayBlockEncoding - Class in io.prestosql.spi.block
 
ShortArrayBlockEncoding() - Constructor for class io.prestosql.spi.block.ShortArrayBlockEncoding
 
shortDecimalToDouble(long, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
shortDecimalToReal(long, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
ShortTimestampType - Class in io.prestosql.spi.type
Encodes timestamps up to p = 6.
ShortTimestampType(int) - Constructor for class io.prestosql.spi.type.ShortTimestampType
 
shortToLongCast(long, long, long, long, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
shortToShortCast(long, long, long, long, long, long, long) - Static method in class io.prestosql.spi.type.DecimalConversions
 
shutdown() - Method in interface io.prestosql.spi.connector.Connector
Shutdown the connector by releasing any held resources such as threads, sockets, etc.
simplify() - Method in class io.prestosql.spi.predicate.Domain
Reduces the number of discrete components in the Domain if there are too many.
simplify() - Method in class io.prestosql.spi.predicate.TupleDomain
 
simplify(int) - Method in class io.prestosql.spi.predicate.Domain
 
simplify(int) - Method in class io.prestosql.spi.predicate.TupleDomain
 
SINGLE_COORDINATOR - io.prestosql.spi.connector.SystemTable.Distribution
 
SingleArrayBlockWriter - Class in io.prestosql.spi.block
 
SingleArrayBlockWriter(BlockBuilder, int) - Constructor for class io.prestosql.spi.block.SingleArrayBlockWriter
 
SingleMapBlock - Class in io.prestosql.spi.block
 
SingleMapBlockEncoding - Class in io.prestosql.spi.block
 
SingleMapBlockEncoding(TypeManager) - Constructor for class io.prestosql.spi.block.SingleMapBlockEncoding
 
SingleMapBlockWriter - Class in io.prestosql.spi.block
 
SingleRowBlock - Class in io.prestosql.spi.block
 
SingleRowBlockEncoding - Class in io.prestosql.spi.block
 
SingleRowBlockEncoding() - Constructor for class io.prestosql.spi.block.SingleRowBlockEncoding
 
SingleRowBlockWriter - Class in io.prestosql.spi.block
 
singleValue(Type, Object) - Static method in class io.prestosql.spi.predicate.Domain
 
size() - Method in interface io.prestosql.spi.function.WindowIndex
Gets the number of rows in the partition
SMALLINT - Static variable in class io.prestosql.spi.type.SmallintType
 
SMALLINT - Static variable in class io.prestosql.spi.type.StandardTypes
 
SmallintType - Class in io.prestosql.spi.type
 
sort(List<Type>, List<Page>, List<Integer>, List<SortOrder>, int) - Method in interface io.prestosql.spi.PageSorter
Deprecated.
SortedRangeSet - Class in io.prestosql.spi.predicate
A set containing zero or more Ranges of the same type over a continuous space of possible values.
SortingProperty<E> - Class in io.prestosql.spi.connector
 
SortingProperty(E, SortOrder) - Constructor for class io.prestosql.spi.connector.SortingProperty
 
SortItem - Class in io.prestosql.spi.connector
 
SortItem(String, SortOrder) - Constructor for class io.prestosql.spi.connector.SortItem
 
SortOrder - Enum in io.prestosql.spi.block
 
SortOrder - Enum in io.prestosql.spi.connector
 
span(Range) - Method in class io.prestosql.spi.predicate.Range
 
splitCompleted(SplitCompletedEvent) - Method in interface io.prestosql.spi.eventlistener.EventListener
 
SplitCompletedEvent - Class in io.prestosql.spi.eventlistener
 
SplitCompletedEvent(String, String, String, Instant, Optional<Instant>, Optional<Instant>, SplitStatistics, Optional<SplitFailureInfo>, String) - Constructor for class io.prestosql.spi.eventlistener.SplitCompletedEvent
 
SplitFailureInfo - Class in io.prestosql.spi.eventlistener
 
SplitFailureInfo(String, String) - Constructor for class io.prestosql.spi.eventlistener.SplitFailureInfo
 
SplitStatistics - Class in io.prestosql.spi.eventlistener
 
SplitStatistics(Duration, Duration, Duration, Duration, long, long, Optional<Duration>, Optional<Duration>) - Constructor for class io.prestosql.spi.eventlistener.SplitStatistics
 
SqlDate - Class in io.prestosql.spi.type
 
SqlDate(int) - Constructor for class io.prestosql.spi.type.SqlDate
 
SqlDecimal - Class in io.prestosql.spi.type
 
SqlDecimal(BigInteger, int, int) - Constructor for class io.prestosql.spi.type.SqlDecimal
 
SqlNullable - Annotation Type in io.prestosql.spi.function
 
SqlTime - Class in io.prestosql.spi.type
 
SqlTime(long) - Constructor for class io.prestosql.spi.type.SqlTime
 
SqlTime(long, TimeZoneKey) - Constructor for class io.prestosql.spi.type.SqlTime
Deprecated.
SqlTimestamp - Class in io.prestosql.spi.type
 
SqlTimestampWithTimeZone - Class in io.prestosql.spi.type
 
SqlTimestampWithTimeZone(long) - Constructor for class io.prestosql.spi.type.SqlTimestampWithTimeZone
 
SqlTimestampWithTimeZone(long, TimeZoneKey) - Constructor for class io.prestosql.spi.type.SqlTimestampWithTimeZone
 
SqlTimestampWithTimeZone(long, TimeZone) - Constructor for class io.prestosql.spi.type.SqlTimestampWithTimeZone
 
SqlTimeWithTimeZone - Class in io.prestosql.spi.type
 
SqlTimeWithTimeZone(long) - Constructor for class io.prestosql.spi.type.SqlTimeWithTimeZone
 
SqlTimeWithTimeZone(long, TimeZoneKey) - Constructor for class io.prestosql.spi.type.SqlTimeWithTimeZone
 
SqlTimeWithTimeZone(long, TimeZone) - Constructor for class io.prestosql.spi.type.SqlTimeWithTimeZone
Deprecated.
SqlType - Annotation Type in io.prestosql.spi.function
 
SqlVarbinary - Class in io.prestosql.spi.type
 
SqlVarbinary(byte[]) - Constructor for class io.prestosql.spi.type.SqlVarbinary
 
StageCpuDistribution - Class in io.prestosql.spi.eventlistener
 
StageCpuDistribution(int, int, long, long, long, long, long, long, long, long, long, double) - Constructor for class io.prestosql.spi.eventlistener.StageCpuDistribution
 
StageGcStatistics - Class in io.prestosql.spi.eventlistener
 
StageGcStatistics(int, int, int, int, int, int, int) - Constructor for class io.prestosql.spi.eventlistener.StageGcStatistics
 
StandardErrorCode - Enum in io.prestosql.spi
 
StandardTypes - Class in io.prestosql.spi.type
 
StandardWarningCode - Enum in io.prestosql.spi.connector
 
start - Variable in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
stateFactoryClass() - Method in annotation type io.prestosql.spi.function.AccumulatorStateMetadata
 
stateSerializerClass() - Method in annotation type io.prestosql.spi.function.AccumulatorStateMetadata
 
stringProperty(String, String, String, boolean) - Static method in class io.prestosql.spi.session.PropertyMetadata
 
SUBQUERY_MULTIPLE_ROWS - io.prestosql.spi.StandardErrorCode
 
SUBSCRIPT - io.prestosql.spi.function.OperatorType
 
subtract(Slice, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
subtract(Slice, Slice, Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
subtract(Domain) - Method in class io.prestosql.spi.predicate.Domain
 
subtract(ValueSet) - Method in interface io.prestosql.spi.predicate.ValueSet
 
SUBTRACT - io.prestosql.spi.function.OperatorType
 
supportsInstanceFactor() - Method in class io.prestosql.spi.function.InvocationConvention
 
supportsMetadataDelete(ConnectorSession, ConnectorTableHandle, ConnectorTableLayoutHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
 
supportsMissingColumnsOnInsert() - Method in interface io.prestosql.spi.connector.ConnectorMetadata
 
supportsSession() - Method in class io.prestosql.spi.function.InvocationConvention
 
SYNTAX_ERROR - io.prestosql.spi.StandardErrorCode
 
SYSTEM - io.prestosql.spi.connector.SampleType
 
SystemAccessControl - Interface in io.prestosql.spi.security
 
SystemAccessControlFactory - Interface in io.prestosql.spi.security
 
SystemSecurityContext - Class in io.prestosql.spi.security
 
SystemSecurityContext(Identity, Optional<QueryId>) - Constructor for class io.prestosql.spi.security.SystemSecurityContext
 
SystemTable - Interface in io.prestosql.spi.connector
SystemTable.Distribution - Enum in io.prestosql.spi.connector
 

T

TABLE_ALREADY_EXISTS - io.prestosql.spi.StandardErrorCode
 
TABLE_NOT_FOUND - io.prestosql.spi.StandardErrorCode
 
TableInfo - Class in io.prestosql.spi.eventlistener
 
TableInfo(String, String, String, String, List<String>, List<ColumnInfo>) - Constructor for class io.prestosql.spi.eventlistener.TableInfo
 
TableNotFoundException - Exception in io.prestosql.spi.connector
 
TableNotFoundException(SchemaTableName) - Constructor for exception io.prestosql.spi.connector.TableNotFoundException
 
TableNotFoundException(SchemaTableName, String) - Constructor for exception io.prestosql.spi.connector.TableNotFoundException
 
TableNotFoundException(SchemaTableName, String, Throwable) - Constructor for exception io.prestosql.spi.connector.TableNotFoundException
 
TableNotFoundException(SchemaTableName, Throwable) - Constructor for exception io.prestosql.spi.connector.TableNotFoundException
 
TableStatistics - Class in io.prestosql.spi.statistics
 
TableStatistics(Estimate, Map<ColumnHandle, ColumnStatistics>) - Constructor for class io.prestosql.spi.statistics.TableStatistics
 
TableStatistics.Builder - Class in io.prestosql.spi.statistics
 
TableStatisticsMetadata - Class in io.prestosql.spi.statistics
 
TableStatisticsMetadata(Set<ColumnStatisticMetadata>, Set<TableStatisticType>, List<String>) - Constructor for class io.prestosql.spi.statistics.TableStatisticsMetadata
 
TableStatisticType - Enum in io.prestosql.spi.statistics
 
ThreadContextClassLoader - Class in io.prestosql.spi.classloader
 
ThreadContextClassLoader(ClassLoader) - Constructor for class io.prestosql.spi.classloader.ThreadContextClassLoader
 
throwIfOverflows(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
throwIfOverflows(Slice, int) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
throwOverflowException() - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
TIME - Static variable in class io.prestosql.spi.type.StandardTypes
 
TIME - Static variable in class io.prestosql.spi.type.TimeType
 
TIME_WITH_TIME_ZONE - Static variable in class io.prestosql.spi.type.StandardTypes
 
TIME_WITH_TIME_ZONE - Static variable in class io.prestosql.spi.type.TimeWithTimeZoneType
 
TIMESTAMP - Static variable in class io.prestosql.spi.type.StandardTypes
 
TIMESTAMP - Static variable in class io.prestosql.spi.type.TimestampParametricType
 
TIMESTAMP - Static variable in class io.prestosql.spi.type.TimestampType
Deprecated.
TIMESTAMP_WITH_TIME_ZONE - Static variable in class io.prestosql.spi.type.StandardTypes
 
TIMESTAMP_WITH_TIME_ZONE - Static variable in class io.prestosql.spi.type.TimestampWithTimeZoneType
 
TimestampParametricType - Class in io.prestosql.spi.type
 
TimestampParametricType() - Constructor for class io.prestosql.spi.type.TimestampParametricType
 
TimestampType - Class in io.prestosql.spi.type
A timestamp is stored as milliseconds from 1970-01-01T00:00:00 UTC and is to be interpreted as date-time in UTC.
TimestampType(int, Class<?>) - Constructor for class io.prestosql.spi.type.TimestampType
 
TimestampWithTimeZoneType - Class in io.prestosql.spi.type
 
TimeType - Class in io.prestosql.spi.type
 
TimeWithTimeZoneType - Class in io.prestosql.spi.type
 
TimeZoneKey - Class in io.prestosql.spi.type
 
TimeZoneNotSupportedException - Exception in io.prestosql.spi.type
 
TimeZoneNotSupportedException(String) - Constructor for exception io.prestosql.spi.type.TimeZoneNotSupportedException
 
TINYINT - Static variable in class io.prestosql.spi.type.StandardTypes
 
TINYINT - Static variable in class io.prestosql.spi.type.TinyintType
 
TinyintType - Class in io.prestosql.spi.type
 
toBigDecimal() - Method in class io.prestosql.spi.type.SqlDecimal
 
toColumnarArray(Block) - Static method in class io.prestosql.spi.block.ColumnarArray
 
toColumnarMap(Block) - Static method in class io.prestosql.spi.block.ColumnarMap
 
toColumnarRow(Block) - Static method in class io.prestosql.spi.block.ColumnarRow
 
toConnectorIdentity() - Method in class io.prestosql.spi.security.Identity
 
toConnectorIdentity(String) - Method in class io.prestosql.spi.security.Identity
 
toErrorCode() - Method in interface io.prestosql.spi.ErrorCodeSupplier
 
toErrorCode() - Method in enum io.prestosql.spi.StandardErrorCode
 
toInetAddress() - Method in class io.prestosql.spi.HostAddress
 
TOO_MANY_ARGUMENTS - io.prestosql.spi.StandardErrorCode
 
TOO_MANY_GROUPING_SETS - io.prestosql.spi.StandardErrorCode
 
TOO_MANY_REQUESTS_FAILED - io.prestosql.spi.StandardErrorCode
 
TOO_MANY_STAGES - io.prestosql.spi.connector.StandardWarningCode
 
toOptionalSchemaTableName() - Method in class io.prestosql.spi.connector.SchemaTablePrefix
 
toSchemaTableName() - Method in class io.prestosql.spi.connector.SchemaTablePrefix
 
toSchemaTablePrefix() - Method in class io.prestosql.spi.connector.SchemaTableName
 
toString() - Method in class io.prestosql.spi.block.ArrayBlock
 
toString() - Method in class io.prestosql.spi.block.ArrayBlockBuilder
 
toString() - Method in class io.prestosql.spi.block.BlockBuilderStatus
 
toString() - Method in class io.prestosql.spi.block.ByteArrayBlock
 
toString() - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
toString() - Method in class io.prestosql.spi.block.DictionaryBlock
 
toString() - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
toString() - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
toString() - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
toString() - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
toString() - Method in class io.prestosql.spi.block.IntArrayBlock
 
toString() - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
toString() - Method in class io.prestosql.spi.block.LongArrayBlock
 
toString() - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
toString() - Method in class io.prestosql.spi.block.MapBlock
 
toString() - Method in class io.prestosql.spi.block.MapBlockBuilder
 
toString() - Method in class io.prestosql.spi.block.PageBuilderStatus
 
toString() - Method in class io.prestosql.spi.block.RowBlock
 
toString() - Method in class io.prestosql.spi.block.RowBlockBuilder
 
toString() - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
toString() - Method in class io.prestosql.spi.block.ShortArrayBlock
 
toString() - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
toString() - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
toString() - Method in class io.prestosql.spi.block.SingleMapBlock
 
toString() - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
toString() - Method in class io.prestosql.spi.block.SingleRowBlock
 
toString() - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
toString() - Method in class io.prestosql.spi.block.VariableWidthBlock
 
toString() - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
toString() - Method in class io.prestosql.spi.connector.AggregateFunction
 
toString() - Method in class io.prestosql.spi.connector.CatalogSchemaName
 
toString() - Method in class io.prestosql.spi.connector.CatalogSchemaRoutineName
 
toString() - Method in class io.prestosql.spi.connector.CatalogSchemaTableName
 
toString() - Method in class io.prestosql.spi.connector.ColumnMetadata
 
toString() - Method in class io.prestosql.spi.connector.ConnectorTableMetadata
 
toString() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition
 
toString() - Method in class io.prestosql.spi.connector.ConnectorViewDefinition.ViewColumn
 
toString() - Method in class io.prestosql.spi.connector.ConstantProperty
 
toString() - Method in class io.prestosql.spi.connector.GroupingProperty
 
toString() - Method in class io.prestosql.spi.connector.SchemaRoutineName
 
toString() - Method in class io.prestosql.spi.connector.SchemaTableName
 
toString() - Method in class io.prestosql.spi.connector.SchemaTablePrefix
 
toString() - Method in class io.prestosql.spi.connector.SortingProperty
 
toString() - Method in class io.prestosql.spi.ErrorCode
 
toString() - Method in class io.prestosql.spi.expression.ConnectorExpression
 
toString() - Method in class io.prestosql.spi.expression.Constant
 
toString() - Method in class io.prestosql.spi.expression.FieldDereference
 
toString() - Method in class io.prestosql.spi.expression.Variable
 
toString() - Method in class io.prestosql.spi.function.InvocationConvention
 
toString() - Method in class io.prestosql.spi.HostAddress
Rebuild the host:port string, including brackets if necessary.
toString() - Method in class io.prestosql.spi.Location
 
toString() - Method in class io.prestosql.spi.memory.MemoryPoolId
 
toString() - Method in class io.prestosql.spi.memory.MemoryPoolInfo
 
toString() - Method in class io.prestosql.spi.Page
 
toString() - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
toString() - Method in class io.prestosql.spi.predicate.Domain
 
toString() - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
toString() - Method in class io.prestosql.spi.predicate.Marker
 
toString() - Method in class io.prestosql.spi.predicate.NullableValue
 
toString() - Method in class io.prestosql.spi.predicate.Range
 
toString() - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
toString() - Method in class io.prestosql.spi.predicate.TupleDomain
 
toString() - Method in interface io.prestosql.spi.predicate.ValueSet
 
toString() - Method in class io.prestosql.spi.PrestoWarning
 
toString() - Method in class io.prestosql.spi.procedure.Procedure.Argument
 
toString() - Method in class io.prestosql.spi.procedure.Procedure
 
toString() - Method in class io.prestosql.spi.QueryId
 
toString() - Method in class io.prestosql.spi.resourcegroups.ResourceGroupId
 
toString() - Method in class io.prestosql.spi.resourcegroups.SelectionCriteria
 
toString() - Method in class io.prestosql.spi.security.BasicPrincipal
 
toString() - Method in class io.prestosql.spi.security.ConnectorIdentity
 
toString() - Method in class io.prestosql.spi.security.Identity
 
toString() - Method in class io.prestosql.spi.security.PrestoPrincipal
 
toString() - Method in class io.prestosql.spi.security.RoleGrant
 
toString() - Method in class io.prestosql.spi.security.SelectedRole
 
toString() - Method in class io.prestosql.spi.session.ResourceEstimates
 
toString() - Method in class io.prestosql.spi.statistics.ColumnStatisticMetadata
 
toString() - Method in class io.prestosql.spi.statistics.ColumnStatistics
 
toString() - Method in class io.prestosql.spi.statistics.DoubleRange
 
toString() - Method in class io.prestosql.spi.statistics.Estimate
 
toString() - Method in class io.prestosql.spi.statistics.TableStatistics
 
toString() - Method in enum io.prestosql.spi.transaction.IsolationLevel
 
toString() - Method in class io.prestosql.spi.type.AbstractType
 
toString() - Method in class io.prestosql.spi.type.CharType
 
toString() - Method in class io.prestosql.spi.type.DecimalParseResult
 
toString() - Method in class io.prestosql.spi.type.NamedTypeSignature
 
toString() - Method in class io.prestosql.spi.type.RowFieldName
 
toString() - Method in class io.prestosql.spi.type.SqlDate
 
toString() - Method in class io.prestosql.spi.type.SqlDecimal
 
toString() - Method in class io.prestosql.spi.type.SqlTime
 
toString() - Method in class io.prestosql.spi.type.SqlTimestamp
 
toString() - Method in class io.prestosql.spi.type.SqlTimestampWithTimeZone
 
toString() - Method in class io.prestosql.spi.type.SqlTimeWithTimeZone
 
toString() - Method in class io.prestosql.spi.type.SqlVarbinary
 
toString() - Method in class io.prestosql.spi.type.TimeZoneKey
 
toString() - Method in class io.prestosql.spi.type.TypeId
 
toString() - Method in class io.prestosql.spi.type.TypeParameter
 
toString() - Method in class io.prestosql.spi.type.TypeSignature
 
toString() - Method in class io.prestosql.spi.type.TypeSignatureParameter
 
toString() - Method in class io.prestosql.spi.type.VarcharType
 
toString() - Method in class io.prestosql.spi.WarningCode
 
toString(long, int) - Static method in class io.prestosql.spi.type.Decimals
 
toString(Slice, int) - Static method in class io.prestosql.spi.type.Decimals
 
toString(ConnectorSession) - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
toString(ConnectorSession) - Method in class io.prestosql.spi.predicate.Domain
 
toString(ConnectorSession) - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
toString(ConnectorSession) - Method in class io.prestosql.spi.predicate.Marker
 
toString(ConnectorSession) - Method in class io.prestosql.spi.predicate.Range
 
toString(ConnectorSession) - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
toString(ConnectorSession) - Method in class io.prestosql.spi.predicate.TupleDomain
 
toString(ConnectorSession) - Method in interface io.prestosql.spi.predicate.ValueSet
 
toString(BigInteger, int) - Static method in class io.prestosql.spi.type.Decimals
 
TOTAL_SIZE_IN_BYTES - io.prestosql.spi.statistics.ColumnStatisticType
 
toType() - Method in annotation type io.prestosql.spi.function.CastDependency
 
toUnscaledString(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
toWarningCode() - Method in enum io.prestosql.spi.connector.StandardWarningCode
 
toWarningCode() - Method in interface io.prestosql.spi.WarningCodeSupplier
 
TRANSACTION_ALREADY_ABORTED - io.prestosql.spi.StandardErrorCode
 
TRANSACTION_CONFLICT - io.prestosql.spi.StandardErrorCode
 
transform(Function<Ranges, T>, Function<DiscreteValues, T>, Function<AllOrNone, T>) - Method in interface io.prestosql.spi.predicate.ValuesProcessor
 
transform(Function<T, U>) - Method in class io.prestosql.spi.predicate.TupleDomain
 
transformDomains(BiFunction<T, Domain, Domain>) - Method in class io.prestosql.spi.predicate.TupleDomain
 
translate(Function<E, Optional<T>>) - Method in class io.prestosql.spi.connector.ConstantProperty
 
translate(Function<E, Optional<T>>) - Method in class io.prestosql.spi.connector.GroupingProperty
 
translate(Function<E, Optional<T>>) - Method in interface io.prestosql.spi.connector.LocalProperty
 
translate(Function<E, Optional<T>>) - Method in class io.prestosql.spi.connector.SortingProperty
Returns Optional.empty() if the column could not be translated
trimTrailingSpaces(Slice) - Static method in class io.prestosql.spi.type.Chars
 
truncateToLength(Slice, int) - Static method in class io.prestosql.spi.type.Varchars
 
truncateToLength(Slice, Type) - Static method in class io.prestosql.spi.type.Varchars
 
truncateToLength(Slice, VarcharType) - Static method in class io.prestosql.spi.type.Varchars
 
truncateToLengthAndTrimSpaces(Slice, int) - Static method in class io.prestosql.spi.type.Chars
 
truncateToLengthAndTrimSpaces(Slice, CharType) - Static method in class io.prestosql.spi.type.Chars
 
truncateToLengthAndTrimSpaces(Slice, Type) - Static method in class io.prestosql.spi.type.Chars
 
tryGetHashTable() - Method in class io.prestosql.spi.block.SingleMapBlock
 
TupleDomain<T> - Class in io.prestosql.spi.predicate
Defines a set of valid tuples according to the constraints on each of its constituent columns
TupleDomain.ColumnDomain<C> - Class in io.prestosql.spi.predicate
 
Type - Interface in io.prestosql.spi.type
 
TYPE - io.prestosql.spi.type.ParameterKind
 
TYPE_MISMATCH - io.prestosql.spi.StandardErrorCode
 
TYPE_NOT_FOUND - io.prestosql.spi.StandardErrorCode
 
Type.Range - Class in io.prestosql.spi.type
 
TypeId - Class in io.prestosql.spi.type
Represents an opaque identifier for a Type than can be used for serialization or storage in external systems.
TypeManager - Interface in io.prestosql.spi.type
 
TypeNotFoundException - Exception in io.prestosql.spi.type
 
TypeNotFoundException(TypeSignature) - Constructor for exception io.prestosql.spi.type.TypeNotFoundException
 
TypeNotFoundException(TypeSignature, Throwable) - Constructor for exception io.prestosql.spi.type.TypeNotFoundException
 
typeParameter(TypeSignature) - Static method in class io.prestosql.spi.type.TypeSignatureParameter
 
TypeParameter - Class in io.prestosql.spi.type
 
TypeParameter - Annotation Type in io.prestosql.spi.function
 
TypeParameters - Annotation Type in io.prestosql.spi.function
 
TypeParameterSpecialization - Annotation Type in io.prestosql.spi.function
 
TypeSerde - Class in io.prestosql.spi.type
 
TypeSignature - Class in io.prestosql.spi.type
 
TypeSignature(String, TypeSignatureParameter...) - Constructor for class io.prestosql.spi.type.TypeSignature
 
TypeSignature(String, List<TypeSignatureParameter>) - Constructor for class io.prestosql.spi.type.TypeSignature
 
TypeSignatureParameter - Class in io.prestosql.spi.type
 
TypeUtils - Class in io.prestosql.spi.type
 
typeVariable() - Method in annotation type io.prestosql.spi.function.WindowFunctionSignature
 
typeVariable(String) - Static method in class io.prestosql.spi.type.TypeSignatureParameter
 

U

UNBOUNDED_LENGTH - Static variable in class io.prestosql.spi.type.VarcharType
 
UNGROUPED_SCHEDULING - io.prestosql.spi.connector.ConnectorSplitManager.SplitSchedulingStrategy
 
union(Domain) - Method in class io.prestosql.spi.predicate.Domain
 
union(ValueSet) - Method in class io.prestosql.spi.predicate.AllOrNoneValueSet
 
union(ValueSet) - Method in class io.prestosql.spi.predicate.EquatableValueSet
 
union(ValueSet) - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
union(ValueSet) - Method in interface io.prestosql.spi.predicate.ValueSet
 
union(DoubleRange, DoubleRange) - Static method in class io.prestosql.spi.statistics.DoubleRange
 
union(Collection<ValueSet>) - Method in class io.prestosql.spi.predicate.SortedRangeSet
 
union(Collection<ValueSet>) - Method in interface io.prestosql.spi.predicate.ValueSet
 
union(List<Domain>) - Static method in class io.prestosql.spi.predicate.Domain
 
unknown() - Static method in class io.prestosql.spi.statistics.Estimate
 
UNKNOWN_TRANSACTION - io.prestosql.spi.StandardErrorCode
 
unpackMillisUtc(long) - Static method in class io.prestosql.spi.type.DateTimeEncoding
 
unpackZoneKey(long) - Static method in class io.prestosql.spi.type.DateTimeEncoding
 
UNSCALED_DECIMAL_128_SLICE_LENGTH - Static variable in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
unscaledDecimal() - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
unscaledDecimal(long) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
unscaledDecimal(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
unscaledDecimal(String) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
unscaledDecimal(BigInteger) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
UnscaledDecimal128Arithmetic - Class in io.prestosql.spi.type
128 bit unscaled decimal arithmetic.
unscaledDecimalToBigInteger(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
unscaledDecimalToUnscaledLong(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
unscaledDecimalToUnscaledLongUnsafe(Slice) - Static method in class io.prestosql.spi.type.UnscaledDecimal128Arithmetic
 
UNSUPPORTED_ISOLATION_LEVEL - io.prestosql.spi.StandardErrorCode
 
UNSUPPORTED_SUBQUERY - io.prestosql.spi.StandardErrorCode
 
UpdatablePageSource - Interface in io.prestosql.spi.connector
 
UPDATE - io.prestosql.spi.security.Privilege
 
updateMillisUtc(long, long) - Static method in class io.prestosql.spi.type.DateTimeEncoding
 
upperUnbounded(Type) - Static method in class io.prestosql.spi.predicate.Marker
 
USER - io.prestosql.spi.security.PrincipalType
 
USER_CANCELED - io.prestosql.spi.StandardErrorCode
 
USER_ERROR - io.prestosql.spi.ErrorType
 
usesLegacyTableLayouts() - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Whether the connector uses the legacy Table Layout feature.
UTC_KEY - Static variable in class io.prestosql.spi.type.TimeZoneKey
 
Utils - Class in io.prestosql.spi.predicate
 
UUID - Static variable in class io.prestosql.spi.type.StandardTypes
 

V

validateId(String) - Static method in class io.prestosql.spi.QueryId
 
validateScan(ConnectorSession, ConnectorTableHandle) - Method in interface io.prestosql.spi.connector.ConnectorMetadata
Allows the connector to reject the table scan produced by the planner.
value() - Method in annotation type io.prestosql.spi.function.AggregationFunction
 
value() - Method in annotation type io.prestosql.spi.function.AggregationState
 
value() - Method in annotation type io.prestosql.spi.function.AggregationStateSerializerFactory
 
value() - Method in annotation type io.prestosql.spi.function.Description
 
value() - Method in annotation type io.prestosql.spi.function.LiteralParameter
 
value() - Method in annotation type io.prestosql.spi.function.LiteralParameters
 
value() - Method in annotation type io.prestosql.spi.function.OutputFunction
 
value() - Method in annotation type io.prestosql.spi.function.ScalarFunction
 
value() - Method in annotation type io.prestosql.spi.function.ScalarOperator
 
value() - Method in annotation type io.prestosql.spi.function.SqlNullable
 
value() - Method in annotation type io.prestosql.spi.function.SqlType
 
value() - Method in annotation type io.prestosql.spi.function.TypeParameter
 
value() - Method in annotation type io.prestosql.spi.function.TypeParameters
 
value() - Method in annotation type io.prestosql.spi.function.WindowFunctionSignatures
 
ValueEntry(Type, Block) - Constructor for class io.prestosql.spi.predicate.EquatableValueSet.ValueEntry
 
valueOf(String) - Static method in enum io.prestosql.spi.block.SortOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.connector.ConnectorCapabilities
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.connector.ConnectorSplitManager.SplitSchedulingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.connector.SampleType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.connector.SortOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.connector.StandardWarningCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.connector.SystemTable.Distribution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.ErrorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.function.InvocationConvention.InvocationArgumentConvention
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.function.InvocationConvention.InvocationReturnConvention
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.function.OperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.predicate.Marker.Bound
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class io.prestosql.spi.QueryId
 
valueOf(String) - Static method in enum io.prestosql.spi.resourcegroups.QueryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.resourcegroups.ResourceGroupState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.resourcegroups.SchedulingPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.security.PrincipalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.security.Privilege
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.security.SelectedRole.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class io.prestosql.spi.security.SelectedRole
 
valueOf(String) - Static method in enum io.prestosql.spi.StandardErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.statistics.ColumnStatisticType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.statistics.TableStatisticType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.transaction.IsolationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.prestosql.spi.type.ParameterKind
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.prestosql.spi.block.SortOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.connector.ConnectorCapabilities
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.connector.ConnectorSplitManager.SplitSchedulingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.connector.SampleType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.connector.SortOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.connector.StandardWarningCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.connector.SystemTable.Distribution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.ErrorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.function.InvocationConvention.InvocationArgumentConvention
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.function.InvocationConvention.InvocationReturnConvention
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.function.OperatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.predicate.Marker.Bound
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.resourcegroups.QueryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.resourcegroups.ResourceGroupState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.resourcegroups.SchedulingPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.security.PrincipalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.security.Privilege
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.security.SelectedRole.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.StandardErrorCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.statistics.ColumnStatisticType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.statistics.TableStatisticType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.transaction.IsolationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.prestosql.spi.type.ParameterKind
Returns an array containing the constants of this enum type, in the order they are declared.
ValueSet - Interface in io.prestosql.spi.predicate
 
ValuesProcessor - Interface in io.prestosql.spi.predicate
 
ValueWindowFunction - Class in io.prestosql.spi.function
 
ValueWindowFunction() - Constructor for class io.prestosql.spi.function.ValueWindowFunction
 
VARBINARY - Static variable in class io.prestosql.spi.type.StandardTypes
 
VARBINARY - Static variable in class io.prestosql.spi.type.VarbinaryType
 
VarbinaryType - Class in io.prestosql.spi.type
 
VARCHAR - Static variable in class io.prestosql.spi.type.StandardTypes
 
VARCHAR - Static variable in class io.prestosql.spi.type.VarcharType
 
Varchars - Class in io.prestosql.spi.type
 
VarcharType - Class in io.prestosql.spi.type
 
Variable - Class in io.prestosql.spi.expression
 
Variable(String, Type) - Constructor for class io.prestosql.spi.expression.Variable
 
VARIABLE - io.prestosql.spi.type.ParameterKind
 
VariableWidthBlock - Class in io.prestosql.spi.block
 
VariableWidthBlock(int, Slice, int[], Optional<boolean[]>) - Constructor for class io.prestosql.spi.block.VariableWidthBlock
 
VariableWidthBlockBuilder - Class in io.prestosql.spi.block
 
VariableWidthBlockBuilder(BlockBuilderStatus, int, int) - Constructor for class io.prestosql.spi.block.VariableWidthBlockBuilder
 
VariableWidthBlockEncoding - Class in io.prestosql.spi.block
 
VariableWidthBlockEncoding() - Constructor for class io.prestosql.spi.block.VariableWidthBlockEncoding
 
VariableWidthType - Interface in io.prestosql.spi.type
VariableWidthType is a type that can have a different size for every value.
VersionEmbedder - Interface in io.prestosql.spi
 
VIEW_IS_RECURSIVE - io.prestosql.spi.StandardErrorCode
 
VIEW_IS_STALE - io.prestosql.spi.StandardErrorCode
 
ViewColumn(String, TypeId) - Constructor for class io.prestosql.spi.connector.ConnectorViewDefinition.ViewColumn
 
ViewExpression - Class in io.prestosql.spi.security
 
ViewExpression(String, Optional<String>, Optional<String>, String) - Constructor for class io.prestosql.spi.security.ViewExpression
 
ViewNotFoundException - Exception in io.prestosql.spi.connector
 
ViewNotFoundException(SchemaTableName) - Constructor for exception io.prestosql.spi.connector.ViewNotFoundException
 
ViewNotFoundException(SchemaTableName, String) - Constructor for exception io.prestosql.spi.connector.ViewNotFoundException
 
ViewNotFoundException(SchemaTableName, String, Throwable) - Constructor for exception io.prestosql.spi.connector.ViewNotFoundException
 
ViewNotFoundException(SchemaTableName, Throwable) - Constructor for exception io.prestosql.spi.connector.ViewNotFoundException
 

W

WarningCode - Class in io.prestosql.spi
 
WarningCode(int, String) - Constructor for class io.prestosql.spi.WarningCode
 
WarningCodeSupplier - Interface in io.prestosql.spi
 
WEIGHTED - io.prestosql.spi.resourcegroups.SchedulingPolicy
 
WEIGHTED_FAIR - io.prestosql.spi.resourcegroups.SchedulingPolicy
 
WindowFunction - Interface in io.prestosql.spi.function
 
WindowFunctionSignature - Annotation Type in io.prestosql.spi.function
 
WindowFunctionSignatures - Annotation Type in io.prestosql.spi.function
 
windowIndex - Variable in class io.prestosql.spi.function.RankingWindowFunction
 
windowIndex - Variable in class io.prestosql.spi.function.ValueWindowFunction
 
WindowIndex - Interface in io.prestosql.spi.function
A window index contains the sorted values for a window partition.
withAdditionalExtraCredentials(Map<String, String>) - Method in class io.prestosql.spi.security.Identity.Builder
 
withAdditionalGroups(Set<String>) - Method in class io.prestosql.spi.security.Identity.Builder
 
withAdditionalRoles(Map<String, SelectedRole>) - Method in class io.prestosql.spi.security.Identity.Builder
 
withColumnDomains(Map<T, Domain>) - Static method in class io.prestosql.spi.predicate.TupleDomain
 
withConstants(Set<E>) - Method in interface io.prestosql.spi.connector.LocalProperty
Simplfies this LocalProperty provided that the specified inputs are constants
withDefaultPort(int) - Method in class io.prestosql.spi.HostAddress
Provide a default port if the parsed string contained only a host.
withExtraCredentials(Map<String, String>) - Method in class io.prestosql.spi.security.ConnectorIdentity.Builder
 
withExtraCredentials(Map<String, String>) - Method in class io.prestosql.spi.security.Identity.Builder
 
withGroups(Set<String>) - Method in class io.prestosql.spi.security.ConnectorIdentity.Builder
 
withGroups(Set<String>) - Method in class io.prestosql.spi.security.Identity.Builder
 
withMaxPageSize(int, List<? extends Type>) - Static method in class io.prestosql.spi.PageBuilder
 
withOnDestroy(Runnable) - Method in class io.prestosql.spi.security.Identity.Builder
 
withPrincipal(Principal) - Method in class io.prestosql.spi.security.ConnectorIdentity.Builder
 
withPrincipal(Principal) - Method in class io.prestosql.spi.security.Identity.Builder
 
withPrincipal(Optional<Principal>) - Method in class io.prestosql.spi.security.ConnectorIdentity.Builder
 
withPrincipal(Optional<Principal>) - Method in class io.prestosql.spi.security.Identity.Builder
 
withRole(SelectedRole) - Method in class io.prestosql.spi.security.ConnectorIdentity.Builder
 
withRole(String, SelectedRole) - Method in class io.prestosql.spi.security.Identity.Builder
 
withRole(Optional<SelectedRole>) - Method in class io.prestosql.spi.security.ConnectorIdentity.Builder
 
withRoles(Map<String, SelectedRole>) - Method in class io.prestosql.spi.security.Identity.Builder
 
withUser(String) - Method in class io.prestosql.spi.security.Identity.Builder
 
write(BlockBuilder, long, int) - Method in class io.prestosql.spi.type.LongTimestampType
 
writeBigDecimal(DecimalType, BlockBuilder, BigDecimal) - Static method in class io.prestosql.spi.type.Decimals
 
writeBlock(SliceOutput, Block) - Method in interface io.prestosql.spi.block.BlockEncodingSerde
Write a blockEncoding to the output.
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.ArrayBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in interface io.prestosql.spi.block.BlockEncoding
Write the specified block to the specified output
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.ByteArrayBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.DictionaryBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.Int128ArrayBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.Int96ArrayBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.IntArrayBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.LazyBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.LongArrayBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.MapBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.RowBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.RunLengthBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.ShortArrayBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.SingleMapBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.SingleRowBlockEncoding
 
writeBlock(BlockEncodingSerde, SliceOutput, Block) - Method in class io.prestosql.spi.block.VariableWidthBlockEncoding
 
writeBoolean(BlockBuilder, boolean) - Method in class io.prestosql.spi.type.AbstractType
 
writeBoolean(BlockBuilder, boolean) - Method in class io.prestosql.spi.type.BooleanType
 
writeBoolean(BlockBuilder, boolean) - Method in interface io.prestosql.spi.type.Type
Writes the boolean value into the BlockBuilder.
writeByte(int) - Method in interface io.prestosql.spi.block.BlockBuilder
Write a byte to the current entry;
writeByte(int) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
writeByte(int) - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
writeByte(int) - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
writeByte(int) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
writeByte(int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
writeBytes(Slice, int, int) - Method in interface io.prestosql.spi.block.BlockBuilder
Write a byte sequences to the current entry;
writeBytes(Slice, int, int) - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
writeBytes(Slice, int, int) - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
writeBytes(Slice, int, int) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
writeBytes(Slice, int, int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
writeBytesTo(int, int, int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
writeBytesTo(int, int, int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
writeBytesTo(int, int, int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
writeBytesTo(int, int, int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
writeBytesTo(int, int, int, BlockBuilder) - Method in interface io.prestosql.spi.block.Block
Appends the byte sequences at offset in the value at position to blockBuilder.
writeBytesTo(int, int, int, BlockBuilder) - Method in class io.prestosql.spi.block.DictionaryBlock
 
writeBytesTo(int, int, int, BlockBuilder) - Method in class io.prestosql.spi.block.LazyBlock
 
writeBytesTo(int, int, int, BlockBuilder) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
writeDouble(BlockBuilder, double) - Method in class io.prestosql.spi.type.AbstractType
 
writeDouble(BlockBuilder, double) - Method in class io.prestosql.spi.type.DoubleType
 
writeDouble(BlockBuilder, double) - Method in interface io.prestosql.spi.type.Type
Writes the double value into the BlockBuilder.
writeInt(int) - Method in interface io.prestosql.spi.block.BlockBuilder
Write a int to the current entry;
writeInt(int) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
writeInt(int) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
writeInt(int) - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
writeInt(int) - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
writeInt(int) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
writeInt(int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
writeLong(long) - Method in interface io.prestosql.spi.block.BlockBuilder
Write a long to the current entry;
writeLong(long) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
writeLong(long) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
writeLong(long) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
writeLong(long) - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
writeLong(long) - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
writeLong(long) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
writeLong(long) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
writeLong(BlockBuilder, long) - Method in class io.prestosql.spi.type.AbstractIntType
 
writeLong(BlockBuilder, long) - Method in class io.prestosql.spi.type.AbstractLongType
 
writeLong(BlockBuilder, long) - Method in class io.prestosql.spi.type.AbstractType
 
writeLong(BlockBuilder, long) - Method in class io.prestosql.spi.type.RealType
 
writeLong(BlockBuilder, long) - Method in class io.prestosql.spi.type.ShortTimestampType
 
writeLong(BlockBuilder, long) - Method in class io.prestosql.spi.type.SmallintType
 
writeLong(BlockBuilder, long) - Method in class io.prestosql.spi.type.TinyintType
 
writeLong(BlockBuilder, long) - Method in interface io.prestosql.spi.type.Type
Writes the long value into the BlockBuilder.
writeNativeValue(Type, BlockBuilder, Object) - Static method in class io.prestosql.spi.type.TypeUtils
Write a native value object to the current entry of blockBuilder.
writeObject(BlockBuilder, Object) - Method in class io.prestosql.spi.type.AbstractType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.spi.type.ArrayType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.spi.type.LongTimestampType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.spi.type.MapType
 
writeObject(BlockBuilder, Object) - Method in class io.prestosql.spi.type.RowType
 
writeObject(BlockBuilder, Object) - Method in interface io.prestosql.spi.type.Type
Writes the Object value into the BlockBuilder.
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractArrayBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractMapBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractRowBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractSingleArrayBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractSingleMapBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractSingleRowBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.AbstractVariableWidthBlock
 
writePositionTo(int, BlockBuilder) - Method in interface io.prestosql.spi.block.Block
Appends the value at position to blockBuilder and close the entry.
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.ByteArrayBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.ByteArrayBlockBuilder
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.DictionaryBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.Int128ArrayBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.Int128ArrayBlockBuilder
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.Int96ArrayBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.Int96ArrayBlockBuilder
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.IntArrayBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.IntArrayBlockBuilder
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.LazyBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.LongArrayBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.LongArrayBlockBuilder
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.RunLengthEncodedBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.ShortArrayBlock
 
writePositionTo(int, BlockBuilder) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
writeShort(int) - Method in interface io.prestosql.spi.block.BlockBuilder
Write a short to the current entry;
writeShort(int) - Method in class io.prestosql.spi.block.ShortArrayBlockBuilder
 
writeShort(int) - Method in class io.prestosql.spi.block.SingleArrayBlockWriter
 
writeShort(int) - Method in class io.prestosql.spi.block.SingleMapBlockWriter
 
writeShort(int) - Method in class io.prestosql.spi.block.SingleRowBlockWriter
 
writeShort(int) - Method in class io.prestosql.spi.block.VariableWidthBlockBuilder
 
writeShortDecimal(BlockBuilder, long) - Static method in class io.prestosql.spi.type.Decimals
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.spi.type.AbstractType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.spi.type.ArrayType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.spi.type.CharType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.spi.type.HyperLogLogType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.spi.type.P4HyperLogLogType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.spi.type.QuantileDigestType
 
writeSlice(BlockBuilder, Slice) - Method in interface io.prestosql.spi.type.Type
Writes the Slice value into the BlockBuilder.
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.spi.type.VarbinaryType
 
writeSlice(BlockBuilder, Slice) - Method in class io.prestosql.spi.type.VarcharType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.spi.type.AbstractType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.spi.type.ArrayType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.spi.type.CharType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.spi.type.HyperLogLogType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.spi.type.P4HyperLogLogType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.spi.type.QuantileDigestType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in interface io.prestosql.spi.type.Type
Writes the Slice value into the BlockBuilder.
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.spi.type.VarbinaryType
 
writeSlice(BlockBuilder, Slice, int, int) - Method in class io.prestosql.spi.type.VarcharType
 
writeString(BlockBuilder, String) - Method in class io.prestosql.spi.type.CharType
 
writeString(BlockBuilder, String) - Method in class io.prestosql.spi.type.VarcharType
 
writeType(SliceOutput, Type) - Static method in class io.prestosql.spi.type.TypeSerde
 

X

XX_HASH_64 - io.prestosql.spi.function.OperatorType
 

Z

zero() - Static method in class io.prestosql.spi.statistics.Estimate
 
$ A B C D E F G H I J L M N O P Q R S T U V W X Z 
All Classes All Packages